- ABlockReader - Interface in org.apache.accumulo.core.file.blockfile
-
- ABlockWriter - Interface in org.apache.accumulo.core.file.blockfile
-
- AboutCommand - Class in org.apache.accumulo.core.util.shell.commands
-
- AboutCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.AboutCommand
-
- AbstractInputFormat<K,V> - Class in org.apache.accumulo.core.client.mapred
-
An abstract input format to provide shared methods common to all other input format classes.
- AbstractInputFormat() - Constructor for class org.apache.accumulo.core.client.mapred.AbstractInputFormat
-
- AbstractInputFormat<K,V> - Class in org.apache.accumulo.core.client.mapreduce
-
An abstract input format to provide shared methods common to all other input format classes.
- AbstractInputFormat() - Constructor for class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
-
- AbstractInputFormat.AbstractRecordReader<K,V> - Class in org.apache.accumulo.core.client.mapred
-
An abstract base class to be used to create
RecordReader
instances that convert from Accumulo
Key
/
Value
pairs to the user's K/V types.
- AbstractInputFormat.AbstractRecordReader() - Constructor for class org.apache.accumulo.core.client.mapred.AbstractInputFormat.AbstractRecordReader
-
- AbstractInputFormat.AbstractRecordReader<K,V> - Class in org.apache.accumulo.core.client.mapreduce
-
An abstract base class to be used to create
RecordReader
instances that convert from Accumulo
Key
/
Value
pairs to the user's K/V types.
- AbstractInputFormat.AbstractRecordReader() - Constructor for class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
-
- accept(String) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration.AllFilter
-
- accept(String) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration.PrefixFilter
-
- accept(String) - Method in interface org.apache.accumulo.core.conf.AccumuloConfiguration.PropertyFilter
-
- accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.Filter
-
- accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.system.ColumnQualifierFilter
-
- accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.system.VisibilityFilter
-
- accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.AgeOffFilter
-
Accepts entries whose timestamps are less than currentTime - threshold.
- accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.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
-
- acceptRow(SortedKeyValueIterator<Key, Value>) - Method in class org.apache.accumulo.core.iterators.user.RowFilter
-
Implementation should return false to suppress a row.
- access(long) - Method in class org.apache.accumulo.core.file.blockfile.cache.CachedBlock
-
Block has been accessed.
- ACCUMULO_NAMESPACE - Static variable in class org.apache.accumulo.core.client.impl.Namespaces
-
- ACCUMULO_NAMESPACE_ID - Static variable in class org.apache.accumulo.core.client.impl.Namespaces
-
- AccumuloConfiguration - Class in org.apache.accumulo.core.conf
-
- AccumuloConfiguration() - Constructor for class org.apache.accumulo.core.conf.AccumuloConfiguration
-
- AccumuloConfiguration.AllFilter - Class in org.apache.accumulo.core.conf
-
- AccumuloConfiguration.AllFilter() - Constructor for class org.apache.accumulo.core.conf.AccumuloConfiguration.AllFilter
-
- AccumuloConfiguration.PrefixFilter - Class in org.apache.accumulo.core.conf
-
- AccumuloConfiguration.PrefixFilter(String) - Constructor for class org.apache.accumulo.core.conf.AccumuloConfiguration.PrefixFilter
-
- AccumuloConfiguration.PropertyFilter - Interface in org.apache.accumulo.core.conf
-
- 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(Throwable) - Constructor for exception org.apache.accumulo.core.client.AccumuloException
-
- AccumuloException(String, Throwable) - Constructor for exception org.apache.accumulo.core.client.AccumuloException
-
- AccumuloFileOutputFormat - Class in org.apache.accumulo.core.client.mapred
-
This class allows MapReduce jobs to write output in the Accumulo data file format.
Care should be taken to write only sorted data (sorted by
Key
), as this is an important requirement of Accumulo data files.
- AccumuloFileOutputFormat() - Constructor for class org.apache.accumulo.core.client.mapred.AccumuloFileOutputFormat
-
- AccumuloFileOutputFormat - Class in org.apache.accumulo.core.client.mapreduce
-
This class allows MapReduce jobs to write output in the Accumulo data file format.
Care should be taken to write only sorted data (sorted by
Key
), as this is an important requirement of Accumulo data files.
- AccumuloFileOutputFormat() - Constructor for class org.apache.accumulo.core.client.mapreduce.AccumuloFileOutputFormat
-
- AccumuloInputFormat - Class in org.apache.accumulo.core.client.mapred
-
This class allows MapReduce jobs to use Accumulo as the source of data.
- AccumuloInputFormat() - Constructor for class org.apache.accumulo.core.client.mapred.AccumuloInputFormat
-
- AccumuloInputFormat - Class in org.apache.accumulo.core.client.mapreduce
-
This class allows MapReduce jobs to use Accumulo as the source of data.
- AccumuloInputFormat() - Constructor for class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
-
- AccumuloMultiTableInputFormat - Class in org.apache.accumulo.core.client.mapred
-
This class allows MapReduce jobs to use multiple Accumulo tables as the source of data.
- AccumuloMultiTableInputFormat() - Constructor for class org.apache.accumulo.core.client.mapred.AccumuloMultiTableInputFormat
-
- AccumuloMultiTableInputFormat - Class in org.apache.accumulo.core.client.mapreduce
-
This class allows MapReduce jobs to use multiple Accumulo tables as the source of data.
- AccumuloMultiTableInputFormat() - Constructor for class org.apache.accumulo.core.client.mapreduce.AccumuloMultiTableInputFormat
-
- AccumuloOutputFormat - Class in org.apache.accumulo.core.client.mapred
-
This class allows MapReduce jobs to use Accumulo as the sink for data.
- AccumuloOutputFormat() - Constructor for class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
-
- AccumuloOutputFormat - Class in org.apache.accumulo.core.client.mapreduce
-
This class allows MapReduce jobs to use Accumulo as the sink for data.
- AccumuloOutputFormat() - Constructor for class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
-
- AccumuloOutputFormat.AccumuloRecordWriter - Class in org.apache.accumulo.core.client.mapred
-
A base class to be used to create RecordWriter
instances that write to Accumulo.
- AccumuloOutputFormat.AccumuloRecordWriter(JobConf) - Constructor for class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat.AccumuloRecordWriter
-
- AccumuloOutputFormat.AccumuloRecordWriter - Class in org.apache.accumulo.core.client.mapreduce
-
A base class to be used to create RecordWriter
instances that write to Accumulo.
- AccumuloOutputFormat.AccumuloRecordWriter(TaskAttemptContext) - Constructor for class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat.AccumuloRecordWriter
-
- AccumuloRowInputFormat - Class in org.apache.accumulo.core.client.mapred
-
This class allows MapReduce jobs to use Accumulo as the source of data.
- AccumuloRowInputFormat() - Constructor for class org.apache.accumulo.core.client.mapred.AccumuloRowInputFormat
-
- AccumuloRowInputFormat - Class in org.apache.accumulo.core.client.mapreduce
-
This class allows MapReduce jobs to use Accumulo as the source of data.
- AccumuloRowInputFormat() - Constructor for class org.apache.accumulo.core.client.mapreduce.AccumuloRowInputFormat
-
- AccumuloSecurityException - Exception in org.apache.accumulo.core.client
-
An Accumulo Exception for security violations, authentication failures, authorization failures, etc.
- AccumuloSecurityException(ThriftSecurityException) - Constructor for exception org.apache.accumulo.core.client.AccumuloSecurityException
-
Construct a user-facing exception from a serialized version.
- AccumuloSecurityException(String, SecurityErrorCode, Throwable) - 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) - Constructor for exception org.apache.accumulo.core.client.AccumuloSecurityException
-
- AccumuloSecurityException(String, SecurityErrorCode, String) - Constructor for exception org.apache.accumulo.core.client.AccumuloSecurityException
-
- AccumuloServerException - Exception in org.apache.accumulo.core.client.impl
-
This class is intended to encapsulate errors that occurred on the server side.
- AccumuloServerException(String, TApplicationException) - Constructor for exception org.apache.accumulo.core.client.impl.AccumuloServerException
-
- 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() - Constructor for class org.apache.accumulo.core.client.admin.ActiveCompaction
-
- ActiveCompaction - Class in org.apache.accumulo.core.tabletserver.thrift
-
- ActiveCompaction() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
-
- ActiveCompaction(TKeyExtent, long, List<String>, String, CompactionType, CompactionReason, String, long, long, List<IterInfo>, Map<String, Map<String, String>>) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
-
- ActiveCompaction(ActiveCompaction) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
-
Performs a deep copy on other.
- ActiveCompaction._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ActiveCompaction.CompactionReason - Enum in org.apache.accumulo.core.client.admin
-
- ActiveCompaction.CompactionType - Enum in org.apache.accumulo.core.client.admin
-
- ActiveCompactionImpl - Class in org.apache.accumulo.core.client.impl
-
- ActiveScan - Class in org.apache.accumulo.core.client.admin
-
A class that contains information about an ActiveScan
- ActiveScan() - Constructor for class org.apache.accumulo.core.client.admin.ActiveScan
-
- ActiveScan - Class in org.apache.accumulo.core.tabletserver.thrift
-
- ActiveScan() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
-
- ActiveScan(String, String, String, long, long, ScanType, ScanState, TKeyExtent, List<TColumn>, List<IterInfo>, Map<String, Map<String, String>>, List<ByteBuffer>) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
-
- ActiveScan(ActiveScan) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
-
Performs a deep copy on other.
- ActiveScan._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ActiveScanImpl - Class in org.apache.accumulo.core.client.impl
-
A class that contains information about an ActiveScan
- add(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.
- add(List<Key>) - Method in class org.apache.accumulo.core.bloomfilter.Filter
-
Adds a list of keys to this filter.
- add(Collection<Key>) - Method in class org.apache.accumulo.core.bloomfilter.Filter
-
Adds a collection of keys to this filter.
- add(Key[]) - Method in class org.apache.accumulo.core.bloomfilter.Filter
-
Adds an array of keys to this filter.
- add(Map.Entry<Key, Value>) - Method in class org.apache.accumulo.core.client.IsolatedScanner.MemoryRowBuffer
-
- add(ConstraintViolationSummary) - Method in class org.apache.accumulo.core.constraints.Violations
-
- add(Violations) - Method in class org.apache.accumulo.core.constraints.Violations
-
- add(List<ConstraintViolationSummary>) - Method in class org.apache.accumulo.core.constraints.Violations
-
- add(CachedBlock) - Method in class org.apache.accumulo.core.file.blockfile.cache.CachedBlockQueue
-
Attempt to add the specified cached block to this queue.
- add(Key, int, long, long, long) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.BufferedWriter
-
- add(MultiLevelIndex.IndexEntry) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader.IndexIterator
-
- add(Key, int, long, long, long) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Writer
-
- add(Text) - Method in class org.apache.accumulo.core.iterators.conf.ColumnSet
-
- add(Text, Text) - Method in class org.apache.accumulo.core.iterators.conf.ColumnSet
-
- add(ColumnVisibility.Node) - Method in class org.apache.accumulo.core.security.ColumnVisibility.Node
-
- add(byte[], int, int) - Method in class org.apache.accumulo.core.util.UnsynchronizedBuffer.Writer
-
- add(boolean) - Method in class org.apache.accumulo.core.util.UnsynchronizedBuffer.Writer
-
- AddAuthsCommand - Class in org.apache.accumulo.core.util.shell.commands
-
- AddAuthsCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.AddAuthsCommand
-
- addCacheFile(URI, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.DistributedCacheHelper
-
- addCondition(Condition) - Method in class org.apache.accumulo.core.data.ConditionalMutation
-
- addConstraint(String, String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
-
Add a new constraint to a namespace.
- addConstraint(String, String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
Add a new constraint to a table.
- addConstraint(String, String) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsHelper
-
- addConstraint(String, String) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsImpl
-
- addConstraint(String, String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsHelper
-
- addConstraint(String, String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
-
- addIterator(JobConf, IteratorSetting) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
-
Encode an iterator on the input for this job.
- addIterator(Job, IteratorSetting) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
-
Encode an iterator on the single input table for this job.
- addIterator(Class<?>, Configuration, IteratorSetting) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
-
Encode an iterator on the input for the single input table associated with this job.
- addIterator(Class<?>, Configuration, IteratorSetting) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator
-
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
- 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
-
- addListDeleteGroup(String) - Static method in class org.apache.accumulo.core.util.shell.commands.OptUtil
-
- addMutation(Mutation) - Method in interface org.apache.accumulo.core.client.BatchWriter
-
Queues one mutation to write.
- addMutation(Mutation) - Method in class org.apache.accumulo.core.client.impl.BatchWriterImpl
-
- addMutation(KeyExtent, T) - Method in class org.apache.accumulo.core.client.impl.TabletLocator.TabletServerMutations
-
- addMutation(String, Mutation) - Method in class org.apache.accumulo.core.client.impl.TabletServerBatchWriter
-
- addMutation(String, Iterator<Mutation>) - Method in class org.apache.accumulo.core.client.impl.TabletServerBatchWriter
-
- addMutation(String, Mutation) - Method in class org.apache.accumulo.core.client.mock.MockAccumulo
-
- addMutation(Mutation) - Method in class org.apache.accumulo.core.client.mock.MockBatchWriter
-
- addMutations(Iterable<Mutation>) - Method in interface org.apache.accumulo.core.client.BatchWriter
-
Queues several mutations to write.
- addMutations(Iterable<Mutation>) - Method in class org.apache.accumulo.core.client.impl.BatchWriterImpl
-
- addMutations(Iterable<Mutation>) - Method in class org.apache.accumulo.core.client.mock.MockBatchWriter
-
- addNamedOption(String, String) - Method in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
-
- addNode(RemoteSpan) - Method in class org.apache.accumulo.core.trace.SpanTree
-
- addObject(Text, K) - Method in class org.apache.accumulo.core.iterators.conf.ColumnToClassMapping
-
- addObject(Text, Text, K) - Method in class org.apache.accumulo.core.iterators.conf.ColumnToClassMapping
-
- addObserver(ConfigurationObserver) - Method in class org.apache.accumulo.core.conf.ObservableConfiguration
-
Adds an observer.
- addOption(String, String) - Method in class org.apache.accumulo.core.client.IteratorSetting
-
Add another option to the iterator.
- addOptions(Set<Map.Entry<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.IteratorSetting
-
Add many options to the iterator.
- addRange(Map<String, Map<KeyExtent, List<Range>>>, String, KeyExtent, Range) - Static method in class org.apache.accumulo.core.client.impl.TabletLocatorImpl
-
- AddressUtil - Class in org.apache.accumulo.core.util
-
- AddressUtil() - Constructor for class org.apache.accumulo.core.util.AddressUtil
-
- addScanIterator(IteratorSetting) - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
-
Adds server-side scan iterators.
- addScanIterator(IteratorSetting) - Method in interface org.apache.accumulo.core.client.ScannerBase
-
Add a server-side scan iterator.
- addScanIterators(Shell, CommandLine, Scanner, String) - Method in class org.apache.accumulo.core.util.shell.commands.ScanCommand
-
- addSource(SortedKeyValueIterator<Key, Value>) - Method in class org.apache.accumulo.core.iterators.system.HeapIterator
-
- addSource(SortedKeyValueIterator<Key, Value>, IteratorEnvironment, Text, boolean) - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
-
- addSplits(String, SortedSet<Text>) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
Ensures that tablets are split along a set of keys.
- addSplits(String, SortedSet<Text>) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
-
- addSplits(String, SortedSet<Text>) - Method in class org.apache.accumulo.core.client.mock.MockAccumulo
-
- addSplits(SortedSet<Text>) - Method in class org.apache.accumulo.core.client.mock.MockTable
-
- AddSplitsCommand - Class in org.apache.accumulo.core.util.shell.commands
-
- AddSplitsCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.AddSplitsCommand
-
- addStat(long) - Method in class org.apache.accumulo.core.util.Stat
-
- addSubcommand(Token) - Method in class org.apache.accumulo.core.util.shell.Token
-
- addSubcommand(Collection<String>) - Method in class org.apache.accumulo.core.util.shell.Token
-
- addTable(Text) - Method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat.AccumuloRecordWriter
-
- addTable(Text) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat.AccumuloRecordWriter
-
- addTerm(SortedKeyValueIterator<Key, Value>, Text, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.OrIterator
-
- addToArguments(ByteBuffer) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
-
- addToAuthorizations(ByteBuffer) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
-
- addToAuthorizations(ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
-
- addToAuthorizations(ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
-
- addToAuthorizations(ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
-
- addToAuthorizations(ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
-
- addToColumns(TColumn) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
-
- addToColumns(TColumn) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
-
- addToColumns(TColumn) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
-
- addToConditions(TCondition) - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
-
- addToDeadTabletServers(DeadServer) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
-
- addToFilenames(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
-
- addToFiles(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
-
- addToFullScans(TKeyExtent) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
-
- addToInputFiles(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
-
- addToIterators(TIteratorSetting) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
-
- addToLogSorts(RecoveryStatus) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
-
- addToMutations(TMutation) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
-
- addToNewTablets(TKeyExtent) - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
-
- addToResults(TKeyValue) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
-
- addToResults(TKeyValue) - Method in class org.apache.accumulo.core.data.thrift.ScanResult
-
- addToServersShuttingDown(String) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
-
- addToSsiList(IterInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
-
- addToSsiList(IterInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
-
- addToSsiList(IterInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
-
- addToSsiList(IterInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
-
- addToSuccess(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
-
- addToSuccess(TDiskUsage) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
-
- addToSuccess(ByteBuffer) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
-
- addToSuccess(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
-
- addToSuccess(TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
-
- addToSuccess(TCMResult) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
-
- addToSuccess(ActiveCompaction) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
-
- addToSuccess(ActiveScan) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
-
- addToSuccess(TabletStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
-
- addToSymbols(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
-
- addToTables(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
-
- addToTables(String) - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
-
- addToTServerInfo(TabletServerStatus) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
-
- addToValues(ByteBuffer) - Method in class org.apache.accumulo.core.data.thrift.TMutation
-
- addToViolationSummaries(TConstraintViolationSummary) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
-
- addToViolationSummaries(TConstraintViolationSummary) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
-
- addTTL(IteratorSetting, IteratorSetting.Column, Long) - Static method in class org.apache.accumulo.core.iterators.user.ColumnAgeOffFilter
-
A convenience method for adding or changing an age off threshold for a column.
- addUnnamedOption(String) - Method in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
-
- advanceToIntersection() - Method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
-
- advanceToIntersection() - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
-
- afterEndKey(Key) - Method in class org.apache.accumulo.core.data.Range
-
- age - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
-
- age - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
-
- AgeOffFilter - Class in org.apache.accumulo.core.iterators.user
-
A filter that ages off key/value pairs based on the Key's timestamp.
- AgeOffFilter() - Constructor for class org.apache.accumulo.core.iterators.user.AgeOffFilter
-
- aggregate() - Method in interface org.apache.accumulo.core.iterators.aggregation.Aggregator
-
Deprecated.
- aggregate() - Method in class org.apache.accumulo.core.iterators.aggregation.LongSummation
-
Deprecated.
- aggregate() - Method in class org.apache.accumulo.core.iterators.aggregation.NumArraySummation
-
Deprecated.
- aggregate() - Method in class org.apache.accumulo.core.iterators.aggregation.NumSummation
-
Deprecated.
- aggregate() - Method in class org.apache.accumulo.core.iterators.aggregation.StringMax
-
Deprecated.
- aggregate() - Method in class org.apache.accumulo.core.iterators.aggregation.StringMin
-
Deprecated.
- aggregate() - Method in class org.apache.accumulo.core.iterators.aggregation.StringSummation
-
Deprecated.
- aggregateStats(Map.Entry<Key, Value>) - Method in class org.apache.accumulo.core.util.format.AggregatingFormatter
-
Generate statistics from each
Map.Entry
, called for each entry to be iterated over.
- aggregateStats(Map.Entry<Key, Value>) - Method in class org.apache.accumulo.core.util.format.ShardedTableDistributionFormatter
-
- aggregateStats(Map.Entry<Key, Value>) - Method in class org.apache.accumulo.core.util.format.StatisticsDisplayFormatter
-
- AggregatingFormatter - Class in org.apache.accumulo.core.util.format
-
Formatter that will aggregate entries for various display purposes.
- AggregatingFormatter() - Constructor for class org.apache.accumulo.core.util.format.AggregatingFormatter
-
- AggregatingIterator - Class in org.apache.accumulo.core.iterators
-
- AggregatingIterator() - Constructor for class org.apache.accumulo.core.iterators.AggregatingIterator
-
Deprecated.
- AggregatingIterator(SortedKeyValueIterator<Key, Value>, ColumnToClassMapping<Aggregator>) - Constructor for class org.apache.accumulo.core.iterators.AggregatingIterator
-
Deprecated.
- Aggregator - Interface in org.apache.accumulo.core.iterators.aggregation
-
- AggregatorConfiguration - Class in org.apache.accumulo.core.iterators.aggregation.conf
-
- AggregatorConfiguration(Text, String) - Constructor for class org.apache.accumulo.core.iterators.aggregation.conf.AggregatorConfiguration
-
Deprecated.
- AggregatorConfiguration(Text, Text, String) - Constructor for class org.apache.accumulo.core.iterators.aggregation.conf.AggregatorConfiguration
-
Deprecated.
- AggregatorSet - Class in org.apache.accumulo.core.iterators.aggregation.conf
-
- AggregatorSet(Map<String, String>) - Constructor for class org.apache.accumulo.core.iterators.aggregation.conf.AggregatorSet
-
Deprecated.
- AggregatorSet() - Constructor for class org.apache.accumulo.core.iterators.aggregation.conf.AggregatorSet
-
Deprecated.
- align(int) - Static method in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
-
Aligns a number to 8.
- align(long) - Static method in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
-
Aligns a number to 8.
- ALL_OPTION - Static variable in class org.apache.accumulo.core.iterators.Combiner
-
- 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
-
Peforms a logical AND between this filter and a specified filter.
- and(ArgumentChecker.Validator<T>) - Method in class org.apache.accumulo.core.util.ArgumentChecker.Validator
-
- 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(LoggingEvent) - Method in class org.apache.accumulo.core.util.AsyncSocketAppender
-
- appendPrintableString(byte[], int, int, int, StringBuilder) - Static method in class org.apache.accumulo.core.data.Key
-
- appendText(StringBuilder, Text) - Static method in class org.apache.accumulo.core.util.format.BinaryFormatter
-
- applyUpdates(TInfo, long, TKeyExtent, List<TMutation>, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
-
- applyUpdates(TInfo, long, TKeyExtent, List<TMutation>, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
-
- applyUpdates(TInfo, long, TKeyExtent, List<TMutation>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
-
- applyUpdates(TInfo, long, TKeyExtent, List<TMutation>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
-
- args - Variable in class org.apache.accumulo.core.util.shell.commands.ScriptCommand
-
- ArgumentChecker - Class in org.apache.accumulo.core.util
-
This class provides methods to check arguments of a variable number for null values, or anything else that might be required on a routine basis.
- ArgumentChecker() - Constructor for class org.apache.accumulo.core.util.ArgumentChecker
-
- ArgumentChecker.Validator<T> - Class in org.apache.accumulo.core.util
-
- ArgumentChecker.Validator() - Constructor for class org.apache.accumulo.core.util.ArgumentChecker.Validator
-
- arguments - Variable in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
-
- ARRAY - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
-
Array overhead
- arrayAdd(List<Long>, List<Long>) - Static method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner
-
- ArrayByteSequence - Class in org.apache.accumulo.core.data
-
- ArrayByteSequence(byte[]) - Constructor for class org.apache.accumulo.core.data.ArrayByteSequence
-
- ArrayByteSequence(byte[], int, int) - Constructor for class org.apache.accumulo.core.data.ArrayByteSequence
-
- ArrayByteSequence(String) - Constructor for class org.apache.accumulo.core.data.ArrayByteSequence
-
- ArrayByteSequence(ByteBuffer) - Constructor for class org.apache.accumulo.core.data.ArrayByteSequence
-
- ARRAYLIST - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
-
Overhead for ArrayList(0)
- asList() - Method in class org.apache.accumulo.core.constraints.Violations
-
- asThriftException() - Method in exception org.apache.accumulo.core.client.AccumuloSecurityException
-
- AsyncSocketAppender - Class in org.apache.accumulo.core.util
-
An asynchronous appender that maintains its own internal socket appender.
- AsyncSocketAppender() - Constructor for class org.apache.accumulo.core.util.AsyncSocketAppender
-
Creates a new appender.
- ATOMIC_BOOLEAN - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
-
Overhead for AtomicBoolean
- ATOMIC_INTEGER - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
-
Overhead for AtomicInteger
- ATOMIC_LONG - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
-
Overhead for AtomicLong
- attachIterator(String, IteratorSetting) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
-
Add an iterator to a namespace on all scopes.
- attachIterator(String, IteratorSetting, 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) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
Add an iterator to a table on all 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) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsHelper
-
- attachIterator(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsHelper
-
- attachIterator(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsImpl
-
- attachIterator(String, IteratorSetting) - Method in class org.apache.accumulo.core.client.impl.TableOperationsHelper
-
- attachIterator(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in class org.apache.accumulo.core.client.impl.TableOperationsHelper
-
- attachIterator(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
-
- AUTH_OPT - Static variable in class org.apache.accumulo.core.iterators.user.TransformingIterator
-
- authenticate(TInfo, TCredentials, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
-
- authenticate(TInfo, TCredentials, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
-
- authenticate(TInfo, TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
-
- authenticate(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
-
- AuthenticateCommand - Class in org.apache.accumulo.core.util.shell.commands
-
- AuthenticateCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.AuthenticateCommand
-
- authenticateUser(String, byte[]) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
-
- authenticateUser(String, AuthenticationToken) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
-
Verify a username/password combination is valid
- authenticateUser(String, byte[]) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
-
Deprecated.
- authenticateUser(String, AuthenticationToken) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
-
- authenticateUser(TInfo, TCredentials, TCredentials, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
-
- authenticateUser(TInfo, TCredentials, TCredentials, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
-
- authenticateUser(TInfo, TCredentials, TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
-
- authenticateUser(TInfo, TCredentials, TCredentials) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
-
- 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.AuthenticationTokenSerializer() - Constructor for class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.AuthenticationTokenSerializer
-
- AuthenticationToken.Properties - Class in org.apache.accumulo.core.client.security.tokens
-
- AuthenticationToken.Properties() - Constructor for class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
-
- AuthenticationToken.TokenProperty - Class in org.apache.accumulo.core.client.security.tokens
-
- AuthenticationToken.TokenProperty(String, String, boolean) - Constructor for class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.TokenProperty
-
- AuthorizationContainer - Interface in org.apache.accumulo.core.security
-
An interface for classes that contain a collection of authorizations.
- authorizationFailures - Variable in class org.apache.accumulo.core.data.thrift.UpdateErrors
-
- authorizations - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
-
- authorizations - Variable in class org.apache.accumulo.core.iterators.system.VisibilityFilter
-
- Authorizations - Class in org.apache.accumulo.core.security
-
A collection of authorization strings.
- 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(byte[]) - Constructor for class org.apache.accumulo.core.security.Authorizations
-
Constructs an authorizations object from a serialized form.
- Authorizations() - Constructor for class org.apache.accumulo.core.security.Authorizations
-
Constructs an empty set of authorizations.
- Authorizations(String...) - Constructor for class org.apache.accumulo.core.security.Authorizations
-
Constructs an authorizations object from a set of human-readable authorizations.
- authorizations - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
-
- authorizations - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
-
- authorizations - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
-
- authorizations - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
-
- auths - Variable in class org.apache.accumulo.core.cli.ClientOpts
-
- auths - Variable in class org.apache.accumulo.core.client.mock.MockScannerBase
-
- autoClean - Variable in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
-
- available() - Method in class org.apache.accumulo.core.file.blockfile.impl.SeekableByteArrayInputStream
-
- available() - Method in class org.apache.accumulo.core.security.crypto.BlockedInputStream
-
- CachableBlockFile - Class in org.apache.accumulo.core.file.blockfile.impl
-
This is a wrapper class for BCFile that includes a cache for independent caches for datablocks and metadatablocks
- CachableBlockFile.BlockRead - Class in org.apache.accumulo.core.file.blockfile.impl
-
Class provides functionality to read one block from the underlying BCFile Since We are caching blocks in the Reader class as bytearrays, this class will
wrap a DataInputStream(ByteArrayStream(cachedBlock)).
- CachableBlockFile.BlockRead(InputStream, long) - Constructor for class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.BlockRead
-
- CachableBlockFile.BlockWrite - Class in org.apache.accumulo.core.file.blockfile.impl
-
- CachableBlockFile.BlockWrite(BCFile.Writer.BlockAppender) - Constructor for class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.BlockWrite
-
- CachableBlockFile.CachedBlockRead - Class in org.apache.accumulo.core.file.blockfile.impl
-
- CachableBlockFile.CachedBlockRead(CacheEntry, byte[]) - Constructor for class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.CachedBlockRead
-
- CachableBlockFile.Reader - Class in org.apache.accumulo.core.file.blockfile.impl
-
Class wraps the BCFile reader.
- CachableBlockFile.Reader(FileSystem, Path, Configuration, BlockCache, BlockCache, AccumuloConfiguration) - Constructor for class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
-
- CachableBlockFile.Reader(FSDataInputStream, long, Configuration, BlockCache, BlockCache, AccumuloConfiguration) - Constructor for class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
-
- CachableBlockFile.Reader(FSDataInputStream, long, Configuration, AccumuloConfiguration) - Constructor for class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
-
- CachableBlockFile.Writer - Class in org.apache.accumulo.core.file.blockfile.impl
-
- CachableBlockFile.Writer(FileSystem, Path, String, Configuration, AccumuloConfiguration) - Constructor for class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Writer
-
- CachableBlockFile.Writer(FSDataOutputStream, String, Configuration, AccumuloConfiguration) - Constructor for class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Writer
-
- cache - Variable in class org.apache.accumulo.core.iterators.system.VisibilityFilter
-
- CACHE_FIXED_OVERHEAD - Static variable in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
-
- cacheBlock(String, byte[], boolean) - Method in interface org.apache.accumulo.core.file.blockfile.cache.BlockCache
-
Add block to cache.
- cacheBlock(String, byte[]) - Method in interface org.apache.accumulo.core.file.blockfile.cache.BlockCache
-
Add block to cache (defaults to not in-memory).
- cacheBlock(String, byte[], boolean) - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
-
Cache the block with the specified name and buffer.
- cacheBlock(String, byte[]) - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
-
Cache the block with the specified name and buffer.
- cacheBlock(String, byte[]) - Method in class org.apache.accumulo.core.file.blockfile.cache.SimpleBlockCache
-
- cacheBlock(String, byte[], boolean) - Method in class org.apache.accumulo.core.file.blockfile.cache.SimpleBlockCache
-
- CachedBlock - Class in org.apache.accumulo.core.file.blockfile.cache
-
- CachedBlock(String, byte[], long) - Constructor for class org.apache.accumulo.core.file.blockfile.cache.CachedBlock
-
- CachedBlock(String, byte[], long, boolean) - Constructor for class org.apache.accumulo.core.file.blockfile.cache.CachedBlock
-
- CachedBlockQueue - Class in org.apache.accumulo.core.file.blockfile.cache
-
A memory-bound queue that will grow until an element brings total size >= maxSize.
- CachedBlockQueue(long, long) - Constructor for class org.apache.accumulo.core.file.blockfile.cache.CachedBlockQueue
-
- cachedClientConfig - Variable in class org.apache.accumulo.core.cli.ClientOpts
-
- CachedConfiguration - Class in org.apache.accumulo.core.util
-
- CachedConfiguration() - Constructor for class org.apache.accumulo.core.util.CachedConfiguration
-
- cachedInstance - Variable in class org.apache.accumulo.core.cli.ClientOpts
-
- CacheEntry - Interface in org.apache.accumulo.core.file.blockfile.cache
-
- cacheMetaBlock(String, BCFile.Reader.BlockReader) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
-
- cacheMetaBlock(String, byte[]) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
-
- CachingHDFSSecretKeyEncryptionStrategy - Class in org.apache.accumulo.core.security.crypto
-
- CachingHDFSSecretKeyEncryptionStrategy() - Constructor for class org.apache.accumulo.core.security.crypto.CachingHDFSSecretKeyEncryptionStrategy
-
- calculateOverhead(long, long, int) - Static method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
-
- cancelCompaction(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
- cancelCompaction(String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
-
- canCreateTables(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
-
Determines whether tables are permitted to be created as needed.
- canCreateTables(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
-
Determines whether tables are permitted to be created as needed.
- canCreateTables(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.OutputConfigurator
-
Determines whether tables are permitted to be created as needed.
- canCreateTables(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.OutputConfigurator
-
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
- candidates - Variable in class org.apache.accumulo.core.gc.thrift.GcCycleStats
-
- canSee(Key) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
-
Indicates whether or not the user is able to see key
.
- canSeeColumnFamily(Key) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
-
Indicates whether or not key
can be seen, according to the fetched column families for this iterator.
- cf - Variable in class org.apache.accumulo.core.data.thrift.TCondition
-
- changeAuthorizations(TInfo, TCredentials, String, List<ByteBuffer>, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
-
- changeAuthorizations(TInfo, TCredentials, String, List<ByteBuffer>, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
-
- changeAuthorizations(TInfo, TCredentials, String, List<ByteBuffer>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
-
- changeAuthorizations(TInfo, TCredentials, String, List<ByteBuffer>) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
-
- changeLocalUserPassword(String, PasswordToken) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
-
Set the user's password
- changeLocalUserPassword(String, PasswordToken) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
-
- changeLocalUserPassword(TInfo, TCredentials, String, ByteBuffer, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
-
- changeLocalUserPassword(TInfo, TCredentials, String, ByteBuffer, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
-
- changeLocalUserPassword(TInfo, TCredentials, String, ByteBuffer) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
-
- changeLocalUserPassword(TInfo, TCredentials, String, ByteBuffer) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
-
- changeUserAuthorizations(String, Authorizations) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
-
Set the user's record-level authorizations
- changeUserAuthorizations(String, Authorizations) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
-
- changeUserPassword(String, byte[]) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
-
- changeUserPassword(String, byte[]) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
-
Deprecated.
- charAt(int) - Method in class org.apache.accumulo.core.util.ByteArrayBackedCharSequence
-
- CHARSET - Static variable in class org.apache.accumulo.core.util.shell.Shell
-
- check(Constraint.Environment, Mutation) - Method in interface org.apache.accumulo.core.constraints.Constraint
-
Checks a mutation for constrain violations.
- check(Constraint.Environment, Mutation) - Method in class org.apache.accumulo.core.constraints.DefaultKeySizeConstraint
-
- check(Constraint.Environment, Mutation) - Method in class org.apache.accumulo.core.security.VisibilityConstraint
-
- checkClass(TInfo, TCredentials, String, String, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
-
- checkClass(TInfo, TCredentials, String, String, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
-
- checkClass(TInfo, TCredentials, String, String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
-
- checkClass(TInfo, TCredentials, String, String) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
-
- checkIteratorConflicts(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
-
Check whether a given iterator configuration conflicts with existing configuration; in particular, determine if the name or priority are already in use for
the specified scopes.
- checkIteratorConflicts(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
Check whether a given iterator configuration conflicts with existing configuration; in particular, determine if the name or priority are already in use for
the specified scopes.
- checkIteratorConflicts(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsHelper
-
- checkIteratorConflicts(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in class org.apache.accumulo.core.client.impl.TableOperationsHelper
-
- checkNamespaceClass(TInfo, TCredentials, String, String, String, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
-
- checkNamespaceClass(TInfo, TCredentials, String, String, String, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
-
- checkNamespaceClass(TInfo, TCredentials, String, String, String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
-
- checkNamespaceClass(TInfo, TCredentials, String, String, String) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
-
- checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
-
- checkOutputSpecs(JobContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
-
- checkState(boolean) - Method in class org.apache.accumulo.core.util.format.DefaultFormatter
-
- checkTableClass(TInfo, TCredentials, String, String, String, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
-
- checkTableClass(TInfo, TCredentials, String, String, String, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
-
- checkTableClass(TInfo, TCredentials, String, String, String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
-
- checkTableClass(TInfo, TCredentials, String, String, String) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
-
- checkTableState() - Method in class org.apache.accumulo.core.util.shell.Shell
-
- chop(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
-
- chop(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
-
- chop(TInfo, TCredentials, String, TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
-
- chop(TInfo, TCredentials, String, TKeyExtent) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
-
- CHOPPED_COLUMN - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ChoppedColumnFamily
-
- CLASS - Static variable in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
-
- CLASS - Static variable in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
-
- CLASS_PREFIX - Static variable in class org.apache.accumulo.core.iterators.LongCombiner
-
- className - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
-
- className - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
-
- className - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
-
- className - Variable in class org.apache.accumulo.core.data.thrift.IterInfo
-
- ClasspathCommand - Class in org.apache.accumulo.core.util.shell.commands
-
- ClasspathCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.ClasspathCommand
-
- ClassSize - Class in org.apache.accumulo.core.file.blockfile.cache
-
Class for determining the "size" of a class, an attempt to calculate the actual bytes that an object of this class will occupy in memory
The core of this class is taken from the Derby project
- ClassSize() - Constructor for class org.apache.accumulo.core.file.blockfile.cache.ClassSize
-
- CleanUp - Class in org.apache.accumulo.core.util
-
- CleanUp() - Constructor for class org.apache.accumulo.core.util.CleanUp
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
-
- clear() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
-
- clear() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args
-
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
-
- clear() - Method in class org.apache.accumulo.core.client.IsolatedScanner.MemoryRowBuffer
-
- clear() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
-
- clear() - Method in class org.apache.accumulo.core.conf.SiteConfiguration
-
method here to support testing, do not call
- clear() - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
-
- clear() - Method in class org.apache.accumulo.core.data.thrift.InitialScan
-
- clear() - Method in class org.apache.accumulo.core.data.thrift.IterInfo
-
- clear() - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
-
- clear() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
-
- clear() - Method in class org.apache.accumulo.core.data.thrift.ScanResult
-
- clear() - Method in class org.apache.accumulo.core.data.thrift.TCMResult
-
- clear() - Method in class org.apache.accumulo.core.data.thrift.TColumn
-
- clear() - Method in class org.apache.accumulo.core.data.thrift.TCondition
-
- clear() - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
-
- clear() - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
-
- clear() - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
-
- clear() - Method in class org.apache.accumulo.core.data.thrift.TKey
-
- clear() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
-
- clear() - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
-
- clear() - Method in class org.apache.accumulo.core.data.thrift.TMutation
-
- clear() - Method in class org.apache.accumulo.core.data.thrift.TRange
-
- clear() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
-
- clear() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
-
- clear() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
-
- clear() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
-
- clear() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
-
- clear() - Method in class org.apache.accumulo.core.iterators.system.HeapIterator
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.Compacting
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.DeadServer
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
-
- clear() - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
-
- clear() - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
-
- clear() - Method in class org.apache.accumulo.core.security.thrift.TCredentials
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
-
- clear() - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
-
- clear() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
-
- clear() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
-
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
-
- clear() - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
-
- clear() - Method in class org.apache.accumulo.core.util.Stat
-
- clearAndNull() - Method in class org.apache.accumulo.core.conf.SiteConfiguration
-
method here to support testing, do not call
- clearCache(Instance) - Static method in class org.apache.accumulo.core.client.impl.Tables
-
- clearColumns() - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
-
- clearColumns() - Method in interface org.apache.accumulo.core.client.ScannerBase
-
Clears the columns to be fetched (useful for resetting the scanner for reuse).
- ClearCommand - Class in org.apache.accumulo.core.util.shell.commands
-
- ClearCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.ClearCommand
-
- clearInstance() - Static method in class org.apache.accumulo.core.conf.SiteConfiguration
-
method here to support testing, do not call
- clearLocatorCache(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
Clears the tablet locator cache for a specified table
- clearLocatorCache(String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
-
Clears the tablet locator cache for a specified table
- clearLocators() - Static method in class org.apache.accumulo.core.client.impl.TabletLocator
-
- clearOptions() - Method in class org.apache.accumulo.core.client.IteratorSetting
-
Remove all options from the iterator.
- clearScanIterators() - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
-
Clears scan iterators prior to returning a scanner to the pool.
- clearScanIterators() - Method in interface org.apache.accumulo.core.client.ScannerBase
-
Clears scan iterators prior to returning a scanner to the pool.
- client - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
-
- clientConfigFile - Variable in class org.apache.accumulo.core.cli.ClientOpts
-
- ClientConfiguration - Class in org.apache.accumulo.core.client
-
Contains a list of property keys recognized by the Accumulo client and convenience methods for setting them.
- ClientConfiguration(List<? extends Configuration>) - Constructor for class org.apache.accumulo.core.client.ClientConfiguration
-
- ClientConfiguration(Configuration...) - Constructor for class org.apache.accumulo.core.client.ClientConfiguration
-
Iterates through the Configuration objects, populating this object.
- ClientConfiguration.ClientProperty - Enum in org.apache.accumulo.core.client
-
- ClientExec<T> - Interface in org.apache.accumulo.core.client.impl
-
- ClientExecReturn<T,C> - Interface in org.apache.accumulo.core.client.impl
-
- ClientOnDefaultTable - Class in org.apache.accumulo.core.cli
-
- ClientOnDefaultTable(String) - Constructor for class org.apache.accumulo.core.cli.ClientOnDefaultTable
-
- ClientOnRequiredTable - Class in org.apache.accumulo.core.cli
-
- ClientOnRequiredTable() - Constructor for class org.apache.accumulo.core.cli.ClientOnRequiredTable
-
- ClientOpts - Class in org.apache.accumulo.core.cli
-
- ClientOpts() - Constructor for class org.apache.accumulo.core.cli.ClientOpts
-
- ClientOpts.AuthConverter - Class in org.apache.accumulo.core.cli
-
- ClientOpts.AuthConverter() - Constructor for class org.apache.accumulo.core.cli.ClientOpts.AuthConverter
-
- ClientOpts.MemoryConverter - Class in org.apache.accumulo.core.cli
-
- ClientOpts.MemoryConverter() - Constructor for class org.apache.accumulo.core.cli.ClientOpts.MemoryConverter
-
- ClientOpts.Password - Class in org.apache.accumulo.core.cli
-
- ClientOpts.Password(String) - Constructor for class org.apache.accumulo.core.cli.ClientOpts.Password
-
- ClientOpts.PasswordConverter - Class in org.apache.accumulo.core.cli
-
- ClientOpts.PasswordConverter() - Constructor for class org.apache.accumulo.core.cli.ClientOpts.PasswordConverter
-
- ClientOpts.TimeConverter - Class in org.apache.accumulo.core.cli
-
- ClientOpts.TimeConverter() - Constructor for class org.apache.accumulo.core.cli.ClientOpts.TimeConverter
-
- ClientOpts.VisibilityConverter - Class in org.apache.accumulo.core.cli
-
- ClientOpts.VisibilityConverter() - Constructor for class org.apache.accumulo.core.cli.ClientOpts.VisibilityConverter
-
- ClientService - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService
-
- ClientService.AsyncClient - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
-
- ClientService.AsyncClient.authenticate_call - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncClient.authenticate_call(TInfo, TCredentials, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.authenticate_call
-
- ClientService.AsyncClient.authenticateUser_call - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncClient.authenticateUser_call(TInfo, TCredentials, TCredentials, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.authenticateUser_call
-
- ClientService.AsyncClient.bulkImportFiles_call - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncClient.bulkImportFiles_call(TInfo, TCredentials, long, String, List<String>, String, boolean, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.bulkImportFiles_call
-
- ClientService.AsyncClient.changeAuthorizations_call - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncClient.changeAuthorizations_call(TInfo, TCredentials, String, List<ByteBuffer>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.changeAuthorizations_call
-
- ClientService.AsyncClient.changeLocalUserPassword_call - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncClient.changeLocalUserPassword_call(TInfo, TCredentials, String, ByteBuffer, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.changeLocalUserPassword_call
-
- ClientService.AsyncClient.checkClass_call - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncClient.checkClass_call(TInfo, TCredentials, String, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.checkClass_call
-
- ClientService.AsyncClient.checkNamespaceClass_call - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncClient.checkNamespaceClass_call(TInfo, TCredentials, String, String, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.checkNamespaceClass_call
-
- ClientService.AsyncClient.checkTableClass_call - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncClient.checkTableClass_call(TInfo, TCredentials, String, String, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.checkTableClass_call
-
- ClientService.AsyncClient.createLocalUser_call - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncClient.createLocalUser_call(TInfo, TCredentials, String, ByteBuffer, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.createLocalUser_call
-
- ClientService.AsyncClient.dropLocalUser_call - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncClient.dropLocalUser_call(TInfo, TCredentials, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.dropLocalUser_call
-
- ClientService.AsyncClient.Factory - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncClient.Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.Factory
-
- ClientService.AsyncClient.getConfiguration_call - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncClient.getConfiguration_call(TInfo, TCredentials, ConfigurationType, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getConfiguration_call
-
- ClientService.AsyncClient.getDiskUsage_call - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncClient.getDiskUsage_call(Set<String>, TCredentials, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getDiskUsage_call
-
- ClientService.AsyncClient.getInstanceId_call - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncClient.getInstanceId_call(AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getInstanceId_call
-
- ClientService.AsyncClient.getNamespaceConfiguration_call - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncClient.getNamespaceConfiguration_call(TInfo, TCredentials, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getNamespaceConfiguration_call
-
- ClientService.AsyncClient.getRootTabletLocation_call - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncClient.getRootTabletLocation_call(AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getRootTabletLocation_call
-
- ClientService.AsyncClient.getTableConfiguration_call - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncClient.getTableConfiguration_call(TInfo, TCredentials, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getTableConfiguration_call
-
- ClientService.AsyncClient.getUserAuthorizations_call - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncClient.getUserAuthorizations_call(TInfo, TCredentials, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getUserAuthorizations_call
-
- ClientService.AsyncClient.getZooKeepers_call - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncClient.getZooKeepers_call(AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getZooKeepers_call
-
- ClientService.AsyncClient.grantNamespacePermission_call - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncClient.grantNamespacePermission_call(TInfo, TCredentials, String, String, byte, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.grantNamespacePermission_call
-
- ClientService.AsyncClient.grantSystemPermission_call - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncClient.grantSystemPermission_call(TInfo, TCredentials, String, byte, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.grantSystemPermission_call
-
- ClientService.AsyncClient.grantTablePermission_call - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncClient.grantTablePermission_call(TInfo, TCredentials, String, String, byte, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.grantTablePermission_call
-
- ClientService.AsyncClient.hasNamespacePermission_call - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncClient.hasNamespacePermission_call(TInfo, TCredentials, String, String, byte, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.hasNamespacePermission_call
-
- ClientService.AsyncClient.hasSystemPermission_call - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncClient.hasSystemPermission_call(TInfo, TCredentials, String, byte, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.hasSystemPermission_call
-
- ClientService.AsyncClient.hasTablePermission_call - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncClient.hasTablePermission_call(TInfo, TCredentials, String, String, byte, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.hasTablePermission_call
-
- ClientService.AsyncClient.isActive_call - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncClient.isActive_call(TInfo, long, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.isActive_call
-
- ClientService.AsyncClient.listLocalUsers_call - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncClient.listLocalUsers_call(TInfo, TCredentials, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.listLocalUsers_call
-
- ClientService.AsyncClient.ping_call - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncClient.ping_call(TCredentials, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.ping_call
-
- ClientService.AsyncClient.revokeNamespacePermission_call - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncClient.revokeNamespacePermission_call(TInfo, TCredentials, String, String, byte, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.revokeNamespacePermission_call
-
- ClientService.AsyncClient.revokeSystemPermission_call - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncClient.revokeSystemPermission_call(TInfo, TCredentials, String, byte, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.revokeSystemPermission_call
-
- ClientService.AsyncClient.revokeTablePermission_call - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncClient.revokeTablePermission_call(TInfo, TCredentials, String, String, byte, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.revokeTablePermission_call
-
- ClientService.AsyncIface - Interface in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncProcessor<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncProcessor(I) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor
-
- ClientService.AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor
-
- ClientService.AsyncProcessor.authenticate<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncProcessor.authenticate() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.authenticate
-
- ClientService.AsyncProcessor.authenticateUser<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncProcessor.authenticateUser() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.authenticateUser
-
- ClientService.AsyncProcessor.bulkImportFiles<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncProcessor.bulkImportFiles() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.bulkImportFiles
-
- ClientService.AsyncProcessor.changeAuthorizations<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncProcessor.changeAuthorizations() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.changeAuthorizations
-
- ClientService.AsyncProcessor.changeLocalUserPassword<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncProcessor.changeLocalUserPassword() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.changeLocalUserPassword
-
- ClientService.AsyncProcessor.checkClass<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncProcessor.checkClass() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.checkClass
-
- ClientService.AsyncProcessor.checkNamespaceClass<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncProcessor.checkNamespaceClass() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.checkNamespaceClass
-
- ClientService.AsyncProcessor.checkTableClass<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncProcessor.checkTableClass() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.checkTableClass
-
- ClientService.AsyncProcessor.createLocalUser<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncProcessor.createLocalUser() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.createLocalUser
-
- ClientService.AsyncProcessor.dropLocalUser<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncProcessor.dropLocalUser() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.dropLocalUser
-
- ClientService.AsyncProcessor.getConfiguration<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncProcessor.getConfiguration() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getConfiguration
-
- ClientService.AsyncProcessor.getDiskUsage<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncProcessor.getDiskUsage() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getDiskUsage
-
- ClientService.AsyncProcessor.getInstanceId<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncProcessor.getInstanceId() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getInstanceId
-
- ClientService.AsyncProcessor.getNamespaceConfiguration<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncProcessor.getNamespaceConfiguration() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getNamespaceConfiguration
-
- ClientService.AsyncProcessor.getRootTabletLocation<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncProcessor.getRootTabletLocation() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getRootTabletLocation
-
- ClientService.AsyncProcessor.getTableConfiguration<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncProcessor.getTableConfiguration() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getTableConfiguration
-
- ClientService.AsyncProcessor.getUserAuthorizations<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncProcessor.getUserAuthorizations() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getUserAuthorizations
-
- ClientService.AsyncProcessor.getZooKeepers<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncProcessor.getZooKeepers() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getZooKeepers
-
- ClientService.AsyncProcessor.grantNamespacePermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncProcessor.grantNamespacePermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.grantNamespacePermission
-
- ClientService.AsyncProcessor.grantSystemPermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncProcessor.grantSystemPermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.grantSystemPermission
-
- ClientService.AsyncProcessor.grantTablePermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncProcessor.grantTablePermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.grantTablePermission
-
- ClientService.AsyncProcessor.hasNamespacePermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncProcessor.hasNamespacePermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.hasNamespacePermission
-
- ClientService.AsyncProcessor.hasSystemPermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncProcessor.hasSystemPermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.hasSystemPermission
-
- ClientService.AsyncProcessor.hasTablePermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncProcessor.hasTablePermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.hasTablePermission
-
- ClientService.AsyncProcessor.isActive<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncProcessor.isActive() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.isActive
-
- ClientService.AsyncProcessor.listLocalUsers<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncProcessor.listLocalUsers() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.listLocalUsers
-
- ClientService.AsyncProcessor.ping<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncProcessor.ping() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.ping
-
- ClientService.AsyncProcessor.revokeNamespacePermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncProcessor.revokeNamespacePermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.revokeNamespacePermission
-
- ClientService.AsyncProcessor.revokeSystemPermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncProcessor.revokeSystemPermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.revokeSystemPermission
-
- ClientService.AsyncProcessor.revokeTablePermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.AsyncProcessor.revokeTablePermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.revokeTablePermission
-
- ClientService.authenticate_args - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.authenticate_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
-
- ClientService.authenticate_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
-
- ClientService.authenticate_args(ClientService.authenticate_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
-
Performs a deep copy on other.
- ClientService.authenticate_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.authenticate_result - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.authenticate_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
-
- ClientService.authenticate_result(boolean, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
-
- ClientService.authenticate_result(ClientService.authenticate_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
-
Performs a deep copy on other.
- ClientService.authenticate_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.authenticateUser_args - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.authenticateUser_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
-
- ClientService.authenticateUser_args(TInfo, TCredentials, TCredentials) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
-
- ClientService.authenticateUser_args(ClientService.authenticateUser_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
-
Performs a deep copy on other.
- ClientService.authenticateUser_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.authenticateUser_result - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.authenticateUser_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
-
- ClientService.authenticateUser_result(boolean, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
-
- ClientService.authenticateUser_result(ClientService.authenticateUser_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
-
Performs a deep copy on other.
- ClientService.authenticateUser_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.bulkImportFiles_args - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.bulkImportFiles_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
-
- ClientService.bulkImportFiles_args(TInfo, TCredentials, long, String, List<String>, String, boolean) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
-
- ClientService.bulkImportFiles_args(ClientService.bulkImportFiles_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
-
Performs a deep copy on other.
- ClientService.bulkImportFiles_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.bulkImportFiles_result - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.bulkImportFiles_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
-
- ClientService.bulkImportFiles_result(List<String>, ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
-
- ClientService.bulkImportFiles_result(ClientService.bulkImportFiles_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
-
Performs a deep copy on other.
- ClientService.bulkImportFiles_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.changeAuthorizations_args - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.changeAuthorizations_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
-
- ClientService.changeAuthorizations_args(TInfo, TCredentials, String, List<ByteBuffer>) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
-
- ClientService.changeAuthorizations_args(ClientService.changeAuthorizations_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
-
Performs a deep copy on other.
- ClientService.changeAuthorizations_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.changeAuthorizations_result - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.changeAuthorizations_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
-
- ClientService.changeAuthorizations_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
-
- ClientService.changeAuthorizations_result(ClientService.changeAuthorizations_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
-
Performs a deep copy on other.
- ClientService.changeAuthorizations_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.changeLocalUserPassword_args - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.changeLocalUserPassword_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
-
- ClientService.changeLocalUserPassword_args(TInfo, TCredentials, String, ByteBuffer) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
-
- ClientService.changeLocalUserPassword_args(ClientService.changeLocalUserPassword_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
-
Performs a deep copy on other.
- ClientService.changeLocalUserPassword_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.changeLocalUserPassword_result - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.changeLocalUserPassword_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
-
- ClientService.changeLocalUserPassword_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
-
- ClientService.changeLocalUserPassword_result(ClientService.changeLocalUserPassword_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
-
Performs a deep copy on other.
- ClientService.changeLocalUserPassword_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.checkClass_args - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.checkClass_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
-
- ClientService.checkClass_args(TInfo, TCredentials, String, String) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
-
- ClientService.checkClass_args(ClientService.checkClass_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
-
Performs a deep copy on other.
- ClientService.checkClass_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.checkClass_result - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.checkClass_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
-
- ClientService.checkClass_result(boolean) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
-
- ClientService.checkClass_result(ClientService.checkClass_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
-
Performs a deep copy on other.
- ClientService.checkClass_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.checkNamespaceClass_args - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.checkNamespaceClass_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
-
- ClientService.checkNamespaceClass_args(TInfo, TCredentials, String, String, String) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
-
- ClientService.checkNamespaceClass_args(ClientService.checkNamespaceClass_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
-
Performs a deep copy on other.
- ClientService.checkNamespaceClass_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.checkNamespaceClass_result - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.checkNamespaceClass_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
-
- ClientService.checkNamespaceClass_result(boolean, ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
-
- ClientService.checkNamespaceClass_result(ClientService.checkNamespaceClass_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
-
Performs a deep copy on other.
- ClientService.checkNamespaceClass_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.checkTableClass_args - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.checkTableClass_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
-
- ClientService.checkTableClass_args(TInfo, TCredentials, String, String, String) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
-
- ClientService.checkTableClass_args(ClientService.checkTableClass_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
-
Performs a deep copy on other.
- ClientService.checkTableClass_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.checkTableClass_result - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.checkTableClass_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
-
- ClientService.checkTableClass_result(boolean, ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
-
- ClientService.checkTableClass_result(ClientService.checkTableClass_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
-
Performs a deep copy on other.
- ClientService.checkTableClass_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.Client - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Client(TProtocol) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
-
- ClientService.Client(TProtocol, TProtocol) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
-
- ClientService.Client.Factory - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Client.Factory() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Client.Factory
-
- ClientService.createLocalUser_args - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.createLocalUser_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
-
- ClientService.createLocalUser_args(TInfo, TCredentials, String, ByteBuffer) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
-
- ClientService.createLocalUser_args(ClientService.createLocalUser_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
-
Performs a deep copy on other.
- ClientService.createLocalUser_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.createLocalUser_result - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.createLocalUser_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
-
- ClientService.createLocalUser_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
-
- ClientService.createLocalUser_result(ClientService.createLocalUser_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
-
Performs a deep copy on other.
- ClientService.createLocalUser_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.dropLocalUser_args - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.dropLocalUser_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
-
- ClientService.dropLocalUser_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
-
- ClientService.dropLocalUser_args(ClientService.dropLocalUser_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
-
Performs a deep copy on other.
- ClientService.dropLocalUser_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.dropLocalUser_result - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.dropLocalUser_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
-
- ClientService.dropLocalUser_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
-
- ClientService.dropLocalUser_result(ClientService.dropLocalUser_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
-
Performs a deep copy on other.
- ClientService.dropLocalUser_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.getConfiguration_args - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.getConfiguration_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
-
- ClientService.getConfiguration_args(TInfo, TCredentials, ConfigurationType) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
-
- ClientService.getConfiguration_args(ClientService.getConfiguration_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
-
Performs a deep copy on other.
- ClientService.getConfiguration_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.getConfiguration_result - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.getConfiguration_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
-
- ClientService.getConfiguration_result(Map<String, String>) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
-
- ClientService.getConfiguration_result(ClientService.getConfiguration_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
-
Performs a deep copy on other.
- ClientService.getConfiguration_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.getDiskUsage_args - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.getDiskUsage_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
-
- ClientService.getDiskUsage_args(Set<String>, TCredentials) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
-
- ClientService.getDiskUsage_args(ClientService.getDiskUsage_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
-
Performs a deep copy on other.
- ClientService.getDiskUsage_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.getDiskUsage_result - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.getDiskUsage_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
-
- ClientService.getDiskUsage_result(List<TDiskUsage>, ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
-
- ClientService.getDiskUsage_result(ClientService.getDiskUsage_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
-
Performs a deep copy on other.
- ClientService.getDiskUsage_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.getInstanceId_args - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.getInstanceId_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
-
- ClientService.getInstanceId_args(ClientService.getInstanceId_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
-
Performs a deep copy on other.
- ClientService.getInstanceId_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.getInstanceId_result - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.getInstanceId_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
-
- ClientService.getInstanceId_result(String) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
-
- ClientService.getInstanceId_result(ClientService.getInstanceId_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
-
Performs a deep copy on other.
- ClientService.getInstanceId_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.getNamespaceConfiguration_args - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.getNamespaceConfiguration_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
-
- ClientService.getNamespaceConfiguration_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
-
- ClientService.getNamespaceConfiguration_args(ClientService.getNamespaceConfiguration_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
-
Performs a deep copy on other.
- ClientService.getNamespaceConfiguration_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.getNamespaceConfiguration_result - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.getNamespaceConfiguration_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
-
- ClientService.getNamespaceConfiguration_result(Map<String, String>, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
-
- ClientService.getNamespaceConfiguration_result(ClientService.getNamespaceConfiguration_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
-
Performs a deep copy on other.
- ClientService.getNamespaceConfiguration_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.getRootTabletLocation_args - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.getRootTabletLocation_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
-
- ClientService.getRootTabletLocation_args(ClientService.getRootTabletLocation_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
-
Performs a deep copy on other.
- ClientService.getRootTabletLocation_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.getRootTabletLocation_result - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.getRootTabletLocation_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
-
- ClientService.getRootTabletLocation_result(String) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
-
- ClientService.getRootTabletLocation_result(ClientService.getRootTabletLocation_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
-
Performs a deep copy on other.
- ClientService.getRootTabletLocation_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.getTableConfiguration_args - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.getTableConfiguration_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
-
- ClientService.getTableConfiguration_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
-
- ClientService.getTableConfiguration_args(ClientService.getTableConfiguration_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
-
Performs a deep copy on other.
- ClientService.getTableConfiguration_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.getTableConfiguration_result - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.getTableConfiguration_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
-
- ClientService.getTableConfiguration_result(Map<String, String>, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
-
- ClientService.getTableConfiguration_result(ClientService.getTableConfiguration_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
-
Performs a deep copy on other.
- ClientService.getTableConfiguration_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.getUserAuthorizations_args - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.getUserAuthorizations_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
-
- ClientService.getUserAuthorizations_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
-
- ClientService.getUserAuthorizations_args(ClientService.getUserAuthorizations_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
-
Performs a deep copy on other.
- ClientService.getUserAuthorizations_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.getUserAuthorizations_result - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.getUserAuthorizations_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
-
- ClientService.getUserAuthorizations_result(List<ByteBuffer>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
-
- ClientService.getUserAuthorizations_result(ClientService.getUserAuthorizations_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
-
Performs a deep copy on other.
- ClientService.getUserAuthorizations_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.getZooKeepers_args - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.getZooKeepers_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
-
- ClientService.getZooKeepers_args(ClientService.getZooKeepers_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
-
Performs a deep copy on other.
- ClientService.getZooKeepers_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.getZooKeepers_result - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.getZooKeepers_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
-
- ClientService.getZooKeepers_result(String) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
-
- ClientService.getZooKeepers_result(ClientService.getZooKeepers_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
-
Performs a deep copy on other.
- ClientService.getZooKeepers_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.grantNamespacePermission_args - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.grantNamespacePermission_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
-
- ClientService.grantNamespacePermission_args(TInfo, TCredentials, String, String, byte) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
-
- ClientService.grantNamespacePermission_args(ClientService.grantNamespacePermission_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
-
Performs a deep copy on other.
- ClientService.grantNamespacePermission_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.grantNamespacePermission_result - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.grantNamespacePermission_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
-
- ClientService.grantNamespacePermission_result(ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
-
- ClientService.grantNamespacePermission_result(ClientService.grantNamespacePermission_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
-
Performs a deep copy on other.
- ClientService.grantNamespacePermission_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.grantSystemPermission_args - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.grantSystemPermission_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
-
- ClientService.grantSystemPermission_args(TInfo, TCredentials, String, byte) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
-
- ClientService.grantSystemPermission_args(ClientService.grantSystemPermission_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
-
Performs a deep copy on other.
- ClientService.grantSystemPermission_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.grantSystemPermission_result - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.grantSystemPermission_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
-
- ClientService.grantSystemPermission_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
-
- ClientService.grantSystemPermission_result(ClientService.grantSystemPermission_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
-
Performs a deep copy on other.
- ClientService.grantSystemPermission_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.grantTablePermission_args - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.grantTablePermission_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
-
- ClientService.grantTablePermission_args(TInfo, TCredentials, String, String, byte) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
-
- ClientService.grantTablePermission_args(ClientService.grantTablePermission_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
-
Performs a deep copy on other.
- ClientService.grantTablePermission_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.grantTablePermission_result - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.grantTablePermission_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
-
- ClientService.grantTablePermission_result(ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
-
- ClientService.grantTablePermission_result(ClientService.grantTablePermission_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
-
Performs a deep copy on other.
- ClientService.grantTablePermission_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.hasNamespacePermission_args - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.hasNamespacePermission_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
-
- ClientService.hasNamespacePermission_args(TInfo, TCredentials, String, String, byte) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
-
- ClientService.hasNamespacePermission_args(ClientService.hasNamespacePermission_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
-
Performs a deep copy on other.
- ClientService.hasNamespacePermission_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.hasNamespacePermission_result - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.hasNamespacePermission_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
-
- ClientService.hasNamespacePermission_result(boolean, ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
-
- ClientService.hasNamespacePermission_result(ClientService.hasNamespacePermission_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
-
Performs a deep copy on other.
- ClientService.hasNamespacePermission_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.hasSystemPermission_args - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.hasSystemPermission_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
-
- ClientService.hasSystemPermission_args(TInfo, TCredentials, String, byte) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
-
- ClientService.hasSystemPermission_args(ClientService.hasSystemPermission_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
-
Performs a deep copy on other.
- ClientService.hasSystemPermission_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.hasSystemPermission_result - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.hasSystemPermission_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
-
- ClientService.hasSystemPermission_result(boolean, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
-
- ClientService.hasSystemPermission_result(ClientService.hasSystemPermission_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
-
Performs a deep copy on other.
- ClientService.hasSystemPermission_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.hasTablePermission_args - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.hasTablePermission_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
-
- ClientService.hasTablePermission_args(TInfo, TCredentials, String, String, byte) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
-
- ClientService.hasTablePermission_args(ClientService.hasTablePermission_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
-
Performs a deep copy on other.
- ClientService.hasTablePermission_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.hasTablePermission_result - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.hasTablePermission_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
-
- ClientService.hasTablePermission_result(boolean, ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
-
- ClientService.hasTablePermission_result(ClientService.hasTablePermission_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
-
Performs a deep copy on other.
- ClientService.hasTablePermission_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.Iface - Interface in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.isActive_args - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.isActive_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
-
- ClientService.isActive_args(TInfo, long) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
-
- ClientService.isActive_args(ClientService.isActive_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
-
Performs a deep copy on other.
- ClientService.isActive_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.isActive_result - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.isActive_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
-
- ClientService.isActive_result(boolean) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
-
- ClientService.isActive_result(ClientService.isActive_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
-
Performs a deep copy on other.
- ClientService.isActive_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.listLocalUsers_args - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.listLocalUsers_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
-
- ClientService.listLocalUsers_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
-
- ClientService.listLocalUsers_args(ClientService.listLocalUsers_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
-
Performs a deep copy on other.
- ClientService.listLocalUsers_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.listLocalUsers_result - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.listLocalUsers_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
-
- ClientService.listLocalUsers_result(Set<String>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
-
- ClientService.listLocalUsers_result(ClientService.listLocalUsers_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
-
Performs a deep copy on other.
- ClientService.listLocalUsers_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.ping_args - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.ping_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
-
- ClientService.ping_args(TCredentials) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
-
- ClientService.ping_args(ClientService.ping_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
-
Performs a deep copy on other.
- ClientService.ping_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.ping_result - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.ping_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
-
- ClientService.ping_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
-
- ClientService.ping_result(ClientService.ping_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
-
Performs a deep copy on other.
- ClientService.ping_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.Processor<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Processor(I) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor
-
- ClientService.Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor
-
- ClientService.Processor.authenticate<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Processor.authenticate() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.authenticate
-
- ClientService.Processor.authenticateUser<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Processor.authenticateUser() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.authenticateUser
-
- ClientService.Processor.bulkImportFiles<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Processor.bulkImportFiles() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.bulkImportFiles
-
- ClientService.Processor.changeAuthorizations<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Processor.changeAuthorizations() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.changeAuthorizations
-
- ClientService.Processor.changeLocalUserPassword<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Processor.changeLocalUserPassword() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.changeLocalUserPassword
-
- ClientService.Processor.checkClass<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Processor.checkClass() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.checkClass
-
- ClientService.Processor.checkNamespaceClass<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Processor.checkNamespaceClass() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.checkNamespaceClass
-
- ClientService.Processor.checkTableClass<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Processor.checkTableClass() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.checkTableClass
-
- ClientService.Processor.createLocalUser<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Processor.createLocalUser() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.createLocalUser
-
- ClientService.Processor.dropLocalUser<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Processor.dropLocalUser() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.dropLocalUser
-
- ClientService.Processor.getConfiguration<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Processor.getConfiguration() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getConfiguration
-
- ClientService.Processor.getDiskUsage<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Processor.getDiskUsage() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getDiskUsage
-
- ClientService.Processor.getInstanceId<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Processor.getInstanceId() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getInstanceId
-
- ClientService.Processor.getNamespaceConfiguration<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Processor.getNamespaceConfiguration() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getNamespaceConfiguration
-
- ClientService.Processor.getRootTabletLocation<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Processor.getRootTabletLocation() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getRootTabletLocation
-
- ClientService.Processor.getTableConfiguration<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Processor.getTableConfiguration() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getTableConfiguration
-
- ClientService.Processor.getUserAuthorizations<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Processor.getUserAuthorizations() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getUserAuthorizations
-
- ClientService.Processor.getZooKeepers<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Processor.getZooKeepers() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getZooKeepers
-
- ClientService.Processor.grantNamespacePermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Processor.grantNamespacePermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.grantNamespacePermission
-
- ClientService.Processor.grantSystemPermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Processor.grantSystemPermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.grantSystemPermission
-
- ClientService.Processor.grantTablePermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Processor.grantTablePermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.grantTablePermission
-
- ClientService.Processor.hasNamespacePermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Processor.hasNamespacePermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.hasNamespacePermission
-
- ClientService.Processor.hasSystemPermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Processor.hasSystemPermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.hasSystemPermission
-
- ClientService.Processor.hasTablePermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Processor.hasTablePermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.hasTablePermission
-
- ClientService.Processor.isActive<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Processor.isActive() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.isActive
-
- ClientService.Processor.listLocalUsers<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Processor.listLocalUsers() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.listLocalUsers
-
- ClientService.Processor.ping<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Processor.ping() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.ping
-
- ClientService.Processor.revokeNamespacePermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Processor.revokeNamespacePermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.revokeNamespacePermission
-
- ClientService.Processor.revokeSystemPermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Processor.revokeSystemPermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.revokeSystemPermission
-
- ClientService.Processor.revokeTablePermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.Processor.revokeTablePermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.revokeTablePermission
-
- ClientService.revokeNamespacePermission_args - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.revokeNamespacePermission_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
-
- ClientService.revokeNamespacePermission_args(TInfo, TCredentials, String, String, byte) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
-
- ClientService.revokeNamespacePermission_args(ClientService.revokeNamespacePermission_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
-
Performs a deep copy on other.
- ClientService.revokeNamespacePermission_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.revokeNamespacePermission_result - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.revokeNamespacePermission_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
-
- ClientService.revokeNamespacePermission_result(ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
-
- ClientService.revokeNamespacePermission_result(ClientService.revokeNamespacePermission_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
-
Performs a deep copy on other.
- ClientService.revokeNamespacePermission_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.revokeSystemPermission_args - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.revokeSystemPermission_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
-
- ClientService.revokeSystemPermission_args(TInfo, TCredentials, String, byte) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
-
- ClientService.revokeSystemPermission_args(ClientService.revokeSystemPermission_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
-
Performs a deep copy on other.
- ClientService.revokeSystemPermission_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.revokeSystemPermission_result - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.revokeSystemPermission_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
-
- ClientService.revokeSystemPermission_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
-
- ClientService.revokeSystemPermission_result(ClientService.revokeSystemPermission_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
-
Performs a deep copy on other.
- ClientService.revokeSystemPermission_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.revokeTablePermission_args - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.revokeTablePermission_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
-
- ClientService.revokeTablePermission_args(TInfo, TCredentials, String, String, byte) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
-
- ClientService.revokeTablePermission_args(ClientService.revokeTablePermission_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
-
Performs a deep copy on other.
- ClientService.revokeTablePermission_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.revokeTablePermission_result - Class in org.apache.accumulo.core.client.impl.thrift
-
- ClientService.revokeTablePermission_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
-
- ClientService.revokeTablePermission_result(ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
-
- ClientService.revokeTablePermission_result(ClientService.revokeTablePermission_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
-
Performs a deep copy on other.
- ClientService.revokeTablePermission_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientSideIteratorScanner - Class in org.apache.accumulo.core.client
-
A scanner that instantiates iterators on the client side instead of on the tablet server.
- ClientSideIteratorScanner(Scanner) - Constructor for class org.apache.accumulo.core.client.ClientSideIteratorScanner
-
Constructs a scanner that can execute client-side iterators.
- ClientSideIteratorScanner.ScannerTranslator - Class in org.apache.accumulo.core.client
-
A class that wraps a Scanner in a SortedKeyValueIterator so that other accumulo iterators can use it as a source.
- ClientSideIteratorScanner.ScannerTranslator(Scanner) - Constructor for class org.apache.accumulo.core.client.ClientSideIteratorScanner.ScannerTranslator
-
Constructs an accumulo iterator from a scanner.
- 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
-
Same as other clip function except if gives the option to return null of the ranges do not overlap instead of throwing an exception.
- clone(String, String, boolean, Map<String, String>, Set<String>) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
Clone a table from an existing table.
- clone(String, String, boolean, Map<String, String>, Set<String>) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
-
- clone() - 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.NullToken
-
- clone() - Method in class org.apache.accumulo.core.client.security.tokens.PasswordToken
-
- clone() - Method in class org.apache.accumulo.core.data.Key
-
- CLONE_EXCLUDE_PREFIX - Static variable in class org.apache.accumulo.core.client.impl.TableOperationsImpl
-
- CLONE_PREFIX - Static variable in class org.apache.accumulo.core.Constants
-
- CLONE_PREFIX_BYTES - Static variable in class org.apache.accumulo.core.Constants
-
- CloneTableCommand - Class in org.apache.accumulo.core.util.shell.commands
-
- CloneTableCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.CloneTableCommand
-
- close() - Method in interface org.apache.accumulo.core.client.BatchDeleter
-
Releases any resources.
- close() - Method in interface org.apache.accumulo.core.client.BatchScanner
-
Cleans up and finalizes the scanner
- close() - Method in interface org.apache.accumulo.core.client.BatchWriter
-
Flush and release any resources.
- close() - Method in interface org.apache.accumulo.core.client.ConditionalWriter
-
release any resources (like threads pools) used by conditional writer
- close() - Method in class org.apache.accumulo.core.client.impl.BatchWriterImpl
-
- close(MasterClientService.Iface) - Static method in class org.apache.accumulo.core.client.impl.MasterClient
-
- close() - Method in class org.apache.accumulo.core.client.impl.MultiTableBatchWriterImpl
-
- close() - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
-
- close(ClientService.Client) - Static method in class org.apache.accumulo.core.client.impl.ServerClient
-
- close() - Method in class org.apache.accumulo.core.client.impl.TabletServerBatchReader
-
- close() - Method in class org.apache.accumulo.core.client.impl.TabletServerBatchWriter
-
- close() - Method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat.AbstractRecordReader
-
- close(Reporter) - Method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat.AccumuloRecordWriter
-
- close() - Method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
-
- close(TaskAttemptContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat.AccumuloRecordWriter
-
- close() - Method in class org.apache.accumulo.core.client.mock.MockBatchScanner
-
- close() - Method in class org.apache.accumulo.core.client.mock.MockBatchWriter
-
- close() - Method in class org.apache.accumulo.core.client.mock.MockMultiTableBatchWriter
-
- close() - Method in interface org.apache.accumulo.core.client.MultiTableBatchWriter
-
Flush and release all resources.
- close() - Method in interface org.apache.accumulo.core.client.ScannerBase
-
Closes any underlying connections on the scanner
- close() - Method in interface org.apache.accumulo.core.file.blockfile.ABlockReader
-
- close() - Method in interface org.apache.accumulo.core.file.blockfile.ABlockWriter
-
- close() - Method in interface org.apache.accumulo.core.file.blockfile.BlockFileReader
-
- close() - Method in interface org.apache.accumulo.core.file.blockfile.BlockFileWriter
-
- close() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.BlockWrite
-
- close() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
-
- close() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Writer
-
- close() - Method in class org.apache.accumulo.core.file.blockfile.impl.SeekableByteArrayInputStream
-
- close() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
-
- close() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Writer
-
- close() - Method in interface org.apache.accumulo.core.file.FileSKVIterator
-
- close() - Method in interface org.apache.accumulo.core.file.FileSKVWriter
-
- close() - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
-
- close() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader.BlockReader
-
Finishing reading the block.
- close() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
-
Finishing reading the BCFile.
- close() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Writer.BlockAppender
-
Signaling the end of write to the block.
- close() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Writer
-
Close the BCFile Writer.
- close(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() - 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.iterators.system.MapFileIterator
-
- close() - Method in class org.apache.accumulo.core.iterators.system.SequenceFileIterator
-
- close() - Method in class org.apache.accumulo.core.security.crypto.BlockedInputStream
-
- close() - Method in class org.apache.accumulo.core.security.crypto.BlockedOutputStream
-
- close() - Method in class org.apache.accumulo.core.security.crypto.DiscardCloseOutputStream
-
- close() - Method in class org.apache.accumulo.core.util.shell.Shell.PrintFile
-
- close() - Method in interface org.apache.accumulo.core.util.shell.Shell.PrintLine
-
- close() - Method in class org.apache.accumulo.core.util.shell.Shell.PrintShell
-
- closeConditionalUpdate(TInfo, long, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
-
- closeConditionalUpdate(TInfo, long, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
-
- closeConditionalUpdate(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
-
- closeConditionalUpdate(TInfo, long) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
-
- closeDeepCopies() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
-
- closeDeepCopies() - Method in interface org.apache.accumulo.core.file.FileSKVIterator
-
- closeDeepCopies() - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
-
- closeDeepCopies() - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
-
- closeDeepCopies() - Method in class org.apache.accumulo.core.iterators.system.MapFileIterator
-
- closeDeepCopies() - Method in class org.apache.accumulo.core.iterators.system.SequenceFileIterator
-
- closeMultiScan(TInfo, long, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
-
- closeMultiScan(TInfo, long, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
-
- closeMultiScan(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
-
- closeMultiScan(TInfo, long) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
-
- closeScan(TInfo, long, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
-
- closeScan(TInfo, long, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
-
- closeScan(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
-
- closeScan(TInfo, long) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
-
- closeUpdate(TInfo, long, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
-
- closeUpdate(TInfo, long, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
-
- closeUpdate(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
-
- closeUpdate(TInfo, long) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
-
- ClsCommand - Class in org.apache.accumulo.core.util.shell.commands
-
- ClsCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.ClsCommand
-
- cmid - Variable in class org.apache.accumulo.core.data.thrift.TCMResult
-
- code - Variable in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
-
- COLF_REGEX - Static variable in class org.apache.accumulo.core.iterators.user.RegExFilter
-
- colFamily - Variable in class org.apache.accumulo.core.data.Key
-
- colFamily - Variable in class org.apache.accumulo.core.data.thrift.TKey
-
- colFamSet - Variable in class org.apache.accumulo.core.iterators.system.ColumnFamilySkippingIterator
-
- collect(Value) - Method in interface org.apache.accumulo.core.iterators.aggregation.Aggregator
-
Deprecated.
- collect(Value) - Method in class org.apache.accumulo.core.iterators.aggregation.LongSummation
-
Deprecated.
- collect(Value) - Method in class org.apache.accumulo.core.iterators.aggregation.NumArraySummation
-
Deprecated.
- collect(Value) - Method in class org.apache.accumulo.core.iterators.aggregation.NumSummation
-
Deprecated.
- collect(Value) - Method in class org.apache.accumulo.core.iterators.aggregation.StringMax
-
Deprecated.
- collect(Value) - Method in class org.apache.accumulo.core.iterators.aggregation.StringMin
-
Deprecated.
- collect(Value) - Method in class org.apache.accumulo.core.iterators.aggregation.StringSummation
-
Deprecated.
- COLQ_REGEX - Static variable in class org.apache.accumulo.core.iterators.user.RegExFilter
-
- colQualifier - Variable in class org.apache.accumulo.core.data.Key
-
- colQualifier - Variable in class org.apache.accumulo.core.data.thrift.TKey
-
- Column - Class in org.apache.accumulo.core.data
-
- Column() - Constructor for class org.apache.accumulo.core.data.Column
-
- Column(byte[], byte[], byte[]) - Constructor for class org.apache.accumulo.core.data.Column
-
- Column(TColumn) - Constructor for class org.apache.accumulo.core.data.Column
-
- 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
-
- ColumnAgeOffFilter.TTLSet(Map<String, String>) - Constructor for class org.apache.accumulo.core.iterators.user.ColumnAgeOffFilter.TTLSet
-
- columnFamilies - Variable in class org.apache.accumulo.core.iterators.system.LocalityGroupIterator.LocalityGroup
-
- columnFamily - Variable in class org.apache.accumulo.core.data.Column
-
- columnFamily - Variable in class org.apache.accumulo.core.data.thrift.TColumn
-
- ColumnFamilyCounter - Class in org.apache.accumulo.core.iterators
-
- ColumnFamilyCounter() - Constructor for class org.apache.accumulo.core.iterators.ColumnFamilyCounter
-
- ColumnFamilyFunctor - Class in org.apache.accumulo.core.file.keyfunctor
-
- ColumnFamilyFunctor() - Constructor for class org.apache.accumulo.core.file.keyfunctor.ColumnFamilyFunctor
-
- ColumnFamilySkippingIterator - Class in org.apache.accumulo.core.iterators.system
-
- ColumnFamilySkippingIterator(SortedKeyValueIterator<Key, Value>) - Constructor for class org.apache.accumulo.core.iterators.system.ColumnFamilySkippingIterator
-
- ColumnFamilySkippingIterator(SortedKeyValueIterator<Key, Value>, Set<ByteSequence>, boolean) - Constructor for class org.apache.accumulo.core.iterators.system.ColumnFamilySkippingIterator
-
- ColumnFQ - Class in org.apache.accumulo.core.util
-
- ColumnFQ(Text, Text) - Constructor for class org.apache.accumulo.core.util.ColumnFQ
-
- ColumnFQ(Key) - Constructor for class org.apache.accumulo.core.util.ColumnFQ
-
- ColumnFQ(ColumnUpdate) - Constructor for class org.apache.accumulo.core.util.ColumnFQ
-
- columnQualifier - Variable in class org.apache.accumulo.core.data.Column
-
- columnQualifier - Variable in class org.apache.accumulo.core.data.thrift.TColumn
-
- ColumnQualifierFilter - Class in org.apache.accumulo.core.iterators.system
-
- ColumnQualifierFilter() - Constructor for class org.apache.accumulo.core.iterators.system.ColumnQualifierFilter
-
- ColumnQualifierFilter(SortedKeyValueIterator<Key, Value>, Set<Column>) - Constructor for class org.apache.accumulo.core.iterators.system.ColumnQualifierFilter
-
- ColumnQualifierFilter(SortedKeyValueIterator<Key, Value>, HashSet<ByteSequence>, HashMap<ByteSequence, HashSet<ByteSequence>>, boolean) - Constructor for class org.apache.accumulo.core.iterators.system.ColumnQualifierFilter
-
- ColumnQualifierFunctor - Class in org.apache.accumulo.core.file.keyfunctor
-
- ColumnQualifierFunctor() - Constructor for class org.apache.accumulo.core.file.keyfunctor.ColumnQualifierFunctor
-
- columns - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
-
- columns - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
-
- columns - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
-
- COLUMNS_OPTION - Static variable in class org.apache.accumulo.core.iterators.Combiner
-
- ColumnSet - Class in org.apache.accumulo.core.iterators.conf
-
- ColumnSet() - Constructor for class org.apache.accumulo.core.iterators.conf.ColumnSet
-
- ColumnSet(Collection<String>) - Constructor for class org.apache.accumulo.core.iterators.conf.ColumnSet
-
- ColumnSliceFilter - Class in org.apache.accumulo.core.iterators.user
-
- ColumnSliceFilter() - Constructor for class org.apache.accumulo.core.iterators.user.ColumnSliceFilter
-
- ColumnToClassMapping<K> - Class in org.apache.accumulo.core.iterators.conf
-
- ColumnToClassMapping() - Constructor for class org.apache.accumulo.core.iterators.conf.ColumnToClassMapping
-
- ColumnToClassMapping(Map<String, String>, Class<? extends K>) - Constructor for class org.apache.accumulo.core.iterators.conf.ColumnToClassMapping
-
- ColumnToClassMapping(Map<String, String>, Class<? extends K>, String) - Constructor for class org.apache.accumulo.core.iterators.conf.ColumnToClassMapping
-
- 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
-
- ColumnUtil - Class in org.apache.accumulo.core.iterators.conf
-
- ColumnUtil() - Constructor for class org.apache.accumulo.core.iterators.conf.ColumnUtil
-
- ColumnUtil.ColFamHashKey - Class in org.apache.accumulo.core.iterators.conf
-
- ColumnUtil.ColHashKey - Class in org.apache.accumulo.core.iterators.conf
-
- columnVisibility - Variable in class org.apache.accumulo.core.data.Column
-
- columnVisibility - Variable in class org.apache.accumulo.core.data.thrift.TColumn
-
- ColumnVisibility - Class in org.apache.accumulo.core.security
-
Validate the column visibility is a valid expression and set the visibility for a Mutation.
- ColumnVisibility() - Constructor for class org.apache.accumulo.core.security.ColumnVisibility
-
Creates an empty visibility.
- ColumnVisibility(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(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.Node - Class in org.apache.accumulo.core.security
-
A node in the parse tree for a visibility expression.
- ColumnVisibility.Node(ColumnVisibility.NodeType, int) - Constructor for class org.apache.accumulo.core.security.ColumnVisibility.Node
-
- ColumnVisibility.Node(int, int) - Constructor for class org.apache.accumulo.core.security.ColumnVisibility.Node
-
- ColumnVisibility.NodeComparator - Class in org.apache.accumulo.core.security
-
A node comparator.
- ColumnVisibility.NodeComparator(byte[]) - Constructor for class org.apache.accumulo.core.security.ColumnVisibility.NodeComparator
-
Creates a new comparator.
- ColumnVisibility.NodeType - Enum in org.apache.accumulo.core.security
-
The node types in a parse tree for a visibility expression.
- colVisibility - Variable in class org.apache.accumulo.core.data.Key
-
- colVisibility - Variable in class org.apache.accumulo.core.data.thrift.TKey
-
- Combiner - Class in org.apache.accumulo.core.iterators
-
A SortedKeyValueIterator that combines the Values for different versions (timestamp) of a Key within a row into a single Value.
- Combiner() - Constructor for class org.apache.accumulo.core.iterators.Combiner
-
- Combiner.ValueIterator - Class in org.apache.accumulo.core.iterators
-
A Java Iterator that iterates over the Values for a given Key from a source SortedKeyValueIterator.
- Combiner.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.
- commandFactory - Variable in class org.apache.accumulo.core.util.shell.Shell
-
- commandGrouping - Variable in class org.apache.accumulo.core.util.shell.Shell
-
- COMMENT_PREFIX - Static variable in class org.apache.accumulo.core.util.shell.Shell
-
- 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, 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, boolean, boolean) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
-
- compact(String, Text, Text, List<IteratorSetting>, boolean, boolean) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
-
- compact(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
-
- compact(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
-
- compact(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
-
- compact(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
-
- COMPACT_COLUMN - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ServerColumnFamily
-
Holds compact IDs to enable waiting on a compaction to complete
- CompactCommand - Class in org.apache.accumulo.core.util.shell.commands
-
- CompactCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.CompactCommand
-
- Compacting - Class in org.apache.accumulo.core.master.thrift
-
- Compacting() - Constructor for class org.apache.accumulo.core.master.thrift.Compacting
-
- Compacting(int, int) - Constructor for class org.apache.accumulo.core.master.thrift.Compacting
-
- Compacting(Compacting) - Constructor for class org.apache.accumulo.core.master.thrift.Compacting
-
Performs a deep copy on other.
- Compacting._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- CompactionReason - Enum in org.apache.accumulo.core.tabletserver.thrift
-
- CompactionType - Enum in org.apache.accumulo.core.tabletserver.thrift
-
- ComparableBytes - Class in org.apache.accumulo.core.data
-
- ComparableBytes(byte[]) - Constructor for class org.apache.accumulo.core.data.ComparableBytes
-
- 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
-
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.accumulo.core.data.Value.Comparator
-
- compare(IterInfo, IterInfo) - Method in class org.apache.accumulo.core.iterators.IteratorUtil.IterInfoComparator
-
- compare(ColumnVisibility.Node, ColumnVisibility.Node) - Method in class org.apache.accumulo.core.security.ColumnVisibility.NodeComparator
-
- compare(byte[], byte[]) - Method in class org.apache.accumulo.core.util.ByteArrayComparator
-
- compareBytes(ByteSequence, ByteSequence) - Static method in class org.apache.accumulo.core.data.ByteSequence
-
- compareColumnFamily(Text) - Method in class org.apache.accumulo.core.data.Key
-
Efficiently compare the the column family of a key w/o allocating a text object and copying the column qualifier into it.
- compareColumnQualifier(Text) - Method in class org.apache.accumulo.core.data.Key
-
Efficiently compare the the column qualifier of a key w/o allocating a text object and copying the column qualifier into it.
- compareRow(Text) - Method in class org.apache.accumulo.core.data.Key
-
Efficiently compare the the row of a key w/o allocating a text object and copying the row into it.
- compareTo(TabletLocator.TabletLocation) - Method in class org.apache.accumulo.core.client.impl.TabletLocator.TabletLocation
-
- compareTo(ClientService.authenticate_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
-
- compareTo(ClientService.authenticate_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
-
- compareTo(ClientService.authenticateUser_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
-
- compareTo(ClientService.authenticateUser_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
-
- compareTo(ClientService.bulkImportFiles_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
-
- compareTo(ClientService.bulkImportFiles_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
-
- compareTo(ClientService.changeAuthorizations_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
-
- compareTo(ClientService.changeAuthorizations_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
-
- compareTo(ClientService.changeLocalUserPassword_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
-
- compareTo(ClientService.changeLocalUserPassword_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
-
- compareTo(ClientService.checkClass_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
-
- compareTo(ClientService.checkClass_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
-
- compareTo(ClientService.checkNamespaceClass_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
-
- compareTo(ClientService.checkNamespaceClass_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
-
- compareTo(ClientService.checkTableClass_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
-
- compareTo(ClientService.checkTableClass_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
-
- compareTo(ClientService.createLocalUser_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
-
- compareTo(ClientService.createLocalUser_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
-
- compareTo(ClientService.dropLocalUser_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
-
- compareTo(ClientService.dropLocalUser_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
-
- compareTo(ClientService.getConfiguration_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
-
- compareTo(ClientService.getConfiguration_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
-
- compareTo(ClientService.getDiskUsage_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
-
- compareTo(ClientService.getDiskUsage_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
-
- compareTo(ClientService.getInstanceId_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
-
- compareTo(ClientService.getInstanceId_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
-
- compareTo(ClientService.getNamespaceConfiguration_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
-
- compareTo(ClientService.getNamespaceConfiguration_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
-
- compareTo(ClientService.getRootTabletLocation_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
-
- compareTo(ClientService.getRootTabletLocation_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
-
- compareTo(ClientService.getTableConfiguration_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
-
- compareTo(ClientService.getTableConfiguration_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
-
- compareTo(ClientService.getUserAuthorizations_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
-
- compareTo(ClientService.getUserAuthorizations_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
-
- compareTo(ClientService.getZooKeepers_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
-
- compareTo(ClientService.getZooKeepers_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
-
- compareTo(ClientService.grantNamespacePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
-
- compareTo(ClientService.grantNamespacePermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
-
- compareTo(ClientService.grantSystemPermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
-
- compareTo(ClientService.grantSystemPermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
-
- compareTo(ClientService.grantTablePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
-
- compareTo(ClientService.grantTablePermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
-
- compareTo(ClientService.hasNamespacePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
-
- compareTo(ClientService.hasNamespacePermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
-
- compareTo(ClientService.hasSystemPermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
-
- compareTo(ClientService.hasSystemPermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
-
- compareTo(ClientService.hasTablePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
-
- compareTo(ClientService.hasTablePermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
-
- compareTo(ClientService.isActive_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
-
- compareTo(ClientService.isActive_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
-
- compareTo(ClientService.listLocalUsers_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
-
- compareTo(ClientService.listLocalUsers_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
-
- compareTo(ClientService.ping_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
-
- compareTo(ClientService.ping_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
-
- compareTo(ClientService.revokeNamespacePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
-
- compareTo(ClientService.revokeNamespacePermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
-
- compareTo(ClientService.revokeSystemPermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
-
- compareTo(ClientService.revokeSystemPermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
-
- compareTo(ClientService.revokeTablePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
-
- compareTo(ClientService.revokeTablePermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
-
- compareTo(TDiskUsage) - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
-
- compareTo(ThriftSecurityException) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
-
- compareTo(ThriftTableOperationException) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
-
- compareTo(ThriftTest.fails_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args
-
- compareTo(ThriftTest.fails_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
-
- compareTo(ThriftTest.success_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args
-
- compareTo(ThriftTest.success_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
-
- compareTo(ThriftTest.throwsError_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args
-
- compareTo(ThriftTest.throwsError_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
-
- compareTo(AuthenticationToken.TokenProperty) - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.TokenProperty
-
- compareTo(ByteSequence) - Method in class org.apache.accumulo.core.data.ByteSequence
-
- compareTo(Column) - Method in class org.apache.accumulo.core.data.Column
-
- compareTo(Key, PartialKey) - Method in class org.apache.accumulo.core.data.Key
-
- compareTo(Key) - Method in class org.apache.accumulo.core.data.Key
-
Compare all elements of a key.
- compareTo(KeyExtent) - Method in class org.apache.accumulo.core.data.KeyExtent
-
Compares extents based on rows
- compareTo(Range) - Method in class org.apache.accumulo.core.data.Range
-
Compares this range to another range.
- compareTo(InitialMultiScan) - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
-
- compareTo(InitialScan) - Method in class org.apache.accumulo.core.data.thrift.InitialScan
-
- compareTo(IterInfo) - Method in class org.apache.accumulo.core.data.thrift.IterInfo
-
- compareTo(MapFileInfo) - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
-
- compareTo(MultiScanResult) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
-
- compareTo(ScanResult) - Method in class org.apache.accumulo.core.data.thrift.ScanResult
-
- compareTo(TCMResult) - Method in class org.apache.accumulo.core.data.thrift.TCMResult
-
- compareTo(TColumn) - Method in class org.apache.accumulo.core.data.thrift.TColumn
-
- compareTo(TCondition) - Method in class org.apache.accumulo.core.data.thrift.TCondition
-
- compareTo(TConditionalMutation) - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
-
- compareTo(TConditionalSession) - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
-
- compareTo(TConstraintViolationSummary) - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
-
- compareTo(TKey) - Method in class org.apache.accumulo.core.data.thrift.TKey
-
- compareTo(TKeyExtent) - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
-
- compareTo(TKeyValue) - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
-
- compareTo(TMutation) - Method in class org.apache.accumulo.core.data.thrift.TMutation
-
- compareTo(TRange) - Method in class org.apache.accumulo.core.data.thrift.TRange
-
- compareTo(UpdateErrors) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
-
- compareTo(Object) - Method in class org.apache.accumulo.core.data.Value
-
Define the sort order of the BytesWritable.
- compareTo(byte[]) - Method in class org.apache.accumulo.core.data.Value
-
Compares the bytes in this object to the specified byte array
- compareTo(CachedBlock) - Method in class org.apache.accumulo.core.file.blockfile.cache.CachedBlock
-
- compareTo(Utils.Version) - Method in class org.apache.accumulo.core.file.rfile.bcfile.Utils.Version
-
Compare this version with another version.
- compareTo(BlockIndex.BlockIndexEntry) - Method in class org.apache.accumulo.core.file.rfile.BlockIndex.BlockIndexEntry
-
- compareTo(MultiLevelIndex.IndexEntry) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
-
- compareTo(GcCycleStats) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
-
- compareTo(GCMonitorService.getStatus_args) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
-
- compareTo(GCMonitorService.getStatus_result) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
-
- compareTo(GCStatus) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
-
- compareTo(OrIterator.TermSource) - Method in class org.apache.accumulo.core.iterators.OrIterator.TermSource
-
- compareTo(Compacting) - Method in class org.apache.accumulo.core.master.thrift.Compacting
-
- compareTo(DeadServer) - Method in class org.apache.accumulo.core.master.thrift.DeadServer
-
- compareTo(FateService.beginFateOperation_args) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
-
- compareTo(FateService.beginFateOperation_result) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
-
- compareTo(FateService.executeFateOperation_args) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
-
- compareTo(FateService.executeFateOperation_result) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
-
- compareTo(FateService.finishFateOperation_args) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
-
- compareTo(FateService.finishFateOperation_result) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
-
- compareTo(FateService.waitForFateOperation_args) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
-
- compareTo(FateService.waitForFateOperation_result) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
-
- compareTo(MasterClientService.getMasterStats_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
-
- compareTo(MasterClientService.getMasterStats_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
-
- compareTo(MasterClientService.initiateFlush_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
-
- compareTo(MasterClientService.initiateFlush_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
-
- compareTo(MasterClientService.removeNamespaceProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
-
- compareTo(MasterClientService.removeNamespaceProperty_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
-
- compareTo(MasterClientService.removeSystemProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
-
- compareTo(MasterClientService.removeSystemProperty_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
-
- compareTo(MasterClientService.removeTableProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
-
- compareTo(MasterClientService.removeTableProperty_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
-
- compareTo(MasterClientService.reportSplitExtent_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
-
- compareTo(MasterClientService.reportTabletStatus_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
-
- compareTo(MasterClientService.setMasterGoalState_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
-
- compareTo(MasterClientService.setMasterGoalState_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
-
- compareTo(MasterClientService.setNamespaceProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
-
- compareTo(MasterClientService.setNamespaceProperty_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
-
- compareTo(MasterClientService.setSystemProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
-
- compareTo(MasterClientService.setSystemProperty_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
-
- compareTo(MasterClientService.setTableProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
-
- compareTo(MasterClientService.setTableProperty_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
-
- compareTo(MasterClientService.shutdown_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
-
- compareTo(MasterClientService.shutdown_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
-
- compareTo(MasterClientService.shutdownTabletServer_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
-
- compareTo(MasterClientService.shutdownTabletServer_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
-
- compareTo(MasterClientService.waitForFlush_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
-
- compareTo(MasterClientService.waitForFlush_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
-
- compareTo(MasterMonitorInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
-
- compareTo(RecoveryException) - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
-
- compareTo(RecoveryStatus) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
-
- compareTo(TableInfo) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
-
- compareTo(TabletServerStatus) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
-
- compareTo(TabletSplit) - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
-
- compareTo(TCredentials) - Method in class org.apache.accumulo.core.security.thrift.TCredentials
-
- compareTo(ActionStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
-
- compareTo(ActiveCompaction) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
-
- compareTo(ActiveScan) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
-
- compareTo(ConstraintViolationException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
-
- compareTo(IteratorConfig) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
-
- compareTo(NoSuchScanIDException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
-
- compareTo(NotServingTabletException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
-
- compareTo(TabletClientService.applyUpdates_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
-
- compareTo(TabletClientService.bulkImport_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
-
- compareTo(TabletClientService.bulkImport_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
-
- compareTo(TabletClientService.chop_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
-
- compareTo(TabletClientService.closeConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
-
- compareTo(TabletClientService.closeMultiScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
-
- compareTo(TabletClientService.closeMultiScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
-
- compareTo(TabletClientService.closeScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
-
- compareTo(TabletClientService.closeUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
-
- compareTo(TabletClientService.closeUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
-
- compareTo(TabletClientService.compact_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
-
- compareTo(TabletClientService.conditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
-
- compareTo(TabletClientService.conditionalUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
-
- compareTo(TabletClientService.continueMultiScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
-
- compareTo(TabletClientService.continueMultiScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
-
- compareTo(TabletClientService.continueScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
-
- compareTo(TabletClientService.continueScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
-
- compareTo(TabletClientService.fastHalt_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
-
- compareTo(TabletClientService.flush_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
-
- compareTo(TabletClientService.flushTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
-
- compareTo(TabletClientService.getActiveCompactions_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
-
- compareTo(TabletClientService.getActiveCompactions_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
-
- compareTo(TabletClientService.getActiveScans_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
-
- compareTo(TabletClientService.getActiveScans_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
-
- compareTo(TabletClientService.getHistoricalStats_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
-
- compareTo(TabletClientService.getHistoricalStats_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
-
- compareTo(TabletClientService.getTabletServerStatus_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
-
- compareTo(TabletClientService.getTabletServerStatus_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
-
- compareTo(TabletClientService.getTabletStats_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
-
- compareTo(TabletClientService.getTabletStats_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
-
- compareTo(TabletClientService.halt_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
-
- compareTo(TabletClientService.halt_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
-
- compareTo(TabletClientService.invalidateConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
-
- compareTo(TabletClientService.invalidateConditionalUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
-
- compareTo(TabletClientService.loadTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
-
- compareTo(TabletClientService.removeLogs_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
-
- compareTo(TabletClientService.splitTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
-
- compareTo(TabletClientService.splitTablet_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
-
- compareTo(TabletClientService.startConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
-
- compareTo(TabletClientService.startConditionalUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
-
- compareTo(TabletClientService.startMultiScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
-
- compareTo(TabletClientService.startMultiScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
-
- compareTo(TabletClientService.startScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
-
- compareTo(TabletClientService.startScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
-
- compareTo(TabletClientService.startUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
-
- compareTo(TabletClientService.startUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
-
- compareTo(TabletClientService.unloadTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
-
- compareTo(TabletClientService.update_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
-
- compareTo(TabletClientService.update_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
-
- compareTo(TabletStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
-
- compareTo(TIteratorSetting) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
-
- compareTo(TooManyFilesException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
-
- compareTo(ColumnFQ) - Method in class org.apache.accumulo.core.util.ColumnFQ
-
- compareTo(ComparablePair<A, B>) - Method in class org.apache.accumulo.core.util.ComparablePair
-
- compareTo(ServerServices) - Method in class org.apache.accumulo.core.util.ServerServices
-
- compatibleWith(Utils.Version) - Method in class org.apache.accumulo.core.file.rfile.bcfile.Utils.Version
-
Test compatibility.
- complete(String, int, List) - Method in class org.apache.accumulo.core.util.shell.ShellCompletor
-
- compress(IteratorSetting[]) - Method in class org.apache.accumulo.core.client.impl.CompressedIterators
-
- compress(List<? extends KeyValue>) - Static method in class org.apache.accumulo.core.data.Key
-
Use this to compress a list of keys before sending them via thrift.
- CompressedIterators - Class in org.apache.accumulo.core.client.impl
-
- CompressedIterators() - Constructor for class org.apache.accumulo.core.client.impl.CompressedIterators
-
- CompressedIterators(List<String>) - Constructor for class org.apache.accumulo.core.client.impl.CompressedIterators
-
- CompressedIterators.IterConfig - Class in org.apache.accumulo.core.client.impl
-
- CompressedIterators.IterConfig() - Constructor for class org.apache.accumulo.core.client.impl.CompressedIterators.IterConfig
-
- Compression - Class in org.apache.accumulo.core.file.rfile.bcfile
-
Compression related stuff.
- Compression.Algorithm - Enum in org.apache.accumulo.core.file.rfile.bcfile
-
Compression algorithms.
- COMPRESSION_GZ - Static variable in class org.apache.accumulo.core.file.rfile.bcfile.Compression
-
compression: gzip
- COMPRESSION_LZO - Static variable in class org.apache.accumulo.core.file.rfile.bcfile.Compression
-
compression: lzo
- COMPRESSION_NONE - Static variable in class org.apache.accumulo.core.file.rfile.bcfile.Compression
-
compression: none
- COMPRESSION_SNAPPY - Static variable in class org.apache.accumulo.core.file.rfile.bcfile.Compression
-
snappy codec
- computeReseekRange(Range) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
-
Possibly expand range
to include everything for the key prefix we are working with.
- concat(byte[]...) - Static method in class org.apache.accumulo.core.client.lexicoder.impl.ByteUtils
-
Concatenates byte arrays with 0x00 as a delimiter
- CONCURRENT_HASHMAP - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
-
Overhead for ConcurrentHashMap
- CONCURRENT_HASHMAP_ENTRY - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
-
Overhead for ConcurrentHashMap.Entry
- CONCURRENT_HASHMAP_SEGMENT - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
-
Overhead for ConcurrentHashMap.Segment
- CONCURRENT_SKIPLISTMAP - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
-
Overhead for ConcurrentSkipListMap
- CONCURRENT_SKIPLISTMAP_ENTRY - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
-
Overhead for ConcurrentSkipListMap Entry
- Condition - Class in org.apache.accumulo.core.data
-
Conditions that must be met on a particular column in a row.
- Condition(CharSequence, CharSequence) - Constructor for class org.apache.accumulo.core.data.Condition
-
- Condition(byte[], byte[]) - Constructor for class org.apache.accumulo.core.data.Condition
-
- Condition(Text, Text) - Constructor for class org.apache.accumulo.core.data.Condition
-
- Condition(ByteSequence, ByteSequence) - Constructor for class org.apache.accumulo.core.data.Condition
-
- ConditionalMutation - Class in org.apache.accumulo.core.data
-
A Mutation that contains a list of conditions that must all be met before the mutation is applied.
- ConditionalMutation(byte[], Condition...) - Constructor for class org.apache.accumulo.core.data.ConditionalMutation
-
- ConditionalMutation(byte[], int, int, Condition...) - Constructor for class org.apache.accumulo.core.data.ConditionalMutation
-
- ConditionalMutation(Text, 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
-
- conditionalUpdate(TInfo, long, Map<TKeyExtent, List<TConditionalMutation>>, List<String>, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
-
- conditionalUpdate(TInfo, long, Map<TKeyExtent, List<TConditionalMutation>>, List<String>, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
-
- conditionalUpdate(TInfo, long, Map<TKeyExtent, List<TConditionalMutation>>, List<String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
-
- conditionalUpdate(TInfo, long, Map<TKeyExtent, List<TConditionalMutation>>, List<String>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
-
- 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.Result(ConditionalWriter.Status, ConditionalMutation, String) - Constructor for class org.apache.accumulo.core.client.ConditionalWriter.Result
-
- ConditionalWriter.Result(Exception, ConditionalMutation, String) - Constructor for class org.apache.accumulo.core.client.ConditionalWriter.Result
-
- ConditionalWriter.Status - Enum in org.apache.accumulo.core.client
-
- ConditionalWriterConfig - Class in org.apache.accumulo.core.client
-
- ConditionalWriterConfig() - Constructor for class org.apache.accumulo.core.client.ConditionalWriterConfig
-
- conditions - Variable in class org.apache.accumulo.core.data.thrift.TConditionalMutation
-
- conf - Static variable in enum org.apache.accumulo.core.file.rfile.bcfile.Compression.Algorithm
-
- CONF_LZO_CLASS - Static variable in enum org.apache.accumulo.core.file.rfile.bcfile.Compression.Algorithm
-
- CONF_SNAPPY_CLASS - Static variable in enum org.apache.accumulo.core.file.rfile.bcfile.Compression.Algorithm
-
- config(String...) - Method in class org.apache.accumulo.core.client.mock.MockShell
-
- config(String...) - Method in class org.apache.accumulo.core.util.shell.Shell
-
Configures the shell using the provided options.
- ConfigCommand - Class in org.apache.accumulo.core.util.shell.commands
-
- ConfigCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.ConfigCommand
-
- ConfigSanityCheck - Class in org.apache.accumulo.core.conf
-
A utility class for checking over configuration entries.
- ConfigSanityCheck() - Constructor for class org.apache.accumulo.core.conf.ConfigSanityCheck
-
- ConfigSanityCheck.SanityCheckException - Exception in org.apache.accumulo.core.conf
-
- ConfigSanityCheck.SanityCheckException(String) - Constructor for exception org.apache.accumulo.core.conf.ConfigSanityCheck.SanityCheckException
-
Creates a new exception with the given message.
- ConfigurationCopy - Class in org.apache.accumulo.core.conf
-
- ConfigurationCopy(Map<String, String>) - Constructor for class org.apache.accumulo.core.conf.ConfigurationCopy
-
- ConfigurationCopy(Iterable<Map.Entry<String, String>>) - Constructor for class org.apache.accumulo.core.conf.ConfigurationCopy
-
- ConfigurationCopy() - Constructor for class org.apache.accumulo.core.conf.ConfigurationCopy
-
- ConfigurationObserver - Interface in org.apache.accumulo.core.conf
-
- ConfigurationType - Enum in org.apache.accumulo.core.client.impl.thrift
-
- ConfiguratorBase - Class in org.apache.accumulo.core.client.mapreduce.lib.impl
-
- ConfiguratorBase() - Constructor for class org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase
-
- ConfiguratorBase - Class in org.apache.accumulo.core.client.mapreduce.lib.util
-
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
- ConfiguratorBase() - Constructor for class org.apache.accumulo.core.client.mapreduce.lib.util.ConfiguratorBase
-
Deprecated.
- ConfiguratorBase.ConnectorInfo - Enum in org.apache.accumulo.core.client.mapreduce.lib.impl
-
- ConfiguratorBase.ConnectorInfo - Enum in org.apache.accumulo.core.client.mapreduce.lib.util
-
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
- ConfiguratorBase.GeneralOpts - Enum in org.apache.accumulo.core.client.mapreduce.lib.impl
-
Configuration keys for general configuration options.
- ConfiguratorBase.GeneralOpts - Enum in org.apache.accumulo.core.client.mapreduce.lib.util
-
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
- ConfiguratorBase.InstanceOpts - Enum in org.apache.accumulo.core.client.mapreduce.lib.impl
-
- ConfiguratorBase.InstanceOpts - Enum in org.apache.accumulo.core.client.mapreduce.lib.util
-
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
- ConfiguratorBase.TokenSource - Enum in org.apache.accumulo.core.client.mapreduce.lib.impl
-
- Connector - Class in org.apache.accumulo.core.client
-
Connector connects to an Accumulo instance and allows the user to request readers and writers for the instance as well as various objects that permit
administrative operations.
- Connector() - Constructor for class org.apache.accumulo.core.client.Connector
-
- ConnectorImpl - Class in org.apache.accumulo.core.client.impl
-
- ConnectorImpl(Instance, Credentials) - Constructor for class org.apache.accumulo.core.client.impl.ConnectorImpl
-
- Constants - Class in org.apache.accumulo.core
-
- Constants() - Constructor for class org.apache.accumulo.core.Constants
-
- constrainClass - Variable in class org.apache.accumulo.core.data.ConstraintViolationSummary
-
- constrainClass - Variable in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
-
- Constraint - Interface in org.apache.accumulo.core.constraints
-
Accumulo uses Constraint objects to determine if mutations will be applied to a table.
- Constraint.Environment - Interface in org.apache.accumulo.core.constraints
-
- ConstraintCommand - Class in org.apache.accumulo.core.util.shell.commands
-
- ConstraintCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.ConstraintCommand
-
- ConstraintViolationException - Exception in org.apache.accumulo.core.tabletserver.thrift
-
- ConstraintViolationException() - Constructor for exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
-
- ConstraintViolationException(List<TConstraintViolationSummary>) - Constructor for exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
-
- ConstraintViolationException(ConstraintViolationException) - Constructor for exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
-
Performs a deep copy on other.
- ConstraintViolationException._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ConstraintViolationSummary - Class in org.apache.accumulo.core.data
-
- ConstraintViolationSummary(String, short, String, long) - Constructor for class org.apache.accumulo.core.data.ConstraintViolationSummary
-
- ConstraintViolationSummary(TConstraintViolationSummary) - Constructor for class org.apache.accumulo.core.data.ConstraintViolationSummary
-
- consume() - Method in class org.apache.accumulo.core.iterators.FirstEntryInRowIterator
-
- consume() - Method in class org.apache.accumulo.core.iterators.SkippingIterator
-
- consume() - Method in class org.apache.accumulo.core.iterators.system.ColumnFamilySkippingIterator
-
- contains(ByteSequence) - Method in class org.apache.accumulo.core.data.KeyExtent
-
- contains(BinaryComparable) - Method in class org.apache.accumulo.core.data.KeyExtent
-
- contains(Key) - Method in class org.apache.accumulo.core.data.Range
-
- contains(Key) - Method in class org.apache.accumulo.core.iterators.conf.ColumnSet
-
- contains(ByteSequence) - Method in interface org.apache.accumulo.core.security.AuthorizationContainer
-
Checks whether this object contains the given authorization.
- contains(byte[]) - Method in class org.apache.accumulo.core.security.Authorizations
-
Checks whether this object contains the given authorization.
- contains(ByteSequence) - Method in class org.apache.accumulo.core.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(KT) - Method in class org.apache.accumulo.core.util.MapCounter
-
- containsCommand(String) - Method in class org.apache.accumulo.core.util.shell.Token
-
- containsKey(Object) - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
-
- containsValue(Object) - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
-
- continueMultiScan(TInfo, long, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
-
- continueMultiScan(TInfo, long, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
-
- continueMultiScan(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
-
- continueMultiScan(TInfo, long) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
-
- continueScan(TInfo, long, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
-
- continueScan(TInfo, long, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
-
- continueScan(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
-
- continueScan(TInfo, long) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
-
- convert(String) - Method in class org.apache.accumulo.core.cli.ClientOpts.AuthConverter
-
- convert(String) - Method in class org.apache.accumulo.core.cli.ClientOpts.MemoryConverter
-
- convert(String) - Method in class org.apache.accumulo.core.cli.ClientOpts.PasswordConverter
-
- convert(String) - Method in class org.apache.accumulo.core.cli.ClientOpts.TimeConverter
-
- convert(String) - Method in class org.apache.accumulo.core.cli.ClientOpts.VisibilityConverter
-
- convert(String) - Method in class org.apache.accumulo.core.util.shell.ShellOptionsJC.PasswordConverter
-
- convert(String) - Method in class org.apache.accumulo.core.util.shell.ShellOptionsJC.TokenConverter
-
- convertClientConfig(AccumuloConfiguration, Configuration) - Static method in class org.apache.accumulo.core.client.impl.ServerConfigurationUtil
-
- copy(byte[]) - Method in class org.apache.accumulo.core.data.Value
-
- COPYONWRITE_ARRAYLIST - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
-
Overhead for CopyOnWriteArrayList
- COPYONWRITE_ARRAYSET - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
-
Overhead for CopyOnWriteArraySet
- copyPartialKey(Key, PartialKey) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
-
Creates a copy of key
, copying only the parts of the key specified in part
.
- CORE_PACKAGE_NAME - Static variable in class org.apache.accumulo.core.Constants
-
- count - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
-
- CountingIterator - Class in org.apache.accumulo.core.iterators.system
-
- CountingIterator(SortedKeyValueIterator<Key, Value>) - Constructor for class org.apache.accumulo.core.iterators.system.CountingIterator
-
- cq - Variable in class org.apache.accumulo.core.data.thrift.TCondition
-
- 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, boolean) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
- create(String, boolean, TimeType) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
- create(String) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsImpl
-
- create(String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
-
Create a table with no special configuration
- create(String, boolean) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
-
- create(String, boolean, TimeType) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
-
- create(HostAndPort, long) - Static method in class org.apache.accumulo.core.util.TTimeoutTransport
-
- create(SocketAddress, long) - Static method in class org.apache.accumulo.core.util.TTimeoutTransport
-
- create(T, AccumuloConfiguration) - Static method in class org.apache.accumulo.core.volume.VolumeConfiguration
-
Create a Volume with the given FileSystem that writes to the default path
- create(T, String) - Static method in class org.apache.accumulo.core.volume.VolumeConfiguration
-
- create(String, Configuration) - Static method in class org.apache.accumulo.core.volume.VolumeConfiguration
-
- create(Path, Configuration) - Static method in class org.apache.accumulo.core.volume.VolumeConfiguration
-
- createBatchDeleter(String, Authorizations, int, long, long, int) - Method in class org.apache.accumulo.core.client.Connector
-
- createBatchDeleter(String, Authorizations, int, BatchWriterConfig) - Method in class org.apache.accumulo.core.client.Connector
-
- createBatchDeleter(String, Authorizations, int, long, long, int) - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
-
Deprecated.
- createBatchDeleter(String, Authorizations, int, BatchWriterConfig) - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
-
- createBatchDeleter(String, Authorizations, int, long, long, int) - Method in class org.apache.accumulo.core.client.mock.MockConnector
-
Deprecated.
- createBatchDeleter(String, Authorizations, int, BatchWriterConfig) - Method in class org.apache.accumulo.core.client.mock.MockConnector
-
- createBatchScanner(String, Authorizations, int) - Method in class org.apache.accumulo.core.client.Connector
-
Factory method to create a BatchScanner connected to Accumulo.
- createBatchScanner(String, Authorizations, int) - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
-
- createBatchScanner(String, Authorizations) - Method in class org.apache.accumulo.core.client.mock.MockAccumulo
-
- createBatchScanner(String, Authorizations, int) - Method in class org.apache.accumulo.core.client.mock.MockConnector
-
- createBatchWriter(String, long, long, int) - Method in class org.apache.accumulo.core.client.Connector
-
- createBatchWriter(String, BatchWriterConfig) - Method in class org.apache.accumulo.core.client.Connector
-
Factory method to create a BatchWriter connected to Accumulo.
- createBatchWriter(String, long, long, int) - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
-
Deprecated.
- createBatchWriter(String, BatchWriterConfig) - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
-
- createBatchWriter(String, long, long, int) - Method in class org.apache.accumulo.core.client.mock.MockConnector
-
Deprecated.
- createBatchWriter(String, BatchWriterConfig) - Method in class org.apache.accumulo.core.client.mock.MockConnector
-
- createClient(TServiceClientFactory<T>, TTransport) - Static method in class org.apache.accumulo.core.util.ThriftUtil
-
- createClientTransport(HostAndPort, int, SslConnectionParams) - Static method in class org.apache.accumulo.core.util.ThriftUtil
-
- createCompressionStream(OutputStream, Compressor, int) - Method in enum org.apache.accumulo.core.file.rfile.bcfile.Compression.Algorithm
-
- createConditionalWriter(String, ConditionalWriterConfig) - Method in class org.apache.accumulo.core.client.Connector
-
Factory method to create a ConditionalWriter connected to Accumulo.
- createConditionalWriter(String, ConditionalWriterConfig) - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
-
- createConditionalWriter(String, ConditionalWriterConfig) - Method in class org.apache.accumulo.core.client.mock.MockConnector
-
- createDecompressionStream(InputStream, Decompressor, int) - Method in enum org.apache.accumulo.core.file.rfile.bcfile.Compression.Algorithm
-
- 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.IsSupportedCompressionAlgorithm() - Constructor for class org.apache.accumulo.core.file.rfile.CreateEmpty.IsSupportedCompressionAlgorithm
-
- CreateEmpty.NamedLikeRFile - Class in org.apache.accumulo.core.file.rfile
-
- CreateEmpty.NamedLikeRFile() - Constructor for class org.apache.accumulo.core.file.rfile.CreateEmpty.NamedLikeRFile
-
- createEntry(Configuration, String, char[]) - Static method in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
-
Create a CredentialEntry using the configured Providers.
- createEntryInProvider(Object, String, char[]) - Static method in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
-
Create a CredentialEntry with the give name and credential in the credentialProvider.
- createFilter(SortedKeyValueIterator<Key, Value>) - Method in class org.apache.accumulo.core.client.mock.MockScannerBase
-
- createHeap(int) - Method in class org.apache.accumulo.core.iterators.system.HeapIterator
-
- createInstanceFromPropertyName(AccumuloConfiguration, Property, Class<T>, T) - Static method in enum org.apache.accumulo.core.conf.Property
-
- createLocalUser(String, PasswordToken) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
-
Create a user
- createLocalUser(String, PasswordToken) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
-
- createLocalUser(TInfo, TCredentials, String, ByteBuffer, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
-
- createLocalUser(TInfo, TCredentials, String, ByteBuffer, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
-
- createLocalUser(TInfo, TCredentials, String, ByteBuffer) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
-
- createLocalUser(TInfo, TCredentials, String, ByteBuffer) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
-
- createMetadataScanner(Instance, Credentials, String, Range) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
-
Create an IsolatedScanner over the given table, fetching the columns necessary to determine when a table has transitioned to online or offline.
- createMetaStore(String) - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Writer
-
- createMetaStore(String) - Method in interface org.apache.accumulo.core.file.FileSKVWriter
-
- createMetaStore(String) - Method in class org.apache.accumulo.core.file.rfile.RFile.Writer
-
- createMultiTableBatchWriter(long, long, int) - Method in class org.apache.accumulo.core.client.Connector
-
- createMultiTableBatchWriter(BatchWriterConfig) - Method in class org.apache.accumulo.core.client.Connector
-
Factory method to create a Multi-Table BatchWriter connected to Accumulo.
- createMultiTableBatchWriter(long, long, int) - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
-
Deprecated.
- createMultiTableBatchWriter(BatchWriterConfig) - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
-
- createMultiTableBatchWriter(long, long, int) - Method in class org.apache.accumulo.core.client.mock.MockConnector
-
Deprecated.
- createMultiTableBatchWriter(BatchWriterConfig) - Method in class org.apache.accumulo.core.client.mock.MockConnector
-
- createNamespace(String, String) - Method in class org.apache.accumulo.core.client.mock.MockAccumulo
-
- CreateNamespaceCommand - Class in org.apache.accumulo.core.util.shell.commands
-
- CreateNamespaceCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.CreateNamespaceCommand
-
- createParamsObjectFromAccumuloConfiguration(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.security.crypto.CryptoModuleFactory
-
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
-
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloMultiTableInputFormat
-
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloRowInputFormat
-
- createScanner(String, Authorizations) - Method in class org.apache.accumulo.core.client.Connector
-
Factory method to create a Scanner connected to Accumulo.
- createScanner(String, Authorizations) - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
-
- createScanner(String, Authorizations) - Method in class org.apache.accumulo.core.client.mock.MockConnector
-
- createTable(String, String, boolean, TimeType) - Method in class org.apache.accumulo.core.client.mock.MockAccumulo
-
- CreateTableCommand - Class in org.apache.accumulo.core.util.shell.commands
-
- CreateTableCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.CreateTableCommand
-
- createTableInstanceFromPropertyName(AccumuloConfiguration, Property, Class<T>, T) - Static method in enum org.apache.accumulo.core.conf.Property
-
- CreateToken - Class in org.apache.accumulo.core.util
-
- CreateToken() - Constructor for class org.apache.accumulo.core.util.CreateToken
-
- createTransport(HostAndPort, AccumuloConfiguration) - Static method in class org.apache.accumulo.core.util.ThriftUtil
-
create a transport that is not pooled
- createUser(String, byte[], Authorizations) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
-
- createUser(String, byte[], Authorizations) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
-
Deprecated.
- CreateUserCommand - Class in org.apache.accumulo.core.util.shell.commands
-
- CreateUserCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.CreateUserCommand
-
- CREDENTIAL_PROVIDER_PATH - Static variable in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
-
- CREDENTIAL_PROVIDERS_PROPERTY - Static variable in class org.apache.accumulo.core.client.security.tokens.CredentialProviderToken
-
- CredentialProviderFactoryShim - Class in org.apache.accumulo.core.conf
-
Shim around Hadoop: tries to use the CredentialProviderFactory provided by hadoop-common, falling back to a copy inside accumulo-core.
- CredentialProviderFactoryShim() - Constructor for class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
-
- CredentialProviderToken - Class in org.apache.accumulo.core.client.security.tokens
-
- CredentialProviderToken() - Constructor for class org.apache.accumulo.core.client.security.tokens.CredentialProviderToken
-
- CredentialProviderToken(String, String) - Constructor for class org.apache.accumulo.core.client.security.tokens.CredentialProviderToken
-
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
-
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
-
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
-
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
-
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
-
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
-
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
-
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
-
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
-
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
-
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
-
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
-
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
-
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
-
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
-
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
-
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
-
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
-
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
-
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
-
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
-
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
-
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
-
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
-
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
-
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
-
- credentials - Variable in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
-
- credentials - Variable in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
-
- credentials - Variable in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
-
- credentials - Variable in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
-
- credentials - Variable in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
-
- credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
-
- credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
-
- credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
-
- credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
-
- credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
-
- credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
-
- credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
-
- credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
-
- credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
-
- credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
-
- credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
-
- credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
-
- credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
-
- credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
-
- Credentials - Class in org.apache.accumulo.core.security
-
A wrapper for internal use.
- Credentials(String, AuthenticationToken) - Constructor for class org.apache.accumulo.core.security.Credentials
-
Creates a new credentials object.
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
-
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
-
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
-
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
-
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
-
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
-
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
-
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
-
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
-
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
-
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
-
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
-
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
-
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
-
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
-
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
-
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
-
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
-
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
-
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
-
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
-
- CryptoModule - Interface in org.apache.accumulo.core.security.crypto
-
Classes that obey this interface may be used to provide encrypting and decrypting streams to the rest of Accumulo.
- CryptoModuleFactory - Class in org.apache.accumulo.core.security.crypto
-
This factory module exists to assist other classes in loading crypto modules.
- CryptoModuleFactory() - Constructor for class org.apache.accumulo.core.security.crypto.CryptoModuleFactory
-
- CryptoModuleParameters - Class in org.apache.accumulo.core.security.crypto
-
This class defines several parameters needed by by a module providing cryptographic stream support in Accumulo.
- CryptoModuleParameters() - Constructor for class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
-
- CT - Static variable in class org.apache.accumulo.core.client.impl.Translators
-
- current - Variable in class org.apache.accumulo.core.gc.thrift.GCStatus
-
- currentDocID - Variable in class org.apache.accumulo.core.iterators.user.IntersectingIterator
-
- currentK - Variable in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
-
The Key that should be returned to the client
- currentKey - Variable in class org.apache.accumulo.core.client.mapred.AbstractInputFormat.AbstractRecordReader
-
- currentKey - Variable in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
-
The Key that is used to determine progress in the current InputSplit.
- currentLog - Variable in class org.apache.accumulo.core.gc.thrift.GCStatus
-
- currentPartition - Variable in class org.apache.accumulo.core.iterators.user.IntersectingIterator
-
- currentV - Variable in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
-
The Value that should be return to the client
- cv - Variable in class org.apache.accumulo.core.data.thrift.TCondition
-
- cve - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
-
- CVST - Static variable in class org.apache.accumulo.core.client.impl.Translators
-