Uses of Class
org.apache.accumulo.core.data.Range
-
-
Uses of Range in org.apache.accumulo.core.client
Methods in org.apache.accumulo.core.client that return Range Modifier and Type Method Description Range
ClientSideIteratorScanner. getRange()
Range
IsolatedScanner. getRange()
Range
Scanner. getRange()
Returns the range of keys to scan over.Methods in org.apache.accumulo.core.client with parameters of type Range Modifier and Type Method Description void
ClientSideIteratorScanner. setRange(Range range)
void
IsolatedScanner. setRange(Range range)
void
Scanner. setRange(Range range)
Sets the range of keys to scan over.Method parameters in org.apache.accumulo.core.client with type arguments of type Range Modifier and Type Method Description void
BatchDeleter. setRanges(Collection<Range> ranges)
Allows deleting multiple ranges efficiently.void
BatchScanner. setRanges(Collection<Range> ranges)
Allows scanning over 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 Modifier and Type Method Description Map<Range,List<TabletId>>
Locations. groupByRange()
For all of the ranges passed toTableOperations.locate(String, java.util.Collection)
, return a map of the tablets each range overlaps.Map<TabletId,List<Range>>
Locations. groupByTablet()
For all of the ranges passed toTableOperations.locate(String, java.util.Collection)
, return a map of the ranges each tablet overlaps.Set<Range>
TableOperations. splitRangeByTablets(String tableName, Range range, int maxSplits)
Methods in org.apache.accumulo.core.client.admin with parameters of type Range Modifier and Type Method Description Set<Range>
TableOperations. splitRangeByTablets(String tableName, Range range, int maxSplits)
Method parameters in org.apache.accumulo.core.client.admin with type arguments of type Range Modifier and Type Method Description Locations
TableOperations. locate(String tableName, Collection<Range> ranges)
Locates the tablet servers and tablets that would service a collections of ranges. -
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 Modifier and Type Method Description protected static List<Range>
InputFormatBase. getRanges(org.apache.hadoop.mapred.JobConf job)
Deprecated.Gets the ranges to scan over from a job.Method parameters in org.apache.accumulo.core.client.mapred with type arguments of type Range Modifier and Type Method Description static void
InputFormatBase. setRanges(org.apache.hadoop.mapred.JobConf job, Collection<Range> ranges)
Deprecated.Sets the input ranges to scan for this job.Constructors in org.apache.accumulo.core.client.mapred with parameters of type Range Constructor Description RangeInputSplit(String table, String tableId, Range range, String[] locations)
Deprecated. -
Uses of Range in org.apache.accumulo.core.client.mapreduce
Methods in org.apache.accumulo.core.client.mapreduce that return Range Modifier and Type Method Description Range
RangeInputSplit. getRange()
Deprecated.Methods in org.apache.accumulo.core.client.mapreduce that return types with arguments of type Range Modifier and Type Method Description protected static List<Range>
InputFormatBase. getRanges(org.apache.hadoop.mapreduce.JobContext context)
Deprecated.Gets the ranges to scan over from a job.List<Range>
InputTableConfig. getRanges()
Deprecated.Returns the ranges to be queried in the configurationMethods in org.apache.accumulo.core.client.mapreduce with parameters of type Range Modifier and Type Method Description void
RangeInputSplit. setRange(Range range)
Deprecated.Method parameters in org.apache.accumulo.core.client.mapreduce with type arguments of type Range Modifier and Type Method Description static void
InputFormatBase. setRanges(org.apache.hadoop.mapreduce.Job job, Collection<Range> ranges)
Deprecated.Sets the input ranges to scan for the single input table associated with this job.InputTableConfig
InputTableConfig. setRanges(List<Range> ranges)
Deprecated.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 Constructor Description RangeInputSplit(String table, String tableId, Range range, String[] locations)
Deprecated. -
Uses of Range in org.apache.accumulo.core.client.rfile
Methods in org.apache.accumulo.core.client.rfile with parameters of type Range Modifier and Type Method Description RFile.ScannerOptions
RFile.ScannerOptions. withBounds(Range range)
This option allows limiting theScanner
from reading data outside of a given range. -
Uses of Range in org.apache.accumulo.core.clientImpl
Methods in org.apache.accumulo.core.clientImpl that return Range Modifier and Type Method Description Range
OfflineScanner. getRange()
Range
ScannerImpl. getRange()
Methods in org.apache.accumulo.core.clientImpl that return types with arguments of type Range Modifier and Type Method Description List<Range>
RootTabletLocator. binRanges(ClientContext context, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
List<Range>
SyncingTabletLocator. binRanges(ClientContext context, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
abstract List<Range>
TabletLocator. binRanges(ClientContext context, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
List<Range>
TabletLocatorImpl. binRanges(ClientContext context, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
List<Range>
TimeoutTabletLocator. binRanges(ClientContext context, 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.clientImpl with parameters of type Range Modifier and Type Method Description protected static void
TabletLocatorImpl. addRange(Map<String,Map<KeyExtent,List<Range>>> binnedRanges, String location, KeyExtent ke, Range range)
static boolean
ThriftScanner. getBatchFromServer(ClientContext context, 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, long batchTimeOut, String classLoaderContext)
void
OfflineScanner. setRange(Range range)
void
ScannerImpl. setRange(Range range)
Set<Range>
TableOperationsImpl. splitRangeByTablets(String tableName, Range range, int maxSplits)
Method parameters in org.apache.accumulo.core.clientImpl with type arguments of type Range Modifier and Type Method Description protected static void
TabletLocatorImpl. addRange(Map<String,Map<KeyExtent,List<Range>>> binnedRanges, String location, KeyExtent ke, Range range)
List<Range>
RootTabletLocator. binRanges(ClientContext context, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
List<Range>
RootTabletLocator. binRanges(ClientContext context, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
List<Range>
SyncingTabletLocator. binRanges(ClientContext context, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
List<Range>
SyncingTabletLocator. binRanges(ClientContext context, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
abstract List<Range>
TabletLocator. binRanges(ClientContext context, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
abstract List<Range>
TabletLocator. binRanges(ClientContext context, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
List<Range>
TabletLocatorImpl. binRanges(ClientContext context, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
List<Range>
TabletLocatorImpl. binRanges(ClientContext context, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
List<Range>
TimeoutTabletLocator. binRanges(ClientContext context, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
List<Range>
TimeoutTabletLocator. binRanges(ClientContext context, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
static void
TabletServerBatchReaderIterator. doLookup(ClientContext context, 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)
Locations
TableOperationsImpl. locate(String tableName, Collection<Range> ranges)
List<TabletLocator.TabletLocation>
TabletLocatorImpl.TabletLocationObtainer. lookupTablets(ClientContext context, String tserver, Map<KeyExtent,List<Range>> map, TabletLocator parent)
void
TabletServerBatchReader. setRanges(Collection<Range> ranges)
Constructors in org.apache.accumulo.core.clientImpl with parameters of type Range Constructor Description ScanState(ClientContext context, TableId tableId, Authorizations authorizations, Range range, SortedSet<Column> fetchedColumns, int size, List<IterInfo> serverSideIteratorList, Map<String,Map<String,String>> serverSideIteratorOptions, boolean isolated, long readaheadThreshold, SamplerConfiguration samplerConfig, long batchTimeOut, String classLoaderContext, Map<String,String> executionHints, boolean useScanServer)
Constructor parameters in org.apache.accumulo.core.clientImpl with type arguments of type Range Constructor Description TabletServerBatchReaderIterator(ClientContext context, TableId tableId, String tableName, Authorizations authorizations, ArrayList<Range> ranges, int numThreads, ExecutorService queryThreadPool, ScannerOptions scannerOptions, long retryTimeout)
-
Uses of Range in org.apache.accumulo.core.clientImpl.mapred
Constructor parameters in org.apache.accumulo.core.clientImpl.mapred with type arguments of type Range Constructor Description BatchInputSplit(String table, TableId tableId, Collection<Range> ranges, String[] location)
Deprecated. -
Uses of Range in org.apache.accumulo.core.clientImpl.mapreduce
Methods in org.apache.accumulo.core.clientImpl.mapreduce that return Range Modifier and Type Method Description Range
BatchInputSplit. getRange()
Deprecated.Methods in org.apache.accumulo.core.clientImpl.mapreduce that return types with arguments of type Range Modifier and Type Method Description Collection<Range>
BatchInputSplit. getRanges()
Deprecated.Methods in org.apache.accumulo.core.clientImpl.mapreduce with parameters of type Range Modifier and Type Method Description static long
SplitUtils. getRangeLength(Range range)
Deprecated.void
BatchInputSplit. setRange(Range range)
Deprecated.Method parameters in org.apache.accumulo.core.clientImpl.mapreduce with type arguments of type Range Modifier and Type Method Description void
BatchInputSplit. setRanges(Collection<Range> ranges)
Deprecated.Constructor parameters in org.apache.accumulo.core.clientImpl.mapreduce with type arguments of type Range Constructor Description BatchInputSplit(String table, TableId tableId, Collection<Range> ranges, String[] locations)
Deprecated. -
Uses of Range in org.apache.accumulo.core.clientImpl.mapreduce.lib
Methods in org.apache.accumulo.core.clientImpl.mapreduce.lib that return types with arguments of type Range Modifier and Type Method Description static Map<String,Map<KeyExtent,List<Range>>>
InputConfigurator. binOffline(TableId tableId, List<Range> ranges, ClientContext context)
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.clientImpl.mapreduce.lib with type arguments of type Range Modifier and Type Method Description static Map<String,Map<KeyExtent,List<Range>>>
InputConfigurator. binOffline(TableId tableId, List<Range> ranges, ClientContext context)
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.data
Methods in org.apache.accumulo.core.data that return Range Modifier and Type Method Description 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)
Creates a range which represents the intersection of this range and the passed in range.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 column 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, column visibility, and timestamp.static Range
Range. exact(org.apache.hadoop.io.Text row)
Creates a range that covers an exact 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 column 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, column 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
TabletId. toRange()
Methods in org.apache.accumulo.core.data that return types with arguments of type Range Modifier and Type Method Description static List<Range>
Range. mergeOverlapping(Collection<Range> ranges)
Merges overlapping and adjacent ranges.Methods in org.apache.accumulo.core.data with parameters of type Range Modifier and Type Method Description 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)
Creates a range which represents the intersection of this range and the passed in range.int
Range. compareTo(Range o)
Compares this range to another range.boolean
Range. equals(Range otherRange)
Determines if this range equals another.Method parameters in org.apache.accumulo.core.data with type arguments of type Range Modifier and Type Method Description static List<Range>
Range. mergeOverlapping(Collection<Range> ranges)
Merges overlapping and adjacent ranges.Constructors in org.apache.accumulo.core.data with parameters of type Range Constructor Description Range(Range range)
Copies a range. -
Uses of Range in org.apache.accumulo.core.dataImpl
Methods in org.apache.accumulo.core.dataImpl that return Range Modifier and Type Method Description Range
KeyExtent. toDataRange()
Compute a representation of this extent as a Range suitable for scanning this extent's table and retrieving all data between this extent's previous end row (exclusive) and its end row (inclusive) in that table (or another table in the same range, since the returned range does not specify the table to scan).Range
KeyExtent. toMetaRange()
Compute a representation of this extent as a Range suitable for scanning the corresponding metadata table for this extent's table, and retrieving all the metadata for the table's tablets between this extent's previous end row (exclusive) and its end row (inclusive) in that table.Range
TabletIdImpl. toRange()
-
Uses of Range in org.apache.accumulo.core.file
Fields in org.apache.accumulo.core.file declared as Range Modifier and Type Field Description Range
FileOperations.FileOptions. range
Methods in org.apache.accumulo.core.file that return Range Modifier and Type Method Description Range
FileOperations.FileOptions. getRange()
Methods in org.apache.accumulo.core.file with parameters of type Range Modifier and Type Method Description FileOperations.ScanReaderBuilder
FileOperations.ScanReaderBuilder. overRange(Range range, Set<ByteSequence> columnFamilies, boolean inclusive)
Set the range over which the constructed iterator will search.void
BloomFilterLayer.Reader. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
protected FileOperations.FileOptions
FileOperations.FileHelper. toScanReaderBuilderOptions(Range range, Set<ByteSequence> columnFamilies, boolean inclusive)
Constructors in org.apache.accumulo.core.file with parameters of type Range Constructor Description FileOptions(AccumuloConfiguration tableConfiguration, String filename, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration fsConf, RateLimiter rateLimiter, String compression, org.apache.hadoop.fs.FSDataOutputStream outputStream, boolean enableAccumuloStart, CacheProvider cacheProvider, com.google.common.cache.Cache<String,Long> fileLenCache, boolean seekToBeginning, CryptoService cryptoService, Range range, Set<ByteSequence> columnFamilies, boolean inclusive, boolean dropCacheBehind)
-
Uses of Range in org.apache.accumulo.core.file.keyfunctor
Methods in org.apache.accumulo.core.file.keyfunctor with parameters of type Range Modifier and Type Method Description org.apache.hadoop.util.bloom.Key
ColumnFamilyFunctor. transform(Range range)
org.apache.hadoop.util.bloom.Key
ColumnQualifierFunctor. 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
RowFunctor. 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 Modifier and Type Method Description 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 Modifier and Type Method Description 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 Modifier and Type Method Description static Range
IteratorUtil. maximizeStartKeyTimeStamp(Range range)
Maximize the Start Key timestamp.static Range
IteratorUtil. minimizeEndKeyTimeStamp(Range range)
Minimize the endKey Timestamp.Methods in org.apache.accumulo.core.iterators with parameters of type Range Modifier and Type Method Description static Range
IteratorUtil. maximizeStartKeyTimeStamp(Range range)
Maximize the Start Key timestamp.static Range
IteratorUtil. minimizeEndKeyTimeStamp(Range range)
Minimize the endKey Timestamp.void
ColumnFamilyCounter. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
void
Combiner. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
void
DebugIterator. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
void
DevNull. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
void
Filter. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
void
FirstEntryInRowIterator. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
void
OrIterator. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
void
OrIterator.TermSource. seek(Range originalRange)
Converts the givenRange
into the correctRange
for this TermSource (per this expected table structure) and then seeks this TermSource's SKVI.void
ServerFilter. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
void
ServerSkippingIterator. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
void
ServerWrappingIterator. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
void
SkippingIterator. 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
SynchronizedServerFilter. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
void
WrappingIterator. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
-
Uses of Range in org.apache.accumulo.core.iterators.user
Fields in org.apache.accumulo.core.iterators.user declared as Range Modifier and Type Field Description protected Range
TransformingIterator. seekRange
Methods in org.apache.accumulo.core.iterators.user that return Range Modifier and Type Method Description protected Range
TransformingIterator. computeReseekRange(Range range)
Possibly expandrange
to include everything for the key prefix we are working with.Methods in org.apache.accumulo.core.iterators.user with parameters of type Range Modifier and Type Method Description protected Range
TransformingIterator. computeReseekRange(Range range)
Possibly expandrange
to include everything for the key prefix we are working with.void
IndexedDocIterator. seek(Range range, Collection<ByteSequence> seekColumnFamilies, boolean inclusive)
void
IntersectingIterator. seek(Range range, Collection<ByteSequence> seekColumnFamilies, boolean inclusive)
void
LargeRowFilter. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
void
RowDeletingIterator. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
void
RowEncodingIterator. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
void
RowFilter. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
void
SeekingFilter. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
void
TransformingIterator. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
void
VersioningIterator. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
void
WholeColumnFamilyIterator. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
-
Uses of Range in org.apache.accumulo.core.iteratorsImpl.system
Fields in org.apache.accumulo.core.iteratorsImpl.system declared as Range Modifier and Type Field Description protected Range
ColumnFamilySkippingIterator. range
Methods in org.apache.accumulo.core.iteratorsImpl.system with parameters of type Range Modifier and Type Method Description void
ColumnFamilySkippingIterator. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
void
DeletingIterator. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
void
EmptyIterator. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
void
LocalityGroupIterator. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
static LocalityGroupIterator.LocalityGroupSeekCache
LocalityGroupIterator. seek(HeapIterator hiter, LocalityGroupIterator.LocalityGroupContext lgContext, Range range, Collection<ByteSequence> columnFamilies, boolean inclusive, LocalityGroupIterator.LocalityGroupSeekCache lgSeekCache)
This seek method will reuse the supplied LocalityGroupSeekCache if it can.void
MapFileIterator. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
void
MultiIterator. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
void
SequenceFileIterator. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
void
SortedMapIterator. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
void
SourceSwitchingIterator. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
void
StatsIterator. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
void
SynchronizedIterator. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
void
TimeSettingIterator. seek(Range range, Collection<ByteSequence> columnFamilies, boolean inclusive)
Constructors in org.apache.accumulo.core.iteratorsImpl.system with parameters of type Range Constructor Description MultiIterator(List<SortedKeyValueIterator<Key,Value>> iters, Range seekFence)
-
Uses of Range in org.apache.accumulo.core.metadata
Method parameters in org.apache.accumulo.core.metadata with type arguments of type Range Modifier and Type Method Description List<TabletLocator.TabletLocation>
MetadataLocationObtainer. lookupTablets(ClientContext context, 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 Modifier and Type Method Description static Range
MetadataSchema.BlipSection. getRange()
static Range
MetadataSchema.DeletesSection. getRange()
static Range
MetadataSchema.ExternalCompactionSection. getRange()
static Range
MetadataSchema.ProblemSection. getRange()
static Range
MetadataSchema.ReplicationSection. getRange()
static Range
MetadataSchema.ReservedSection. getRange()
static Range
MetadataSchema.ScanServerFileReferenceSection. getRange()
static Range
MetadataSchema.TabletsSection. getRange()
static Range
MetadataSchema.TabletsSection. getRange(TableId tableId)
Methods in org.apache.accumulo.core.metadata.schema with parameters of type Range Modifier and Type Method Description TabletsMetadata.Options
TabletsMetadata.Builder. overRange(Range range)
TabletsMetadata.Options
TabletsMetadata.RangeOptions. overRange(Range range)
-
Uses of Range in org.apache.accumulo.core.schema
Methods in org.apache.accumulo.core.schema that return Range Modifier and Type Method Description Range
Section. getRange()
-
Uses of Range in org.apache.accumulo.core.summary
Methods in org.apache.accumulo.core.summary that return Range Modifier and Type Method Description Range
Gatherer.RowRange. toRange()
-
Uses of Range in org.apache.accumulo.core.util
Methods in org.apache.accumulo.core.util with parameters of type Range Modifier and Type Method Description static void
LocalityGroupUtil. seek(FileSKVIterator reader, Range range, String lgName, Map<String,ArrayList<ByteSequence>> localityGroupCF)
This method created to help seek an rfile for a locality group obtained fromRFile.Reader.getLocalityGroupCF()
.
-