All Classes and Interfaces

Class
Description
AbstractEncoder is an Encoder that implements all of Encoder's methods validating the input, but has those methods defer logic to a new method, AbstractEncoder.decodeUnchecked(byte[], int, int).
A base class that can be used to create Samplers based on hashing.
An abstract identifier class for comparing equality of identifiers of the same type.
Deprecated.
since 2.0.0; Use org.apache.accumulo.hadoop.mapred instead from the accumulo-hadoop-mapreduce.jar
Deprecated.
since 2.0.0; Use org.apache.accumulo.hadoop.mapreduce instead from the accumulo-hadoop-mapreduce.jar
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.
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.
 
An exception for FATE operations to use to denote when an Exception is acceptable and should not trigger warning messages.
Concrete implementation of AcceptableException for table operations.
This class contains all API entry points created in 2.0.0 or later.
Internal class indicating a concurrent merge occurred during the new bulk import.
Client connection to an Accumulo instance.
Builder methods for authentication
Builds AccumuloClient or client Properties after all options have been specified
Build methods for connection options
 
Builder method for setting Accumulo instance and zookeepers
Builder methods for creating AccumuloClient using properties
Build methods for SASL
Build methods for SSL/TLS
A configuration object.
Automatically regenerates an object whenever configuration changes.
A generic Accumulo Exception for general accumulo failures.
Deprecated.
since 2.0.0; Use org.apache.accumulo.hadoop.mapred instead from the accumulo-hadoop-mapreduce.jar
Deprecated.
since 2.0.0; Use org.apache.accumulo.hadoop.mapreduce instead from the accumulo-hadoop-mapreduce.jar
Deprecated.
since 2.0.0; Use org.apache.accumulo.hadoop.mapred instead from the accumulo-hadoop-mapreduce.jar
Deprecated.
since 2.0.0; Use org.apache.accumulo.hadoop.mapreduce instead from the accumulo-hadoop-mapreduce.jar
Deprecated.
since 2.0.0; Use org.apache.accumulo.hadoop.mapred instead from the accumulo-hadoop-mapreduce.jar
Deprecated.
since 2.0.0; Use org.apache.accumulo.hadoop.mapreduce instead from the accumulo-hadoop-mapreduce.jar
Deprecated.
since 2.0.0; Use org.apache.accumulo.hadoop.mapred instead from the accumulo-hadoop-mapreduce.jar
Deprecated.
since 2.0.0; Use org.apache.accumulo.hadoop.mapreduce instead from the accumulo-hadoop-mapreduce.jar
A base class to be used to create RecordWriter instances that write to Accumulo.
A base class to be used to create RecordWriter instances that write to Accumulo.
Deprecated.
Deprecated.
since 2.0.0; Use org.apache.accumulo.hadoop.mapred instead from the accumulo-hadoop-mapreduce.jar
Deprecated.
since 2.0.0; Use org.apache.accumulo.hadoop.mapreduce instead from the accumulo-hadoop-mapreduce.jar
An Accumulo Exception for security violations, authentication failures, authorization failures, etc.
This class is intended to encapsulate errors that occurred on the server side.
This is a workaround for the issue reported in https://issues.apache.org/jira/browse/THRIFT-5732 and can be removed once that issue is fixed.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
 
 
 
A class that contains information about an ActiveScan
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
A class that contains information about an ActiveScan
 
A utility to administer FATE operations
 
FATE transaction status, including lock information.
Example implementation of AES encryption for Accumulo
A filter that ages off key/value pairs based on the Key's timestamp.
This store removes Repos, in the store it wraps, that are in a finished or new state for more than a configurable time period.
 
Formatter that will aggregate entries for various display purposes.
Accumulo Metadata Persistence Layer.
Accumulo is a distributed tree with three levels.
Enables status based processing of GcCandidates.
Controls how Accumulo metadata is read.
Interface for changing a tablets persistent data.
This interface allows efficiently updating multiple tablets.
 
An implementation of ByteSequence that uses a backing byte array.
 
 
A utility class to serialize/deserialize AuthenticationToken objects.
Unfortunately, these methods are provided in an inner-class, to avoid breaking the interface API.
 
 
Implementation that identifies the underlying Token for Accumulo.
An interface for classes that contain a collection of authorizations.
A collection of authorization strings.
Counts unique authorizations in column visibility labels.
 
 
This interface is an extension of ServiceEnvironment that exposes system level information that is specific to tablet balancing.
 
Implementations of BatchDeleter support efficient deletion of ranges in accumulo.
Deprecated.
since 2.0.0
Deprecated.
since 2.0.0
In exchange for possibly returning scanned entries out of order, BatchScanner implementations may scan an Accumulo table more efficiently by Looking up multiple ranges in parallel.
Send Mutations to a single Table in Accumulo.
This object holds configuration settings used to instantiate a BatchWriter
 
Block Compressed file, the underlying physical storage layer for TFile.
BCFile Reader, interface to read the file's data and meta blocks.
Access point to read a block.
BCFile writer, the entry point for creating a new BCFile.
A family of combiners that treat values as BigDecimals, encoding and decoding using the built-in BigDecimal String input/output functions.
Provides the ability to encode scientific notation.
 
 
 
A lexicoder to encode/decode a BigInteger to/from bytes that maintain its native Java sort order.
Deprecated.
since 1.8.0; Use DefaultFormatter providing showLength and printTimestamps via FormatterConfig.
Block cache interface.
 
Cache statistics.
 
 
 
 
Reader corresponding to BlockedOutputStream.
Buffers all input in a growing buffer until flush() is called.
 
 
Implements a Bloom filter, as defined by Bloom in 1970.
A class that sits on top of different accumulo file formats and provides bloom filter functionality.
 
 
BoundedRangeFIleInputStream abstracts a contiguous region of a Hadoop FSDataInputStream as a regular input stream.
 
WARNING : do not change this class, its used for serialization to Json
 
WARNING : do not change this class, its used for serialization to Json
WARNING : do not change this class, its used for serialization to Json
 
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Place for all bulk import serialization code.
 
 
 
 
 
A sequence of bytes.
For each of the methods, this lexicoder just passes the input through untouched.
 
 
This is a wrapper class for BCFile that includes a cache for independent caches for datablocks and metadatablocks
 
 
Class wraps the BCFile reader.
Represents an entry in the configurable block cache.
 
A memory-bound queue that will grow until an element brings total size >= maxSize.
 
 
 
 
A simple future wrapper that will set an atomic boolean to true if a future is successfully canceled
Filters key/value pairs for a range of column families and a range of column qualifiers.
 
Filters key/value pairs for a range of column families and a range of column qualifiers.
 
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
This class collects all the cleaner actions executed in various parts of the code.
Deprecated.
since 2.0.0 Use only AccumuloClient instead.
 
Generates client-properties.md for documentation on Accumulo website and accumulo-client.properties for Accumulo distribution tarball
Deprecated.
since 2.0.0, replaced by Accumulo.newClient()
 
This class represents any essential configuration and credentials needed to initiate RPC operations throughout the code.
 
Accumulo client information.
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
A scanner that instantiates iterators on the client side instead of on the tablet server.
A configuration object that can be used with the table clone command in the TableOperations.
A CloneConfiguration builder
A CloneConfiguration implementation which also implements the builder thereof
 
A column, specified by family, qualifier, and visibility.
A filter that ages off key/value pairs based on the Key's column and timestamp.
 
 
 
 
 
 
 
 
 
 
A single column and value pair within a Mutation.
 
 
 
Validate the column visibility is a valid expression and set the visibility for a Mutation.
A node in the parse tree for a visibility expression.
A node comparator.
The node types in a parse tree for a visibility expression.
A SortedKeyValueIterator that combines the Values for different versions (timestamp) of a Key within a row into a single Value.
A Java Iterator that iterates over the Values for a given Key from a source SortedKeyValueIterator.
A single file ready to compact, that will come in a set of possible candidates.
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
This class exist to pass parameters to TableOperations.compact(String, CompactionConfig)
Enables dynamically overriding of per table properties used to create the output file for a compaction.
 
 
Specifies how the output file should be created for a compaction.
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
 
 
 
 
 
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The dispatch of a CompactionDispatcher
 
Required service parameter for CompactionDispatch
Can be configured per table to dispatch compactions to different compaction services.
A unique identifier for a a compaction executor that a CompactionPlanner can schedule compactions on using a CompactionJob.
 
An immutable object that describes what files to compact and where to compact them.
An immutable object that describes what files to compact and where to compact them.
 
 
 
 
 
Plans compaction work for a compaction service.
This interface exists so the API can evolve and additional parameters can be passed to the method in the future.
This interface exists so the API can evolve and additional parameters can be passed to the method in the future.
 
This class selects which files a user compaction will compact.
 
 
 
A unique identifier for a compaction service
Provider of information about configured compaction services.
This class serves to configure compaction services from an AccumuloConfiguration object.
 
Deprecated, for removal: This API element is subject to removal in a future version.
since 2.1.0 CompactionStrategies were deprecated for multiple reasons.
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
 
 
 
 
 
An array of bytes wrapped so as to extend Hadoop's BinaryComparable class.
 
 
 
 
Compression related stuff.
There is a static initializer in Compression that finds all implementations of CompressionAlgorithmConfiguration and initializes a CompressionAlgorithm instance.
 
 
A compaction configurer that can adjust the compression configuration for a compaction when the sum of the input file sizes exceeds a threshold.
Conditions that must be met on a particular column in a row.
Logger that wraps another Logger and only emits a log message once per the supplied duration.
A Logger implementation that will suppress duplicate messages within the supplied duration.
A Logger implementation that will log a message at the supplied elevated level if it has not been seen in the supplied duration.
A Mutation that contains a list of conditions that must all be met before the mutation is applied.
ConditionalWriter provides the ability to do efficient, atomic read-modify-write operations on rows.
 
 
 
 
A utility class for validating AccumuloConfiguration instances.
The exception thrown when ConfigCheckUtil.validate(Iterable, String) fails.
 
 
Extension of the ConfigurableScanServerSelector that can be used when there are multiple ScanServers running on the same host and for some reason, like using a shared off-heap cache, sending scans for the same tablet to the same host may provide a better experience.
The default Accumulo selector for scan servers.
 
An AccumuloConfiguration which holds a flat copy of properties defined in another configuration
This class generates documentation to inform users of the available configuration properties in a presentable form.
The implementation class used for providing SPI configuration without exposing internal types.
 
 
 
Specifies that connection info was configured
Configuration keys for general configuration options.
Configuration keys for available Instance types.
 
Deprecated.
since 2.0.0.
Deprecated.
 
Deprecated.
since 2.1.0 Use Constraint
Constraint objects are used to determine if mutations will be applied to a table.
The environment within which a constraint exists.
The environment within which a constraint exists.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
A summary of constraint violations across some number of mutations.
The environment provided to the context class loader factory for its use
The ContextClassLoaderFactory provides a mechanism for various Accumulo components to use a custom ClassLoader for specific contexts, such as loading table iterators.
This a convenience class for interpreting summary data generated by implementations of CountingSummarizer
 
This class counts arbitrary keys while defending against too many keys and keys that are too long.
A function that converts key values to zero or more counter objects.
Create an empty RFile for use in recovering from data loss where Accumulo still refers internally to a path.
 
 
 
An AuthenticationToken backed by a Hadoop CredentialProvider.
A wrapper for internal use.
Useful information provided to the crypto implementation
Where in Accumulo the on-disk file encryption takes place.
 
 
A self-contained cryptographic service.
Runtime Crypto exception
A Factory that returns a CryptoService based on the environment and configuration.
 
 
 
DateFormatSupplier is a ThreadLocal<DateFormat> that will set the correct TimeZone when the object is retrieved by DateFormatSupplier.get().
A lexicoder for date objects.
Deprecated.
since 1.8.0
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
Finds the largest continuous set of small files that meet the compaction ratio and do not prevent future compactions.
An AccumuloConfiguration that contains only default values for properties.
The default implementation of ContextClassLoaderFactory.
 
Deprecated.
since 2.1.0 Use DefaultKeySizeConstraint
A constraints that limits the size of keys to 1mb.
Deprecated.
since 2.1.0 This will be removed in a future version in favor of JShell
A VolumeChooser that delegates to another volume chooser based on other properties: table.custom.volume.chooser for tables, and general.custom.volume.chooser.scoped for scopes.
An AuthenticationToken that wraps a "Hadoop style" delegation token created by Accumulo.
Configuration options for obtaining a delegation token created by SecurityOperations.getDelegationToken(DelegationTokenConfig)
Handles serialization of DelegationTokenConfig
 
Deprecated.
since 2.0.0
This summarizer tracks the total number of delete Keys seen and the total number of keys seen.
 
 
 
 
An iterator that is useful testing...
 
 
 
A ReadWriteLock that can be implemented in ZooKeeper.
 
A lexicoder for preserving the native Java sort order of Double values.
The value for the durability of a BatchWriter or ConditionalWriter.
 
 
Implements a dynamic Bloom filter, as defined in the INFOCOM 2006 paper.
 
An encoder represents a typed object that can be encoded/decoded to/from a byte array.
 
Summarizer that computes summary information about field lengths.
Offered to a Compaction Planner at initialization time so it can create executors.
 
 
 
 
 
Counts column column families.
 
Fault tolerant executor
 
A persistent lock mechanism in ZooKeeper used for locking tables during FaTE operations.
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
 
 
 
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
Class implementation that will decrypt a file.
Class implementation that will encrypt a file.
 
Helper class extended by both writers and readers.
 
 
 
 
 
 
Configuration keys for AccumuloConfiguration.
 
 
Defines the general behavior of a filter.
A SortedKeyValueIterator that filters entries from its source iterator.
 
Transport that simply wraps another transport.
 
 
Uses a fixed length array and will not grow in size dynamically like the ByteArrayOutputStream.
A lexicoder for preserving the native Java sort order of Float values.
 
Holds configuration settings for a Formatter
Formats with milliseconds since epoch
 
This class implements using multiple tservers to gather summaries.
 
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
 
 
 
 
 
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
Factory that will load a crypto service configured, first checking GenericCryptoServiceFactory.GENERAL_SERVICE_NAME_PROP and then GenericCryptoServiceFactory.TABLE_SERVICE_NAME_PROP.
This iterator provides exact string matching of the term specified by the "term" option.
A balancer that evenly spreads groups of tablets across all tablet server.
Rate limiter from the Guava library.
 
Shim around Hadoop's CredentialProviderFactory provided by hadoop-common.
 
Constructs a PriorityQueue of multiple SortedKeyValueIterators.
Implementations can be asked for an estimate of their size in bytes.
 
 
Deprecated.
Deprecated.
When configured for a scan executor, this prioritizer allows scanners to set priorities as integers.
This class was copied from Guava release 23.0 to replace the older Guava 14 version that had been used in Accumulo.
This balancer creates groups of tablet servers using user-provided regular expressions over the tablet server hostnames.
 
 
 
 
 
Prioritize scans based on the ratio of runTime/idleTime.
A configuration object that can be used with TableOperations.importTable(String, Set, ImportConfiguration)
A ImportConfiguration builder
 
This iterator facilitates document-partitioned indexing.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Creation mode for table creation.
 
Configuration keys for various features.
Configuration keys for Scanner.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Deprecated.
since 2.0.0; Use org.apache.accumulo.hadoop.mapred instead from the accumulo-hadoop-mapreduce.jar
Deprecated.
since 2.0.0; Use org.apache.accumulo.hadoop.mapreduce instead from the accumulo-hadoop-mapreduce.jar
 
 
Deprecated.
since 2.0.0; Use org.apache.accumulo.hadoop.mapreduce instead from the accumulo-hadoop-mapreduce.jar
Deprecated.
since 2.0.0, use Accumulo.newClient() and Properties instead
A strongly typed representation of an Accumulo instance ID.
 
Provides a class for administering the accumulo instance
A lexicoder for signed integers.
A utility that mimics String.intern() for any immutable object type (including String).
Allows an iterator to be interrupted.
This iterator facilitates document-partitioned indexing.
 
A scanner that presents a row isolated view of an accumulo table.
 
 
 
 
 
Exception thrown if an interrupt flag is detected.
 
Builder class for setting up the iterator stack.
 
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Provides information about a configured Accumulo Iterator
Utility class for configuring iterators.
 
Configure an iterator for minc, majc, and/or scan.
A convenience class for passing column family and column qualifiers to iterator configuration methods.
Utility class for Iterators.
Even though this type is not in a public API package, its used by methods in the public API.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Authentication token for Kerberos authenticated clients
This is the Key used to store and access individual values in Accumulo.
A builder used to build Keys by defining their components.
Base Builder interface which can be used to set the Key timestamp and delete marker and to build the Key.
Builder step used to set the columnFamily part of the Key.
Builder step used to set the column qualifier part of the Key.
Builder step used to set the column visibility part of the Key.
Builder step used to set the row part of the Key.
keeps track of information needed to identify a tablet
 
Deprecated.
since 2.0.0; Use org.apache.accumulo.hadoop.mapreduce.partition instead from the accumulo-hadoop-mapreduce.jar
Code to shorten keys that will be placed into RFile indexes.
A key/value pair.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
This iterator suppresses rows that exceed a specified number of columns.
A lexicoder provides methods to convert to/from byte arrays.
Tablets for a table in the metadata table should form a linked list.
A lexicoder to encode/decode a Java List to/from a byte array where the concatenation of each encoded element sorts lexicographically.
Iterator for reading the Bulk Load Mapping JSON.
Information about where to load files into an Accumulo table.
 
Mapping of a file to a row range with an associated range type.
 
 
 
 
This will cache the arguments used in the seek call along with the locality groups seeked.
 
 
 
 
A snapshot of metadata information about where a specified set of ranges are located returned by TableOperations.locate(String, java.util.Collection)
 
 
Example implementation of enabling a metrics provider by implementing the MeterRegistryFactory interface.
A TypedValueCombiner that translates each Value to a Long before reducing, then encodes the reduced Long back to a Value.
An Encoder that uses an 8-byte encoding for Longs.
An Encoder that uses a String representation of Longs.
 
An Encoder that uses a variable-length encoding for Longs.
Signed long lexicoder.
A block cache implementation that is memory-aware using HeapSize, memory-bound using an LRU eviction algorithm, and concurrent: backed by a ConcurrentHashMap and with a non-blocking eviction thread giving constant-time LruBlockCache.cacheBlock(java.lang.String, byte[], boolean) and LruBlockCache.getBlock(java.lang.String) operations.
 
 
 
 
 
 
ManagerClient<C extends org.apache.thrift.TServiceClient>
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
A Map counter for counting with longs or integers.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
 
 
A Combiner that interprets Values as Longs and returns the largest Long among them.
 
 
 
 
Exception - Meta Block with the same name already exists.
Exception - No such Meta Block with the given name.
 
Describes the table schema used for metadata tables
Holds bulk-load-in-progress processing flags
Holds delete markers for potentially unused files/directories
Value to indicate that the row has been skewed/encoded.
 
Deprecated.
Holds error message processing flags
Holds references to files that need replication
Contains additional metadata in a reserved area not for tablets
 
Used for storing information about tablets
Temporary markers that indicate a tablet loaded a bulk file
Column family for indicating that the files in a tablet have been trimmed to only include data for the current tablet, so that they are safe to merge
Temporary marker that indicates a tablet was successfully cloned
Column family for storing entries created by the TServer to indicate it has loaded a tablet that it was assigned
Column family for storing files used by a tablet
 
Column family for storing the assigned location
Column family for storing last location, as a hint for assignment
Column family for storing write-ahead log entries
Column family for storing the set of files scanned with an isolated scanner, to prevent them from being deleted
Column family for recording information used by the TServer
Column family for storing suspension location, as a demand for assignment.
Column family for storing the tablet information needed by clients
Provides a consolidated API for handling table metadata
 
Immutable metadata time object
Deprecated.
since 2.1.3; use MeterRegistryFactory instead
The Micrometer metrics allows for different monitoring systems.
 
Interface used to gather metrics from RFiles.
 
Prior to 2.1.0 Accumulo used the Hadoop Metrics2 framework.
A Combiner that interprets Values as Longs and returns the smallest Long among them.
 
An iterator capable of iterating over other iterators in sorted order.
 
this class buffers writes to the index so that chunks of index blocks are contiguous in the file instead of having index blocks sprinkled throughout the file making scans of the entire index slow.
 
 
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
This class enables efficient batch writing to multiple tables.
 
 
Mutation represents an action that manipulates a row in a table.
Provides methods for setting the column family of a Mutation.
Provides methods for setting the value of a Mutation.
Provides methods for setting the column qualifier of a Mutation.
Formats available for serializing Mutations.
Provides methods for setting the timestamp of a Mutation.
Provides methods for setting the column visibility of a Mutation.
Communicate the failed mutations of a BatchWriter back to the client.
 
Thrown when the namespace specified already exists, and it was expected that it didn't
A strongly typed representation of a namespace ID.
Thrown when the namespace specified contains tables
Thrown when the namespace specified doesn't exist when it was expected to
Provides an API for administering namespaces All tables exist in a namespace.
 
 
Accumulo namespace permissions.
 
This object stores table creation parameters.
 
The default encryption strategy which does nothing.
 
Deprecated.
since 2.1.0 Use NoDeleteConstraint
This constraint ensures mutations do not have deletes.
 
 
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
A rate limiter which doesn't actually limit rates at all.
 
 
 
 
 
Provides a stop watch for timing a single type of event.
The OptionDescriber interface allows you to set up iterator properties interactively in the accumulo shell.
 
An iterator that provides a sorted-iteration of column qualifiers for a set of column families in a row.
 
 
Configuration keys for various features.
Configuration keys for BatchWriter.
 
PairLexicoder<A extends Comparable<A>,B extends Comparable<B>>
This class is a lexicoder that sorts a ComparablePair.
Specifications for part of a Key.
 
 
Deprecated.
Deprecated.
A factory that loads a CryptoService based on TableId.
Encapsulates the configuration of an Accumulo server side plugin, which consist of a class name and options.
This interface exposes Accumulo system level information to plugins in a stable manner.
 
An ArrayList implementation that represents a type-safe pre-allocated array.
A RandomVolumeChooser that selects preferred volumes to use from the provided volume options.
 
 
 
Types of Property values.
 
Helper methods for interacting with Protocol Buffers and Accumulo
A VolumeChooser that selects a volume at random from the list of provided volumes.
This class is used to specify a range of Accumulo keys.
Deprecated.
since 2.0.0; Use org.apache.accumulo.hadoop.mapred instead from the accumulo-hadoop-mapreduce.jar
Deprecated.
since 2.0.0; Use org.apache.accumulo.hadoop.mapreduce instead from the accumulo-hadoop-mapreduce.jar
Deprecated.
since 2.0.0; Use org.apache.accumulo.hadoop.mapreduce.partition instead from the accumulo-hadoop-mapreduce.jar
A decorator for an InputStream which limits the rate at which reads are performed.
A decorator for OutputStream which limits the rate at which data may be written.
 
Read only access to a repeatable persisted operation.
Read only access to a Transaction Store.
Possible operational status codes.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
A GC reference used for collecting files and directories into a single stream.
A GC reference used for streaming and delete markers.
A Filter that matches entries based on Java regular expressions.
A GroupBalancer that groups tablets using a configurable regex.
 
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Deprecated.
Deprecated.
 
 
 
 
 
 
 
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
Deprecated.
Deprecated.
 
Deprecated.
Deprecated.
Deprecated.
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
Deprecated.
Deprecated.
Deprecated.
Repeatable persisted operation
A Filter that matches entries with a non-empty ColumnVisibility.
Encapsulates the retrying implementation for some operation.
 
 
 
 
 
 
 
 
A lexicoder that flips the sort order from another lexicoder.
RFile is Accumulo's internal storage format for Key Value pairs.
 
This is an intermediate interface in a larger builder pattern.
This is an intermediate interface in a larger builder pattern.
 
This is an intermediate interface in a larger builder pattern.
This is an intermediate interface in a larger builder pattern.
This is an intermediate interface in a larger builder pattern.
This is an intermediate interface in a larger builder pattern.
This is an intermediate interface in a large builder pattern.
 
This is an intermediate interface in a larger builder pattern.
This is an intermediate interface in a larger builder pattern.
This class extends CipherOutputStream to include a way to track the number of bytes that have been encrypted by the stream.
 
RFile metadata is stored at the end of the file.
This class provides an API for writing RFiles.
 
 
This class is used to serialize and deserialize root tablet metadata using GSon.
This sampler can hash any subset of a Key's fields.
An iterator for deleting whole rows.
The RowEncodingIterator is designed to provide row-isolation so that queries see mutations as atomic.
This iterator makes it easy to select rows that meet a given criteria.
 
Group Key/Value pairs into Iterators over rows.
Builds a sample based on entire rows.
 
 
 
Exception thrown when a table does not have sampling configured or when sampling is configured but it differs from what was requested.
A function that decides which key values are stored in a tables sample.
This class encapsulates configuration and options needed to setup and use sampling.
 
 
Client-side callbackhandler for sasl authentication which is the client-side sibling to the server-side SaslDigestCallbackHandler.
Connection parameters for setting up a TSaslTransportFactory
Enumeration around Sasl.QOP
The SASL mechanism to use for authentication
Common serialization methods across the client and server callback handlers for SASL.
 
Encapsulates information about how a scan should be executed.
 
Communicates how a scan should use cache.
A per table scan dispatcher that decides which executor should be used to process a scan.
The method parameters for ScanDispatcher.init(InitParameters).
Interface for obtaining information about a scan executor
 
Provides information about an active Accumulo scan against a tablet.
 
Deprecated.
since 2.1.0 This will be removed in a future version in favor of JShell
Scans a table over a given range.
This class hosts configuration methods that are shared between different types of scanners.
Consistency level for the scanner.
provides scanner functionality "Clients can iterate over multiple column families, and there are several mechanisms for limiting the rows, columns, and timestamps traversed by a scan.
 
 
A factory for creating comparators used for prioritizing scans.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
This object is used to communicate what previous actions were attempted, when they were attempted, and the result of those attempts
 
This class is used to track scan attempts for the ScanServerSelector.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Information about a scan server.
 
Returned by ScanServerSelector.selectServers(ScanServerSelector.SelectorParameters) to specify what scan servers to use and how to use them.
A client side plugin that determines what scan servers to use for eventually consistent scans.
This interface exists so that is easier to evolve what is passed to ScanServerSelector.init(InitParameters) without having to make breaking changes.
This interface exists so that is easier to evolve what is passed to ScanServerSelector.selectServers(SelectorParameters) without having to make breaking changes.
 
 
 
 
 
 
 
Provides a class for managing users and permissions
 
This class is like byte array input stream with two differences.
A wrapper converting a Seekable InputStream into a Seekable DataInputStream
Base class for filters that can skip over key-value pairs which do not match their filter predicate.
 
 
 
A Lexicoder to encode/decode a Java List to/from a byte array where the concatenation of each encoded element sorts lexicographically.
An optimized version of Filter.
 
 
An optimized version of SkippingIterator.
An optimized version of WrappingIterator.
This interface exposes Accumulo system level information to plugins in a stable manner.
 
 
 
 
 
 
Formats the rows in a METADATA table scan to show distribution of shards over servers per day.
Provides the ability to retrieve a RateLimiter keyed to a specific string, which will dynamically update its rate according to a specified callback function.
A callback which provides the current rate for a RateLimiter.
 
Dispatcher that supports simple configuration for making tables use compaction services.
A simple tablet balancer that attempts to spread tablets out evenly across all available tablet servers.
If no options are given, then this will default to an executor named default and ScanDispatch.CacheUsage.TABLE for index and data cache.
This class automates management of static singletons that maintain state for Accumulo clients.
These enums determine the behavior of the SingletonManager.
 
The SingletonManager uses this interface to enable and disable singleton services.
An AccumuloConfiguration which first loads any properties set on the command-line (using the -o option) and then from accumulo.properties.
 
 
 
Every call to SkippingIterator.next() and SkippingIterator.seek(Range, Collection, boolean) calls the parent's implementation and then calls the implementation's SkippingIterator.consume().
 
 
SortedKeyValueIterator<K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable>
An iterator that supports iterating over key and value pairs.
A simple iterator over a Java SortedMap Note that this class is intended as an in-memory replacement for RFile$Reader, so its behavior reflects the same assumptions; namely, that this iterator is not responsible for respecting the columnFamilies passed into seek().
 
A SortedKeyValueIterator which presents a view over some section of data, regardless of whether or not it is backed by memory (InMemoryMap) or an RFile (InMemoryMap that was minor compacted to a file).
 
A PreferredVolumeChooser that takes remaining HDFS space into account when making a volume choice rather than a simpler round-robin.
Split an RFile into large and small key/value files.
Deprecated.
since 2.0.0
 
 
 
Does not show contents from scan, only displays statistics.
 
 
StopWatch<K extends Enum<K>>
 
Object representing a tablet file entry stored in the metadata table.
This lexicoder encodes/decodes a given String to/from bytes without further processing.
Instances of this interface can be configured for Accumulo tables.
When Accumulo calls methods in this interface, it will call Summarizer.Collector.accept(Key, Value) zero or more times and then call Summarizer.Collector.summarize(Summarizer.StatisticConsumer) once.
A Combiner is used to merge statistics emitted from Summarizer.Collector.summarize(Summarizer.StatisticConsumer) and from previous invocations of itself.
 
This class encapsulates the configuration needed to instantiate a Summarizer.
 
 
 
This class encapsulates summary statistics, information about how those statistics were generated, and information about files the statistics were obtained from.
 
This class facilitates merging, storing, and serializing (to/from thrift) intermediate summary information.
 
This interface allows configuring where and which summary data to retrieve before retrieving it.
 
A Combiner that interprets Values as arrays of Longs and returns an array of element-wise sums.
 
 
 
 
 
A Combiner that interprets Values as Longs and returns their sum.
For a suspended tablet, the time of suspension and the server it was suspended from.
SynchronizedIterator<K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable>
Wraps a SortedKeyValueIterator so that all of its methods are synchronized.
A SortedKeyValueIterator similar to ServerFilter but with the implemented methods marked as synchronized.
This class implements loading in such a way that load operations for the same block will not run concurrently.
Syncs itself with the static collection of TabletLocators, so that when the server clears it, it will automatically get the most up-to-date version.
System utility class.
Accumulo system permissions.
This exception is thrown if a table is deleted after an operation starts.
Thrown when the table specified already exists, and it was expected that it didn't
A strongly typed representation of a table ID.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
Used for thread safe caching of immutable table ID maps.
 
Thrown when the table specified doesn't exist when it was expected to
 
 
 
Provides a class for administering tables
 
Options giving control of how the bulk import file mapping is done.
 
 
 
Accumulo table permissions.
 
 
 
This class is responsible for managing the distribution of tablets throughout an Accumulo cluster.
An interface for grouping parameters required for the balancer to assign unassigned tablets.
An interface for grouping parameters required for the balancer to balance tablets.
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
Object representing a tablet file that may exist in the metadata table.
 
A TabletId provides the information needed to uniquely identify a tablet.
 
 
When a tablet is assigned, we mark its future location.
 
 
 
 
 
 
 
 
This class contains source for logs messages about a tablets internal state, like its location, set of files, metadata.
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
 
 
 
 
 
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
 
 
 
 
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
An abstraction layer for reading tablet metadata from the accumulo.metadata and accumulo.root tables.
 
 
 
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
A lexicoder that preserves a Text's native sort order.
 
 
 
 
 
 
ThriftClientTypes<C extends org.apache.thrift.TServiceClient>
 
execute method with supplied client returning object of type R
execute method with supplied client
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
Serializes and deserializes Thrift messages to and from byte arrays.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
 
 
 
 
 
 
 
 
 
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
 
 
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
 
Factory methods for creating Thrift client objects
Throttles logging of balancer problems by storing the last log time for each problem and limiting reports to once per minute.
 
 
 
Throws a TimedOutException if the specified timeout duration elapses between two failed TabletLocator calls.
 
A Filter that matches entries whose timestamps fall within a range.
The type of ordering to use for the table's entries (default is MILLIS)
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
A block cache that is memory bounded using the W-TinyLFU eviction algorithm.
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
This compaction selector works in concert with the DeletesSummarizer.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCompactProtocol.Factory implementation which uses a protocol which traces
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
The TransformingIterator allows portions of a key (except for the row) to be transformed.
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TServerClient<C extends org.apache.thrift.TServiceClient>
 
A tablet is assigned to a tablet server at the given address as long as it is alive and well.
 
 
Transaction Store: a place to save transactions A transaction consists of a number of operations.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
A utility class for setting up a TTransport with various necessary configurations for ideal performance in Accumulo.
 
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
A Combiner that decodes each Value to type V before reducing, then encodes the result of typedReduce back to Value.
The Thrift SASL transports call Sasl.createSaslServer and Sasl.createSaslClient inside open().
A TransportFactory that wraps another one, but assumes a specified UGI before calling through.
A lexicoder for an unsigned integer.
Unsigned long lexicoder.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
A utility class for reading and writing bytes to byte buffers without synchronization.
A byte buffer reader.
A byte buffer writer.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
 
 
 
 
Supporting Utility classes used by TFile, and shared by users of TFile.
A generic Version class.
 
A lexicoder for a UUID that maintains its lexicographic sorting order.
 
Utility class for validation of tablet file paths.
A class that validates arguments of a specified generic type.
 
A byte sequence that is usable as a key or value.
A Comparator optimized for Value.
Exception used for TypedValueCombiner and it's Encoders decode() function
 
 
A class for accumulating constraint violations across a number of mutations.
Deprecated.
since 2.1.0 Use VisibilityConstraint
A constraint that checks the visibility of columns against the actor's authorizations.
A class which evaluates visibility expressions against a set of authorizations.
A SortedKeyValueIterator that filters based on ColumnVisibility.
A SortedKeyValueIterator that filters based on ColumnVisibility and optimized for use with system iterators.
Class that holds the components of a visibility metric.
An exception thrown when a visibility string cannot be parsed.
Counts column visibility labels.
This class provides visibility metrics per locality group.
Encapsulates a FileSystem and a base Path within that filesystem.
Helper used to select a volume from a set of Volume URIs.
 
A scope for the volume chooser environment; a TABLE scope should be accompanied by a tableId.
 
Basic Volume implementation that contains a FileSystem and a base path that should be used within that filesystem.
 
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
The WholeColumnFamilyIterator is designed to provide row/cf-isolation so that queries see mutations as atomic.
The WholeRowIterator is designed to provide row-isolation so that queries see mutations as atomic.
A convenience class for implementing iterators that select, but do not modify, entries read from a source iterator.
 
This callback handles the state of yielding within an iterator
YieldingKeyValueIterator<K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable>
An iterator that supports yielding on a next or seek call (only used by SortedKeyValueIterators)
A cache for values stored in ZooKeeper.
 
A factory for ZooCache instances.
Deprecated.
since 2.0.0, Use Accumulo.newClient() instead