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.
 
This class contains all API entry points created in 2.0.0 or later.
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 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
 
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.
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
 
This class allows MapReduce jobs to use Accumulo as the source of data.
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
 
This class allows MapReduce jobs to use Accumulo as the sink for data.
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.
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
 
This class allows MapReduce jobs to use Accumulo as the source of data.
An Accumulo Exception for security violations, authentication failures, authorization failures, etc.
 
 
 
 
 
A class that contains information about an ActiveScan
Example implementation of AES encryption for Accumulo
A filter that ages off key/value pairs based on the Key's timestamp.
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.
 
 
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.
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
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.
Block cache interface.
 
Cache statistics.
 
 
A sequence of bytes.
For each of the methods, this lexicoder just passes the input through untouched.
 
 
 
 
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.
Deprecated.
since 2.0.0, replaced by Accumulo.newClient()
 
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 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.
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 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.
 
 
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.
Deprecated, for removal: This API element is subject to removal in a future version.
since 2.1.0 CompactionStrategies were deprecated for multiple reasons.
 
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.
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.
 
 
 
The default Accumulo selector for scan servers.
Deprecated.
since 2.0.0.
Constraint objects are used to determine if mutations will be applied to a table.
The environment within which a constraint exists.
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.
An AuthenticationToken backed by a Hadoop CredentialProvider.
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.
A lexicoder for date objects.
 
Finds the largest continuous set of small files that meet the compaction ratio and do not prevent future compactions.
A constraints that limits the size of keys to 1mb.
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)
This summarizer tracks the total number of delete Keys seen and the total number of keys seen.
An iterator that is useful testing...
 
A lexicoder for preserving the native Java sort order of Double values.
The value for the durability of a BatchWriter or ConditionalWriter.
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.
Class implementation that will decrypt a file.
Class implementation that will encrypt a file.
Builder for all the information needed for the Map Reduce job.
Options for builder
Required params for builder
A SortedKeyValueIterator that filters entries from its source iterator.
 
 
A lexicoder for preserving the native Java sort order of Float values.
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.
A balancer that evenly spreads groups of tablets across all tablet server.
 
When configured for a scan executor, this prioritizer allows scanners to set priorities as integers.
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.
Creation mode for table creation.
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
 
 
Builder for all the information needed for the Map Reduce job.
Required params for builder
Optional values to set using fluent API
Required params for builder
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.
 
A lexicoder for signed integers.
This iterator facilitates document-partitioned indexing.
 
A scanner that presents a row isolated view of an accumulo table.
 
 
 
 
 
Provides information about a configured Accumulo Iterator
 
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.
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.
Deprecated.
since 2.0.0; Use org.apache.accumulo.hadoop.mapreduce.partition instead from the accumulo-hadoop-mapreduce.jar
Hadoop partitioner that uses ranges based on row keys, and optionally sub-bins based on hashing.
A key/value pair.
This iterator suppresses rows that exceed a specified number of columns.
A lexicoder provides methods to convert to/from byte arrays.
A lexicoder to encode/decode a Java List to/from a byte array where the concatenation of each encoded element sorts lexicographically.
Information about where to load files into an Accumulo table.
 
Mapping of a file to a row range with an associated range type.
 
A snapshot of metadata information about where a specified set of ranges are located returned by TableOperations.locate(String, java.util.Collection)
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 Combiner that interprets Values as Longs and returns the largest Long among them.
 
A Combiner that interprets Values as Longs and returns the smallest Long among them.
A utility class that will create Zookeeper and Accumulo processes that write all of their data to a single local directory.
Holds configuration for MiniAccumuloCluster.
Deprecated.
A runner for starting up a MiniAccumuloCluster from the command line using an optional configuration properties file.
 
 
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.
 
This constraint ensures mutations do not have deletes.
 
 
 
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.
 
Builder for all the information needed for the Map Reduce job.
Required params for client
Builder options
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.
 
A RandomVolumeChooser that selects preferred volumes to use from the provided volume options.
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
Hadoop partitioner that uses ranges, and optionally sub-bins based on hashing.
A Filter that matches entries based on Java regular expressions.
A GroupBalancer that groups tablets using a configurable regex.
Deprecated.
A Filter that matches entries with a non-empty ColumnVisibility.
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.
RFile metadata is stored at the end of the file.
This class provides an API for writing RFiles.
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.
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.
 
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.
A factory for creating comparators used for prioritizing scans.
This object is used to communicate what previous actions were attempted, when they were attempted, and the result of those attempts
 
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
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.
 
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.
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 PreferredVolumeChooser that takes remaining HDFS space into account when making a volume choice rather than a simpler round-robin.
 
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 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.
A SortedKeyValueIterator similar to ServerFilter but with the implemented methods marked as synchronized.
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.
 
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.
A TabletId provides the information needed to uniquely identify a tablet.
 
 
 
A lexicoder that preserves a Text's native sort order.
Throttles logging of balancer problems by storing the last log time for each problem and limiting reports to once per minute.
 
 
 
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)
This compaction selector works in concert with the DeletesSummarizer.
The TransformingIterator allows portions of a key (except for the row) to be transformed.
 
 
A Combiner that decodes each Value to type V before reducing, then encodes the result of typedReduce back to Value.
A lexicoder for an unsigned integer.
Unsigned long lexicoder.
A lexicoder for a UUID that maintains its lexicographic sorting order.
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 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.
An exception thrown when a visibility string cannot be parsed.
Counts column visibility labels.
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.
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)
Deprecated.
since 2.0.0, Use Accumulo.newClient() instead