Uses of Class
org.apache.accumulo.core.dataImpl.KeyExtent
-
Packages that use KeyExtent Package Description org.apache.accumulo.core.clientImpl org.apache.accumulo.core.clientImpl.bulk org.apache.accumulo.core.clientImpl.mapreduce.lib org.apache.accumulo.core.constraints org.apache.accumulo.core.dataImpl org.apache.accumulo.core.iteratorsImpl.system org.apache.accumulo.core.logging This package exist to provide a central place in Accumulo's source code for important log messages.org.apache.accumulo.core.metadata org.apache.accumulo.core.metadata.schema org.apache.accumulo.core.replication org.apache.accumulo.core.summary org.apache.accumulo.core.tabletserver.log org.apache.accumulo.core.util -
-
Uses of KeyExtent in org.apache.accumulo.core.clientImpl
Fields in org.apache.accumulo.core.clientImpl declared as KeyExtent Modifier and Type Field Description KeyExtent
TabletLocator.TabletLocation. tablet_extent
Methods in org.apache.accumulo.core.clientImpl that return KeyExtent Modifier and Type Method Description KeyExtent
Translator.TKeyExtentTranslator. translate(TKeyExtent input)
Methods in org.apache.accumulo.core.clientImpl that return types with arguments of type KeyExtent Modifier and Type Method Description List<KeyExtent>
TabletLocator.TabletLocations. getLocationless()
Map<KeyExtent,List<T>>
TabletLocator.TabletServerMutations. getMutations()
Methods in org.apache.accumulo.core.clientImpl with parameters of type KeyExtent Modifier and Type Method Description void
TabletLocator.TabletServerMutations. addMutation(KeyExtent ke, T m)
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
RootTabletLocator. invalidateCache(KeyExtent failedExtent)
void
SyncingTabletLocator. invalidateCache(KeyExtent failedExtent)
abstract void
TabletLocator. invalidateCache(KeyExtent failedExtent)
void
TabletLocatorImpl. invalidateCache(KeyExtent failedExtent)
TKeyExtent
Translator.KeyExtentTranslator. translate(KeyExtent input)
static TabletType
TabletType. type(KeyExtent ke)
Method parameters in org.apache.accumulo.core.clientImpl with type arguments of type KeyExtent 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>
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)
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)
void
RootTabletLocator. invalidateCache(Collection<KeyExtent> keySet)
void
SyncingTabletLocator. invalidateCache(Collection<KeyExtent> keySet)
abstract void
TabletLocator. invalidateCache(Collection<KeyExtent> keySet)
void
TabletLocatorImpl. invalidateCache(Collection<KeyExtent> keySet)
List<TabletLocator.TabletLocation>
TabletLocatorImpl.TabletLocationObtainer. lookupTablets(ClientContext context, String tserver, Map<KeyExtent,List<Range>> map, TabletLocator parent)
static TabletType
TabletType. type(Collection<KeyExtent> extents)
Constructors in org.apache.accumulo.core.clientImpl with parameters of type KeyExtent Constructor Description TabletLocation(KeyExtent tablet_extent, String tablet_location, String session)
-
Uses of KeyExtent in org.apache.accumulo.core.clientImpl.bulk
Methods in org.apache.accumulo.core.clientImpl.bulk that return KeyExtent Modifier and Type Method Description KeyExtent
Bulk.Mapping. getKeyExtent(TableId tableId)
KeyExtent
BulkImport.KeyExtentCache. lookup(org.apache.hadoop.io.Text row)
KeyExtent
Bulk.Tablet. toKeyExtent(TableId tableId)
static KeyExtent
Bulk. toKeyExtent(TableId tableId, Bulk.Tablet tablet)
Methods in org.apache.accumulo.core.clientImpl.bulk that return types with arguments of type KeyExtent Modifier and Type Method Description static SortedMap<KeyExtent,Bulk.Files>
BulkImport. computeFileToTabletMappings(org.apache.hadoop.fs.FileSystem fs, TableId tableId, org.apache.hadoop.fs.Path dirPath, Executor executor, ClientContext context)
static Map<KeyExtent,Long>
BulkImport. estimateSizes(AccumuloConfiguration acuConf, org.apache.hadoop.fs.Path mapFile, long fileSize, Collection<KeyExtent> extents, org.apache.hadoop.fs.FileSystem ns, com.google.common.cache.Cache<String,Long> fileLenCache, CryptoService cs)
static List<KeyExtent>
BulkImport. findOverlappingTablets(BulkImport.KeyExtentCache extentCache, FileSKVIterator reader)
static List<KeyExtent>
BulkImport. findOverlappingTablets(ClientContext context, BulkImport.KeyExtentCache extentCache, org.apache.hadoop.fs.Path file, org.apache.hadoop.fs.FileSystem fs, com.google.common.cache.Cache<String,Long> fileLenCache, CryptoService cs)
Map.Entry<KeyExtent,Bulk.Files>
LoadMappingIterator. next()
Methods in org.apache.accumulo.core.clientImpl.bulk with parameters of type KeyExtent Modifier and Type Method Description static Bulk.Tablet
Bulk. toTablet(KeyExtent keyExtent)
Method parameters in org.apache.accumulo.core.clientImpl.bulk with type arguments of type KeyExtent Modifier and Type Method Description static Map<KeyExtent,Long>
BulkImport. estimateSizes(AccumuloConfiguration acuConf, org.apache.hadoop.fs.Path mapFile, long fileSize, Collection<KeyExtent> extents, org.apache.hadoop.fs.FileSystem ns, com.google.common.cache.Cache<String,Long> fileLenCache, CryptoService cs)
static void
BulkSerialize. writeLoadMapping(SortedMap<KeyExtent,Bulk.Files> loadMapping, String sourceDir, BulkSerialize.Output output)
Serialize bulk load mapping to "loadmap.json"Constructors in org.apache.accumulo.core.clientImpl.bulk with parameters of type KeyExtent Constructor Description Mapping(KeyExtent tablet, Bulk.Files files)
-
Uses of KeyExtent in org.apache.accumulo.core.clientImpl.mapreduce.lib
Methods in org.apache.accumulo.core.clientImpl.mapreduce.lib that return types with arguments of type KeyExtent Modifier and Type Method Description static Map<String,Map<KeyExtent,List<Range>>>
InputConfigurator. binOffline(TableId tableId, List<Range> ranges, ClientContext context)
-
Uses of KeyExtent in org.apache.accumulo.core.constraints
Methods in org.apache.accumulo.core.constraints that return KeyExtent Modifier and Type Method Description KeyExtent
Constraint.Environment. getExtent()
Gets the key extent of the environment. -
Uses of KeyExtent in org.apache.accumulo.core.dataImpl
Methods in org.apache.accumulo.core.dataImpl that return KeyExtent Modifier and Type Method Description static KeyExtent
KeyExtent. findContainingExtent(KeyExtent extent, SortedSet<KeyExtent> extents)
Methods in org.apache.accumulo.core.dataImpl that return types with arguments of type KeyExtent Modifier and Type Method Description static SortedSet<KeyExtent>
KeyExtent. findChildren(KeyExtent ke, SortedSet<KeyExtent> tablets)
static Set<KeyExtent>
KeyExtent. findOverlapping(KeyExtent nke, SortedMap<KeyExtent,?> extents)
static Set<KeyExtent>
KeyExtent. findOverlapping(KeyExtent nke, SortedSet<KeyExtent> extents)
Methods in org.apache.accumulo.core.dataImpl with parameters of type KeyExtent Modifier and Type Method Description int
KeyExtent. compareTo(KeyExtent other)
static SortedSet<KeyExtent>
KeyExtent. findChildren(KeyExtent ke, SortedSet<KeyExtent> tablets)
static KeyExtent
KeyExtent. findContainingExtent(KeyExtent extent, SortedSet<KeyExtent> extents)
static Set<KeyExtent>
KeyExtent. findOverlapping(KeyExtent nke, SortedMap<KeyExtent,?> extents)
static Set<KeyExtent>
KeyExtent. findOverlapping(KeyExtent nke, SortedSet<KeyExtent> extents)
static org.apache.hadoop.io.Text
KeyExtent. getMetadataEntry(KeyExtent extent)
static Mutation
KeyExtent. getPrevRowUpdateMutation(KeyExtent ke)
boolean
KeyExtent. isPreviousExtent(KeyExtent prevExtent)
boolean
KeyExtent. overlaps(KeyExtent other)
Method parameters in org.apache.accumulo.core.dataImpl with type arguments of type KeyExtent Modifier and Type Method Description static SortedSet<KeyExtent>
KeyExtent. findChildren(KeyExtent ke, SortedSet<KeyExtent> tablets)
static KeyExtent
KeyExtent. findContainingExtent(KeyExtent extent, SortedSet<KeyExtent> extents)
static Set<KeyExtent>
KeyExtent. findOverlapping(KeyExtent nke, SortedMap<KeyExtent,?> extents)
static Set<KeyExtent>
KeyExtent. findOverlapping(KeyExtent nke, SortedSet<KeyExtent> extents)
Constructors in org.apache.accumulo.core.dataImpl with parameters of type KeyExtent Constructor Description KeyExtent(KeyExtent extent)
TabletIdImpl(KeyExtent ke)
-
Uses of KeyExtent in org.apache.accumulo.core.iteratorsImpl.system
Constructors in org.apache.accumulo.core.iteratorsImpl.system with parameters of type KeyExtent Constructor Description MultiIterator(List<SortedKeyValueIterator<Key,Value>> iters2, KeyExtent extent)
-
Uses of KeyExtent in org.apache.accumulo.core.logging
Methods in org.apache.accumulo.core.logging with parameters of type KeyExtent Modifier and Type Method Description static void
TabletLogger. assigned(KeyExtent extent, Ample.TServer server)
A decision was made to assign a tablet to a tablet server process.static void
TabletLogger. bulkImported(KeyExtent extent, TabletFile file)
static void
TabletLogger. compacted(KeyExtent extent, CompactionJob job, TabletFile output)
static void
TabletLogger. compacting(KeyExtent extent, CompactionJob job, CompactionConfig config)
static void
TabletLogger. flushed(KeyExtent extent, TabletFile newDatafile)
static void
TabletLogger. loaded(KeyExtent extent, Ample.TServer server)
static void
TabletLogger. loading(KeyExtent extent, Ample.TServer server)
A tablet server has received an assignment message from master and queued the tablet for loading.static void
TabletLogger. missassigned(KeyExtent extent, String goalState, String currentState, Ample.TServer future, Ample.TServer current, int walogs)
Called when a tablet's current assignment state does not match the goal state.static void
TabletLogger. recovered(KeyExtent extent, List<LogEntry> logEntries, long numMutation, long numEntries)
static void
TabletLogger. recovering(KeyExtent extent, List<LogEntry> logEntries)
static void
TabletLogger. selected(KeyExtent extent, CompactionKind kind, Collection<? extends TabletFile> inputs)
static void
TabletLogger. split(KeyExtent parent, KeyExtent lowChild, KeyExtent highChild, Ample.TServer server)
static void
TabletLogger. suspended(KeyExtent extent, HostAndPort server, long time, TimeUnit timeUnit, int numWalogs)
static void
TabletLogger. unassigned(KeyExtent extent, int logCount)
static void
TabletLogger. unsuspended(KeyExtent extent)
static void
TabletLogger. walRefsChanged(KeyExtent extent, Collection<String> refsSupplier)
Called when the set of write ahead logs a tablet currently has unflushed data in changes. -
Uses of KeyExtent in org.apache.accumulo.core.metadata
Fields in org.apache.accumulo.core.metadata declared as KeyExtent Modifier and Type Field Description static KeyExtent
RootTable. EXTENT
static KeyExtent
RootTable. OLD_EXTENT
Method parameters in org.apache.accumulo.core.metadata with type arguments of type KeyExtent Modifier and Type Method Description abstract void
MetadataServicer. getTabletLocations(SortedMap<KeyExtent,String> tablets)
Populate the provided data structure with the known tablets for the table being servicedList<TabletLocator.TabletLocation>
MetadataLocationObtainer. lookupTablets(ClientContext context, String tserver, Map<KeyExtent,List<Range>> tabletsRanges, TabletLocator parent)
-
Uses of KeyExtent in org.apache.accumulo.core.metadata.schema
Methods in org.apache.accumulo.core.metadata.schema that return KeyExtent Modifier and Type Method Description KeyExtent
TabletMetadata. getExtent()
Methods in org.apache.accumulo.core.metadata.schema with parameters of type KeyExtent Modifier and Type Method Description TabletsMetadata.Options
TabletsMetadata.TableOptions. forTablet(KeyExtent extent)
Get the tablet metadata for this extents end row.default Ample.TabletMutator
Ample. mutateTablet(KeyExtent extent)
Initiates mutating a single tablets persistent metadata.Ample.TabletMutator
Ample.TabletsMutator. mutateTablet(KeyExtent extent)
TabletMetadata
Ample. readTablet(KeyExtent extent, TabletMetadata.ColumnType... colsToFetch)
Read a single tablets metadata.TabletMetadata
AmpleImpl. readTablet(KeyExtent extent, TabletMetadata.ColumnType... colsToFetch)
-
Uses of KeyExtent in org.apache.accumulo.core.replication
Methods in org.apache.accumulo.core.replication with parameters of type KeyExtent Modifier and Type Method Description static boolean
ReplicationConfigurationUtil. isEnabled(KeyExtent extent, AccumuloConfiguration conf)
Determines if the replication is enabled for the givenKeyExtent
-
Uses of KeyExtent in org.apache.accumulo.core.summary
Constructors in org.apache.accumulo.core.summary with parameters of type KeyExtent Constructor Description RowRange(KeyExtent ke)
-
Uses of KeyExtent in org.apache.accumulo.core.tabletserver.log
Fields in org.apache.accumulo.core.tabletserver.log declared as KeyExtent Modifier and Type Field Description KeyExtent
LogEntry. extent
Constructors in org.apache.accumulo.core.tabletserver.log with parameters of type KeyExtent Constructor Description LogEntry(KeyExtent extent, long timestamp, String server, String filename)
-
Uses of KeyExtent in org.apache.accumulo.core.util
Constructors in org.apache.accumulo.core.util with parameters of type KeyExtent Constructor Description Size(KeyExtent extent, long size)
-