Uses of Class
org.apache.accumulo.core.data.Range

Packages that use Range
org.apache.accumulo.core.client   
org.apache.accumulo.core.client.admin   
org.apache.accumulo.core.client.impl   
org.apache.accumulo.core.client.mapred   
org.apache.accumulo.core.client.mapreduce   
org.apache.accumulo.core.client.mapreduce.lib.impl This package exists to store common helpers for configuring MapReduce jobs in a single location. 
org.apache.accumulo.core.client.mapreduce.lib.util   
org.apache.accumulo.core.client.mock   
org.apache.accumulo.core.client.mock.impl   
org.apache.accumulo.core.data   
org.apache.accumulo.core.file   
org.apache.accumulo.core.file.keyfunctor   
org.apache.accumulo.core.file.map   
org.apache.accumulo.core.file.rfile   
org.apache.accumulo.core.iterators   
org.apache.accumulo.core.iterators.system   
org.apache.accumulo.core.iterators.user   
org.apache.accumulo.core.metadata   
org.apache.accumulo.core.metadata.schema   
org.apache.accumulo.core.util.shell.commands   
 

Uses of Range in org.apache.accumulo.core.client
 

Methods in org.apache.accumulo.core.client that return Range
 Range Scanner.getRange()
          Returns the range of keys to scan over.
 Range IsolatedScanner.getRange()
           
 Range ClientSideIteratorScanner.getRange()
           
 

Methods in org.apache.accumulo.core.client with parameters of type Range
 void ClientSideIteratorScanner.ScannerTranslator.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
           
 void Scanner.setRange(Range range)
          Sets the range of keys to scan over.
 void IsolatedScanner.setRange(Range range)
           
 void ClientSideIteratorScanner.setRange(Range range)
           
 

Method parameters in org.apache.accumulo.core.client with type arguments of type Range
 void BatchScanner.setRanges(Collection<Range> ranges)
          Allows scanning over multiple ranges efficiently.
 void BatchDeleter.setRanges(Collection<Range> ranges)
          Allows deleting multiple ranges efficiently.
 

Uses of Range in org.apache.accumulo.core.client.admin
 

Methods in org.apache.accumulo.core.client.admin that return types with arguments of type Range
 Set<Range> TableOperations.splitRangeByTablets(String tableName, Range range, int maxSplits)
           
 

Methods in org.apache.accumulo.core.client.admin with parameters of type Range
 Set<Range> TableOperations.splitRangeByTablets(String tableName, Range range, int maxSplits)
           
 

Uses of Range in org.apache.accumulo.core.client.impl
 

Fields in org.apache.accumulo.core.client.impl with type parameters of type Range
static Translator<Range,TRange> Translators.RT
           
 

Methods in org.apache.accumulo.core.client.impl that return Range
 Range ScannerImpl.getRange()
           
 Range OfflineScanner.getRange()
           
 Range Translator.TRangeTranslator.translate(TRange input)
           
 

Methods in org.apache.accumulo.core.client.impl that return types with arguments of type Range
 List<Range> TimeoutTabletLocator.binRanges(Credentials credentials, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
           
 List<Range> TabletLocatorImpl.binRanges(Credentials credentials, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
           
abstract  List<Range> TabletLocator.binRanges(Credentials credentials, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
           
 List<Range> RootTabletLocator.binRanges(Credentials credentials, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
           
 Set<Range> TableOperationsImpl.splitRangeByTablets(String tableName, Range range, int maxSplits)
           
 

Methods in org.apache.accumulo.core.client.impl with parameters of type Range
protected static void TabletLocatorImpl.addRange(Map<String,Map<KeyExtent,List<Range>>> binnedRanges, String location, KeyExtent ke, Range range)
           
protected  IsolatedScanner TableOperationsImpl.createMetadataScanner(Instance inst, Credentials creds, String metaTable, Range range)
          Create an IsolatedScanner over the given table, fetching the columns necessary to determine when a table has transitioned to online or offline.
static boolean ThriftScanner.getBatchFromServer(Instance instance, Credentials credentials, Range range, KeyExtent extent, String server, SortedMap<Key,Value> results, SortedSet<Column> fetchedColumns, List<IterInfo> serverSideIteratorList, Map<String,Map<String,String>> serverSideIteratorOptions, int size, Authorizations authorizations, boolean retry, AccumuloConfiguration conf)
           
 void ScannerImpl.setRange(Range range)
           
 void OfflineScanner.setRange(Range range)
           
 Set<Range> TableOperationsImpl.splitRangeByTablets(String tableName, Range range, int maxSplits)
           
 TRange Translator.RangeTranslator.translate(Range input)
           
 

Method parameters in org.apache.accumulo.core.client.impl with type arguments of type Range
protected static void TabletLocatorImpl.addRange(Map<String,Map<KeyExtent,List<Range>>> binnedRanges, String location, KeyExtent ke, Range range)
           
 List<Range> TimeoutTabletLocator.binRanges(Credentials credentials, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
           
 List<Range> TimeoutTabletLocator.binRanges(Credentials credentials, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
           
 List<Range> TabletLocatorImpl.binRanges(Credentials credentials, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
           
 List<Range> TabletLocatorImpl.binRanges(Credentials credentials, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
           
abstract  List<Range> TabletLocator.binRanges(Credentials credentials, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
           
abstract  List<Range> TabletLocator.binRanges(Credentials credentials, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
           
 List<Range> RootTabletLocator.binRanges(Credentials credentials, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
           
 List<Range> RootTabletLocator.binRanges(Credentials credentials, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
           
static void TabletServerBatchReaderIterator.doLookup(Instance instance, Credentials credentials, String server, Map<KeyExtent,List<Range>> requested, Map<KeyExtent,List<Range>> failures, Map<KeyExtent,List<Range>> unscanned, TabletServerBatchReaderIterator.ResultReceiver receiver, List<Column> columns, ScannerOptions options, Authorizations authorizations, AccumuloConfiguration conf)
           
static void TabletServerBatchReaderIterator.doLookup(Instance instance, Credentials credentials, String server, Map<KeyExtent,List<Range>> requested, Map<KeyExtent,List<Range>> failures, Map<KeyExtent,List<Range>> unscanned, TabletServerBatchReaderIterator.ResultReceiver receiver, List<Column> columns, ScannerOptions options, Authorizations authorizations, AccumuloConfiguration conf)
           
static void TabletServerBatchReaderIterator.doLookup(Instance instance, Credentials credentials, String server, Map<KeyExtent,List<Range>> requested, Map<KeyExtent,List<Range>> failures, Map<KeyExtent,List<Range>> unscanned, TabletServerBatchReaderIterator.ResultReceiver receiver, List<Column> columns, ScannerOptions options, Authorizations authorizations, AccumuloConfiguration conf)
           
 List<TabletLocator.TabletLocation> TabletLocatorImpl.TabletLocationObtainer.lookupTablets(Credentials credentials, String tserver, Map<KeyExtent,List<Range>> map, TabletLocator parent)
           
 void TabletServerBatchReader.setRanges(Collection<Range> ranges)
           
 

Constructors in org.apache.accumulo.core.client.impl with parameters of type Range
ThriftScanner.ScanState(Instance instance, Credentials credentials, org.apache.hadoop.io.Text tableId, Authorizations authorizations, Range range, SortedSet<Column> fetchedColumns, int size, List<IterInfo> serverSideIteratorList, Map<String,Map<String,String>> serverSideIteratorOptions, boolean isolated)
           
ThriftScanner.ScanState(Instance instance, Credentials credentials, org.apache.hadoop.io.Text tableId, Authorizations authorizations, Range range, SortedSet<Column> fetchedColumns, int size, List<IterInfo> serverSideIteratorList, Map<String,Map<String,String>> serverSideIteratorOptions, boolean isolated, long readaheadThreshold)
           
 

Constructor parameters in org.apache.accumulo.core.client.impl with type arguments of type Range
TabletServerBatchReaderIterator(Instance instance, Credentials credentials, String table, Authorizations authorizations, ArrayList<Range> ranges, int numThreads, ExecutorService queryThreadPool, ScannerOptions scannerOptions, long timeout)
           
 

Uses of Range in org.apache.accumulo.core.client.mapred
 

Methods in org.apache.accumulo.core.client.mapred that return types with arguments of type Range
protected static List<Range> InputFormatBase.getRanges(org.apache.hadoop.mapred.JobConf job)
          Gets the ranges to scan over from a job.
 

Method parameters in org.apache.accumulo.core.client.mapred with type arguments of type Range
static void InputFormatBase.setRanges(org.apache.hadoop.mapred.JobConf job, Collection<Range> ranges)
          Sets the input ranges to scan for this job.
 

Constructors in org.apache.accumulo.core.client.mapred with parameters of type Range
InputFormatBase.RangeInputSplit(String table, Range range, String[] locations)
          Deprecated.  
InputFormatBase.RangeInputSplit(String table, String tableId, Range range, String[] locations)
          Deprecated.  
RangeInputSplit(String table, String tableId, Range range, String[] locations)
           
 

Uses of Range in org.apache.accumulo.core.client.mapreduce
 

Methods in org.apache.accumulo.core.client.mapreduce that return Range
 Range RangeInputSplit.getRange()
           
 

Methods in org.apache.accumulo.core.client.mapreduce that return types with arguments of type Range
 List<Range> InputTableConfig.getRanges()
          Returns the ranges to be queried in the configuration
protected static List<Range> InputFormatBase.getRanges(org.apache.hadoop.mapreduce.JobContext context)
          Gets the ranges to scan over from a job.
 

Methods in org.apache.accumulo.core.client.mapreduce with parameters of type Range
 void RangeInputSplit.setRange(Range range)
           
 

Method parameters in org.apache.accumulo.core.client.mapreduce with type arguments of type Range
static void InputFormatBase.setRanges(org.apache.hadoop.mapreduce.Job job, Collection<Range> ranges)
          Sets the input ranges to scan for the single input table associated with this job.
 InputTableConfig InputTableConfig.setRanges(List<Range> ranges)
          Sets the input ranges to scan for all tables associated with this job.
 

Constructors in org.apache.accumulo.core.client.mapreduce with parameters of type Range
InputFormatBase.RangeInputSplit(String table, Range range, String[] locations)
          Deprecated.  
InputFormatBase.RangeInputSplit(String table, String tableId, Range range, String[] locations)
          Deprecated.  
RangeInputSplit(String table, String tableId, Range range, String[] locations)
           
 

Uses of Range in org.apache.accumulo.core.client.mapreduce.lib.impl
 

Methods in org.apache.accumulo.core.client.mapreduce.lib.impl that return types with arguments of type Range
static Map<String,Map<KeyExtent,List<Range>>> InputConfigurator.binOffline(String tableId, List<Range> ranges, Instance instance, Connector conn)
           
static List<Range> InputConfigurator.getRanges(Class<?> implementingClass, org.apache.hadoop.conf.Configuration conf)
          Gets the ranges to scan over from a job.
 

Method parameters in org.apache.accumulo.core.client.mapreduce.lib.impl with type arguments of type Range
static Map<String,Map<KeyExtent,List<Range>>> InputConfigurator.binOffline(String tableId, List<Range> ranges, Instance instance, Connector conn)
           
static void InputConfigurator.setRanges(Class<?> implementingClass, org.apache.hadoop.conf.Configuration conf, Collection<Range> ranges)
          Sets the input ranges to scan on all input tables for this job.
 

Uses of Range in org.apache.accumulo.core.client.mapreduce.lib.util
 

Methods in org.apache.accumulo.core.client.mapreduce.lib.util that return types with arguments of type Range
static List<Range> InputConfigurator.getRanges(Class<?> implementingClass, org.apache.hadoop.conf.Configuration conf)
          Deprecated. since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
 

Method parameters in org.apache.accumulo.core.client.mapreduce.lib.util with type arguments of type Range
static void InputConfigurator.setRanges(Class<?> implementingClass, org.apache.hadoop.conf.Configuration conf, Collection<Range> ranges)
          Deprecated. since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
 

Uses of Range in org.apache.accumulo.core.client.mock
 

Methods in org.apache.accumulo.core.client.mock that return Range
 Range MockScanner.getRange()
           
 

Methods in org.apache.accumulo.core.client.mock that return types with arguments of type Range
 List<Range> MockTabletLocator.binRanges(List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges, TCredentials credentials)
          Deprecated.  
 

Methods in org.apache.accumulo.core.client.mock with parameters of type Range
 void MockScanner.setRange(Range range)
           
 

Method parameters in org.apache.accumulo.core.client.mock with type arguments of type Range
 List<Range> MockTabletLocator.binRanges(List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges, TCredentials credentials)
          Deprecated.  
 List<Range> MockTabletLocator.binRanges(List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges, TCredentials credentials)
          Deprecated.  
 void MockBatchScanner.setRanges(Collection<Range> ranges)
           
 

Uses of Range in org.apache.accumulo.core.client.mock.impl
 

Methods in org.apache.accumulo.core.client.mock.impl that return types with arguments of type Range
 List<Range> MockTabletLocator.binRanges(Credentials credentials, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
           
 

Method parameters in org.apache.accumulo.core.client.mock.impl with type arguments of type Range
 List<Range> MockTabletLocator.binRanges(Credentials credentials, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
           
 List<Range> MockTabletLocator.binRanges(Credentials credentials, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
           
 

Uses of Range in org.apache.accumulo.core.data
 

Methods in org.apache.accumulo.core.data that return Range
 Range Range.bound(Column min, Column max)
          Creates a new range that is bounded by the columns passed in.
 Range Range.clip(Range range)
          Creates a range which represents the intersection of this range and the passed in range.
 Range Range.clip(Range range, boolean returnNullIfDisjoint)
          Same as other clip function except if gives the option to return null of the ranges do not overlap instead of throwing an exception.
static Range Range.exact(CharSequence row)
          Creates a range that covers an exact row
static Range Range.exact(CharSequence row, CharSequence cf)
          Creates a range that covers an exact row and column family
static Range Range.exact(CharSequence row, CharSequence cf, CharSequence cq)
          Creates a range that covers an exact row, column family, and column qualifier
static Range Range.exact(CharSequence row, CharSequence cf, CharSequence cq, CharSequence cv)
          Creates a range that covers an exact row, column family, column qualifier, and visibility
static Range Range.exact(CharSequence row, CharSequence cf, CharSequence cq, CharSequence cv, long ts)
          Creates a range that covers an exact row, column family, column qualifier, visibility, and timestamp
static Range Range.exact(org.apache.hadoop.io.Text row)
          Creates a range that covers an exact row Returns the same Range as new Range(row)
static Range Range.exact(org.apache.hadoop.io.Text row, org.apache.hadoop.io.Text cf)
          Creates a range that covers an exact row and column family
static Range Range.exact(org.apache.hadoop.io.Text row, org.apache.hadoop.io.Text cf, org.apache.hadoop.io.Text cq)
          Creates a range that covers an exact row, column family, and column qualifier
static Range Range.exact(org.apache.hadoop.io.Text row, org.apache.hadoop.io.Text cf, org.apache.hadoop.io.Text cq, org.apache.hadoop.io.Text cv)
          Creates a range that covers an exact row, column family, column qualifier, and visibility
static Range Range.exact(org.apache.hadoop.io.Text row, org.apache.hadoop.io.Text cf, org.apache.hadoop.io.Text cq, org.apache.hadoop.io.Text cv, long ts)
          Creates a range that covers an exact row, column family, column qualifier, visibility, and timestamp
static Range Range.prefix(CharSequence rowPrefix)
          Returns a Range that covers all rows beginning with a prefix
static Range Range.prefix(CharSequence row, CharSequence cfPrefix)
          Returns a Range that covers all column families beginning with a prefix within a given row
static Range Range.prefix(CharSequence row, CharSequence cf, CharSequence cqPrefix)
          Returns a Range that covers all column qualifiers beginning with a prefix within a given row and column family
static Range Range.prefix(CharSequence row, CharSequence cf, CharSequence cq, CharSequence cvPrefix)
          Returns a Range that covers all column visibilities beginning with a prefix within a given row, column family, and column qualifier
static Range Range.prefix(org.apache.hadoop.io.Text rowPrefix)
          Returns a Range that covers all rows beginning with a prefix
static Range Range.prefix(org.apache.hadoop.io.Text row, org.apache.hadoop.io.Text cfPrefix)
          Returns a Range that covers all column families beginning with a prefix within a given row
static Range Range.prefix(org.apache.hadoop.io.Text row, org.apache.hadoop.io.Text cf, org.apache.hadoop.io.Text cqPrefix)
          Returns a Range that covers all column qualifiers beginning with a prefix within a given row and column family
static Range Range.prefix(org.apache.hadoop.io.Text row, org.apache.hadoop.io.Text cf, org.apache.hadoop.io.Text cq, org.apache.hadoop.io.Text cvPrefix)
          Returns a Range that covers all column visibilities beginning with a prefix within a given row, column family, and column qualifier
 Range KeyExtent.toDataRange()
           
 Range KeyExtent.toMetadataRange()
           
 

Methods in org.apache.accumulo.core.data that return types with arguments of type Range
static List<Range> Range.mergeOverlapping(Collection<Range> ranges)
          Takes a collection on range and merges overlapping and adjacent ranges.
 

Methods in org.apache.accumulo.core.data with parameters of type Range
 Range Range.clip(Range range)
          Creates a range which represents the intersection of this range and the passed in range.
 Range Range.clip(Range range, boolean returnNullIfDisjoint)
          Same as other clip function except if gives the option to return null of the ranges do not overlap instead of throwing an exception.
 int Range.compareTo(Range o)
          Compares this range to another range.
 boolean Range.equals(Range otherRange)
           
 

Method parameters in org.apache.accumulo.core.data with type arguments of type Range
static List<Range> Range.mergeOverlapping(Collection<Range> ranges)
          Takes a collection on range and merges overlapping and adjacent ranges.
 

Constructors in org.apache.accumulo.core.data with parameters of type Range
Range(Range range)
          Copies a range
 

Uses of Range in org.apache.accumulo.core.file
 

Methods in org.apache.accumulo.core.file with parameters of type Range
abstract  FileSKVIterator FileOperations.openReader(String file, Range range, Set<ByteSequence> columnFamilies, boolean inclusive, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, AccumuloConfiguration tableConf)
          Open a reader that will not be seeked giving an initial seek location.
abstract  FileSKVIterator FileOperations.openReader(String file, Range range, Set<ByteSequence> columnFamilies, boolean inclusive, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, AccumuloConfiguration tableConf, BlockCache dataCache, BlockCache indexCache)
           
 void BloomFilterLayer.Reader.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
           
 

Uses of Range in org.apache.accumulo.core.file.keyfunctor
 

Methods in org.apache.accumulo.core.file.keyfunctor with parameters of type Range
 org.apache.hadoop.util.bloom.Key RowFunctor.transform(Range range)
           
 org.apache.hadoop.util.bloom.Key KeyFunctor.transform(Range range)
          Implementations should return null if a range can not be converted to a bloom key.
 org.apache.hadoop.util.bloom.Key ColumnQualifierFunctor.transform(Range range)
           
 org.apache.hadoop.util.bloom.Key ColumnFamilyFunctor.transform(Range range)
           
 

Uses of Range in org.apache.accumulo.core.file.map
 

Methods in org.apache.accumulo.core.file.map with parameters of type Range
 FileSKVIterator MapFileOperations.openReader(String file, Range range, Set<ByteSequence> columnFamilies, boolean inclusive, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, AccumuloConfiguration tableConf)
           
 FileSKVIterator MapFileOperations.openReader(String file, Range range, Set<ByteSequence> columnFamilies, boolean inclusive, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, AccumuloConfiguration tableConf, BlockCache dataCache, BlockCache indexCache)
           
 void MapFileOperations.RangeIterator.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
           
 

Uses of Range in org.apache.accumulo.core.file.rfile
 

Methods in org.apache.accumulo.core.file.rfile with parameters of type Range
 FileSKVIterator RFileOperations.openReader(String file, Range range, Set<ByteSequence> columnFamilies, boolean inclusive, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, AccumuloConfiguration tableConf)
           
 FileSKVIterator RFileOperations.openReader(String file, Range range, Set<ByteSequence> columnFamilies, boolean inclusive, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, AccumuloConfiguration tableConf, BlockCache dataCache, BlockCache indexCache)
           
 void RFile.Reader.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
           
 

Uses of Range in org.apache.accumulo.core.iterators
 

Methods in org.apache.accumulo.core.iterators that return Range
static Range IteratorUtil.maximizeStartKeyTimeStamp(Range range)
           
static Range IteratorUtil.minimizeEndKeyTimeStamp(Range range)
           
 

Methods in org.apache.accumulo.core.iterators with parameters of type Range
static Range IteratorUtil.maximizeStartKeyTimeStamp(Range range)
           
static Range IteratorUtil.minimizeEndKeyTimeStamp(Range range)
           
 void WrappingIterator.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
           
 void SortedMapIterator.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
           
 void SortedKeyValueIterator.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
          Seeks to the first key in the Range, restricting the resulting K,V pairs to those with the specified columns.
 void SkippingIterator.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
           
 void OrIterator.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
           
 void FirstEntryInRowIterator.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
           
 void Filter.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
           
 void DevNull.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
           
 void DebugIterator.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
           
 void Combiner.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
           
 void ColumnFamilyCounter.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
           
 void AggregatingIterator.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
          Deprecated.  
 

Uses of Range in org.apache.accumulo.core.iterators.system
 

Fields in org.apache.accumulo.core.iterators.system declared as Range
protected  Range ColumnFamilySkippingIterator.range
           
 

Methods in org.apache.accumulo.core.iterators.system with parameters of type Range
static int LocalityGroupIterator.seek(HeapIterator hiter, LocalityGroupIterator.LocalityGroup[] groups, Set<ByteSequence> nonDefaultColumnFamilies, Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
           
 void TimeSettingIterator.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
           
 void SynchronizedIterator.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
           
 void StatsIterator.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
           
 void SourceSwitchingIterator.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
           
 void SequenceFileIterator.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
           
 void MultiIterator.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
           
 void MapFileIterator.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
           
 void LocalityGroupIterator.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
           
 void DeletingIterator.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
           
 void ColumnFamilySkippingIterator.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
           
 

Constructors in org.apache.accumulo.core.iterators.system with parameters of type Range
MultiIterator(List<SortedKeyValueIterator<Key,Value>> iters, Range seekFence)
           
 

Uses of Range in org.apache.accumulo.core.iterators.user
 

Fields in org.apache.accumulo.core.iterators.user declared as Range
protected  Range TransformingIterator.seekRange
           
 

Methods in org.apache.accumulo.core.iterators.user that return Range
protected  Range TransformingIterator.computeReseekRange(Range range)
          Possibly expand range to include everything for the key prefix we are working with.
 

Methods in org.apache.accumulo.core.iterators.user with parameters of type Range
protected  Range TransformingIterator.computeReseekRange(Range range)
          Possibly expand range to include everything for the key prefix we are working with.
 void WholeColumnFamilyIterator.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
           
 void VersioningIterator.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
           
 void TransformingIterator.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
           
 void RowFilter.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
           
 void RowEncodingIterator.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
           
 void RowDeletingIterator.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
           
 void LargeRowFilter.seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
           
 void IntersectingIterator.seek(Range range, Collection<ByteSequence> seekColumnFamilies, boolean inclusive)
           
 void IndexedDocIterator.seek(Range range, Collection<ByteSequence> seekColumnFamilies, boolean inclusive)
           
 

Uses of Range in org.apache.accumulo.core.metadata
 

Method parameters in org.apache.accumulo.core.metadata with type arguments of type Range
 List<TabletLocator.TabletLocation> MetadataLocationObtainer.lookupTablets(Credentials credentials, String tserver, Map<KeyExtent,List<Range>> tabletsRanges, TabletLocator parent)
           
 

Uses of Range in org.apache.accumulo.core.metadata.schema
 

Methods in org.apache.accumulo.core.metadata.schema that return Range
static Range MetadataSchema.TabletsSection.getRange()
           
static Range MetadataSchema.ReservedSection.getRange()
           
static Range MetadataSchema.DeletesSection.getRange()
           
static Range MetadataSchema.BlipSection.getRange()
           
static Range MetadataSchema.TabletsSection.getRange(String tableId)
           
 

Uses of Range in org.apache.accumulo.core.util.shell.commands
 

Methods in org.apache.accumulo.core.util.shell.commands that return Range
protected  Range ScanCommand.getRange(org.apache.commons.cli.CommandLine cl, ScanInterpreter formatter)
           
 



Copyright © 2015 Apache Accumulo Project. All rights reserved.