Modifier and Type | Field and Description |
---|---|
static KeyExtent |
Constants.ROOT_TABLET_EXTENT |
Modifier and Type | Method and Description |
---|---|
List<KeyExtent> |
MutationsRejectedException.getAuthorizationFailures()
Deprecated.
since 1.5, see
MutationsRejectedException.getAuthorizationFailuresMap() |
Map<KeyExtent,Set<SecurityErrorCode>> |
MutationsRejectedException.getAuthorizationFailuresMap() |
Constructor and Description |
---|
MutationsRejectedException(List<ConstraintViolationSummary> cvsList,
HashMap<KeyExtent,Set<SecurityErrorCode>> hashMap,
Collection<String> serverSideErrors,
int unknownErrors,
Throwable cause) |
Modifier and Type | Method and Description |
---|---|
KeyExtent |
ActiveScan.getExtent() |
KeyExtent |
ActiveCompaction.getExtent() |
Modifier and Type | Field and Description |
---|---|
KeyExtent |
TabletLocator.TabletLocation.tablet_extent |
Modifier and Type | Method and Description |
---|---|
KeyExtent |
Translator.TKeyExtentTranslator.translate(TKeyExtent input) |
Modifier and Type | Method and Description |
---|---|
List<KeyExtent> |
TabletLocator.TabletLocations.getLocationless() |
Map<KeyExtent,List<Mutation>> |
TabletLocator.TabletServerMutations.getMutations() |
Modifier and Type | Method and Description |
---|---|
void |
TabletLocator.TabletServerMutations.addMutation(KeyExtent ke,
Mutation m) |
protected static void |
TabletLocatorImpl.addRange(Map<String,Map<KeyExtent,List<Range>>> binnedRanges,
String location,
KeyExtent ke,
Range range) |
void |
RootTabletLocator.invalidateCache(KeyExtent failedExtent) |
void |
TabletLocatorImpl.invalidateCache(KeyExtent failedExtent) |
abstract void |
TabletLocator.invalidateCache(KeyExtent failedExtent) |
void |
TimeoutTabletLocator.invalidateCache(KeyExtent failedExtent) |
TKeyExtent |
Translator.KeyExtentTranslator.translate(KeyExtent input) |
static TabletType |
TabletType.type(KeyExtent ke) |
Modifier and Type | Method and Description |
---|---|
protected static void |
TabletLocatorImpl.addRange(Map<String,Map<KeyExtent,List<Range>>> binnedRanges,
String location,
KeyExtent ke,
Range range) |
List<Range> |
RootTabletLocator.binRanges(List<Range> ranges,
Map<String,Map<KeyExtent,List<Range>>> binnedRanges,
TCredentials credentials) |
List<Range> |
TabletLocatorImpl.binRanges(List<Range> ranges,
Map<String,Map<KeyExtent,List<Range>>> binnedRanges,
TCredentials credentials) |
abstract List<Range> |
TabletLocator.binRanges(List<Range> ranges,
Map<String,Map<KeyExtent,List<Range>>> binnedRanges,
TCredentials credentials) |
List<Range> |
TimeoutTabletLocator.binRanges(List<Range> ranges,
Map<String,Map<KeyExtent,List<Range>>> binnedRanges,
TCredentials credentials) |
void |
RootTabletLocator.invalidateCache(Collection<KeyExtent> keySet) |
void |
TabletLocatorImpl.invalidateCache(Collection<KeyExtent> keySet) |
abstract void |
TabletLocator.invalidateCache(Collection<KeyExtent> keySet) |
void |
TimeoutTabletLocator.invalidateCache(Collection<KeyExtent> keySet) |
List<TabletLocator.TabletLocation> |
TabletLocatorImpl.TabletLocationObtainer.lookupTablets(String tserver,
Map<KeyExtent,List<Range>> map,
TabletLocator parent,
TCredentials credentials) |
List<TabletLocator.TabletLocation> |
MetadataLocationObtainer.lookupTablets(String tserver,
Map<KeyExtent,List<Range>> tabletsRanges,
TabletLocator parent,
TCredentials credentials) |
static TabletType |
TabletType.type(Collection<KeyExtent> extents) |
Constructor and Description |
---|
TabletLocator.TabletLocation(KeyExtent tablet_extent,
String tablet_location) |
Constructor and Description |
---|
TabletLocator.TabletLocations(List<TabletLocator.TabletLocation> locations,
List<KeyExtent> locationless) |
Modifier and Type | Method and Description |
---|---|
void |
MockTabletLocator.invalidateCache(KeyExtent failedExtent) |
Modifier and Type | Method and Description |
---|---|
List<Range> |
MockTabletLocator.binRanges(List<Range> ranges,
Map<String,Map<KeyExtent,List<Range>>> binnedRanges,
TCredentials credentials) |
void |
MockTabletLocator.invalidateCache(Collection<KeyExtent> keySet) |
Modifier and Type | Method and Description |
---|---|
KeyExtent |
Constraint.Environment.getExtent() |
Modifier and Type | Method and Description |
---|---|
static KeyExtent |
KeyExtent.findContainingExtent(KeyExtent extent,
SortedSet<KeyExtent> extents) |
Modifier and Type | Method and Description |
---|---|
static SortedSet<KeyExtent> |
KeyExtent.findChildren(KeyExtent ke,
SortedSet<KeyExtent> tablets) |
static Set<KeyExtent> |
KeyExtent.findOverlapping(KeyExtent nke,
SortedMap<KeyExtent,? extends Object> extents) |
static Set<KeyExtent> |
KeyExtent.findOverlapping(KeyExtent nke,
SortedSet<KeyExtent> extents) |
static Collection<KeyExtent> |
KeyExtent.getKeyExtentsForRange(org.apache.hadoop.io.Text startRow,
org.apache.hadoop.io.Text endRow,
Set<KeyExtent> kes)
Empty start or end rows tell the method there are no start or end rows, and to use all the keyextents that are before the end row if no start row etc.
|
Modifier and Type | Method and Description |
---|---|
int |
KeyExtent.compareTo(KeyExtent other)
Compares extents based on rows
|
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,? extends Object> 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) |
Modifier and Type | Method and 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,? extends Object> extents) |
static Set<KeyExtent> |
KeyExtent.findOverlapping(KeyExtent nke,
SortedSet<KeyExtent> extents) |
static Collection<KeyExtent> |
KeyExtent.getKeyExtentsForRange(org.apache.hadoop.io.Text startRow,
org.apache.hadoop.io.Text endRow,
Set<KeyExtent> kes)
Empty start or end rows tell the method there are no start or end rows, and to use all the keyextents that are before the end row if no start row etc.
|
Constructor and Description |
---|
KeyExtent(KeyExtent extent) |
Modifier and Type | Method and Description |
---|---|
static Map<KeyExtent,Long> |
FileUtil.estimateSizes(AccumuloConfiguration acuConf,
org.apache.hadoop.fs.Path mapFile,
long fileSize,
List<KeyExtent> extents,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs) |
Modifier and Type | Method and Description |
---|---|
static Map<KeyExtent,Long> |
FileUtil.estimateSizes(AccumuloConfiguration acuConf,
org.apache.hadoop.fs.Path mapFile,
long fileSize,
List<KeyExtent> extents,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs) |
Modifier and Type | Method and Description |
---|---|
static <K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable> |
IteratorUtil.loadIterators(IteratorUtil.IteratorScope scope,
SortedKeyValueIterator<K,V> source,
KeyExtent extent,
AccumuloConfiguration conf,
IteratorEnvironment env) |
static <K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable> |
IteratorUtil.loadIterators(IteratorUtil.IteratorScope scope,
SortedKeyValueIterator<K,V> source,
KeyExtent extent,
AccumuloConfiguration conf,
List<IteratorSetting> iterators,
IteratorEnvironment env) |
static <K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable> |
IteratorUtil.loadIterators(IteratorUtil.IteratorScope scope,
SortedKeyValueIterator<K,V> source,
KeyExtent extent,
AccumuloConfiguration conf,
List<IterInfo> ssiList,
Map<String,Map<String,String>> ssio,
IteratorEnvironment env) |
static <K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable> |
IteratorUtil.loadIterators(IteratorUtil.IteratorScope scope,
SortedKeyValueIterator<K,V> source,
KeyExtent extent,
AccumuloConfiguration conf,
List<IterInfo> ssiList,
Map<String,Map<String,String>> ssio,
IteratorEnvironment env,
boolean useAccumuloClassLoader) |
Constructor and Description |
---|
MultiIterator(List<SortedKeyValueIterator<Key,Value>> iters2,
KeyExtent extent) |
Modifier and Type | Field and Description |
---|---|
KeyExtent |
LogEntry.extent |
Modifier and Type | Method and Description |
---|---|
static Pair<SortedMap<KeyExtent,org.apache.hadoop.io.Text>,List<KeyExtent>> |
MetadataTable.getMetadataLocationEntries(SortedMap<Key,Value> entries) |
static Pair<SortedMap<KeyExtent,org.apache.hadoop.io.Text>,List<KeyExtent>> |
MetadataTable.getMetadataLocationEntries(SortedMap<Key,Value> entries) |
Modifier and Type | Method and Description |
---|---|
static boolean |
MetadataTable.isContiguousRange(KeyExtent ke,
SortedSet<KeyExtent> children) |
Modifier and Type | Method and Description |
---|---|
static void |
MetadataTable.getEntries(Instance instance,
TCredentials credentials,
String table,
boolean isTid,
Map<KeyExtent,String> locations,
SortedSet<KeyExtent> tablets) |
static void |
MetadataTable.getEntries(Instance instance,
TCredentials credentials,
String table,
boolean isTid,
Map<KeyExtent,String> locations,
SortedSet<KeyExtent> tablets) |
static boolean |
MetadataTable.isContiguousRange(KeyExtent ke,
SortedSet<KeyExtent> children) |
static void |
MetadataTable.validateEntries(String tableId,
SortedSet<KeyExtent> tablets) |
Constructor and Description |
---|
Merge.Size(KeyExtent extent,
long size) |
Modifier and Type | Method and Description |
---|---|
static List<TabletLocator.TabletLocation> |
BulkImporter.findOverlappingTablets(AccumuloConfiguration acuConf,
org.apache.hadoop.fs.FileSystem fs,
TabletLocator locator,
org.apache.hadoop.fs.Path file,
KeyExtent failed,
TCredentials credentials) |
Modifier and Type | Method and Description |
---|---|
TableConfiguration |
ServerConfiguration.getTableConfiguration(KeyExtent extent) |
Modifier and Type | Field and Description |
---|---|
KeyExtent |
LogFileKey.tablet |
Modifier and Type | Method and Description |
---|---|
static void |
LogReader.printLogEvent(LogFileKey key,
LogFileValue value,
org.apache.hadoop.io.Text row,
Matcher rowMatcher,
KeyExtent ke,
Set<Integer> tabletIds,
int maxMutations) |
Modifier and Type | Method and Description |
---|---|
Collection<KeyExtent> |
Master.migrations() |
Modifier and Type | Method and Description |
---|---|
void |
LiveTServerSet.TServerConnection.assignTablet(ZooLock lock,
KeyExtent extent) |
void |
LiveTServerSet.TServerConnection.chop(ZooLock lock,
KeyExtent extent) |
void |
LiveTServerSet.TServerConnection.flushTablet(ZooLock lock,
KeyExtent extent) |
MergeInfo |
Master.getMergeInfo(KeyExtent tablet) |
void |
LiveTServerSet.TServerConnection.splitTablet(ZooLock lock,
KeyExtent extent,
org.apache.hadoop.io.Text splitPoint) |
void |
LiveTServerSet.TServerConnection.unloadTablet(ZooLock lock,
KeyExtent extent,
boolean save) |
Modifier and Type | Field and Description |
---|---|
Set<KeyExtent> |
TabletBalancer.OutstandingMigrations.migrations |
Modifier and Type | Method and Description |
---|---|
TServerInstance |
DefaultLoadBalancer.getAssignment(SortedMap<TServerInstance,TabletServerStatus> locations,
KeyExtent extent,
TServerInstance last) |
Modifier and Type | Method and Description |
---|---|
boolean |
RecoveryManager.recoverLogs(KeyExtent extent,
Collection<Collection<String>> walogs) |
Modifier and Type | Field and Description |
---|---|
KeyExtent |
TabletLocationState.extent |
KeyExtent |
Assignment.tablet |
KeyExtent |
TabletMigration.tablet |
Modifier and Type | Method and Description |
---|---|
KeyExtent |
MergeInfo.getRange() |
Modifier and Type | Method and Description |
---|---|
Collection<KeyExtent> |
CurrentState.migrations() |
Modifier and Type | Method and Description |
---|---|
boolean |
MergeInfo.needsToBeChopped(KeyExtent extent) |
boolean |
MergeInfo.overlaps(KeyExtent extent) |
void |
MergeStats.update(KeyExtent ke,
TabletState state,
boolean chopped,
boolean hasWALs) |
Modifier and Type | Method and Description |
---|---|
static void |
TabletStateChangeIterator.setMigrations(IteratorSetting cfg,
Collection<KeyExtent> migrations) |
Constructor and Description |
---|
Assignment(KeyExtent tablet,
TServerInstance server) |
MergeInfo(KeyExtent range,
MergeInfo.Operation op) |
TabletLocationState(KeyExtent extent,
TServerInstance future,
TServerInstance current,
TServerInstance last,
Collection<Collection<String>> walogs,
boolean chopped) |
TabletMigration(KeyExtent extent,
TServerInstance before,
TServerInstance after) |
Modifier and Type | Field and Description |
---|---|
protected KeyExtent |
Compactor.extent |
Modifier and Type | Field and Description |
---|---|
List<KeyExtent> |
MemoryManagementActions.tabletsToMinorCompact |
Modifier and Type | Method and Description |
---|---|
KeyExtent |
TabletState.getExtent() |
KeyExtent |
Tablet.getExtent()
Returns a KeyExtent object representing this tablet's key range.
|
KeyExtent |
Tablet.CommitSession.getExtent() |
Modifier and Type | Method and Description |
---|---|
TreeMap<KeyExtent,org.apache.accumulo.server.tabletserver.Tablet.SplitInfo> |
Tablet.split(byte[] sp) |
static Pair<org.apache.hadoop.io.Text,KeyExtent> |
TabletServer.verifyTabletInformation(KeyExtent extent,
TServerInstance instance,
SortedMap<Key,Value> tabletsKeyValues,
String clientAddress,
ZooLock lock) |
Modifier and Type | Method and Description |
---|---|
void |
TabletServer.addLoggersToMetadata(List<DfsLogger> logs,
KeyExtent extent,
int id) |
void |
TabletServerResourceManager.addMigration(KeyExtent tablet,
Runnable migrationHandler) |
int |
TabletServer.createLogId(KeyExtent tablet) |
void |
TabletServerResourceManager.executeMajorCompaction(KeyExtent tablet,
Runnable compactionTask) |
void |
TabletServerResourceManager.TabletResourceManager.executeMajorCompaction(KeyExtent tablet,
Runnable compactionTask) |
void |
TabletServerResourceManager.executeReadAhead(KeyExtent tablet,
Runnable task) |
void |
TabletServerResourceManager.executeSplit(KeyExtent tablet,
Runnable splitTask) |
TableConfiguration |
TabletServer.getTableConfiguration(KeyExtent extent) |
FileManager.ScanFileManager |
FileManager.newScanFileManager(KeyExtent tablet) |
void |
LargestFirstMemoryManager.tabletClosed(KeyExtent extent) |
void |
MemoryManager.tabletClosed(KeyExtent extent)
This method is called when a tablet is closed.
|
static Pair<org.apache.hadoop.io.Text,KeyExtent> |
TabletServer.verifyTabletInformation(KeyExtent extent,
TServerInstance instance,
SortedMap<Key,Value> tabletsKeyValues,
String clientAddress,
ZooLock lock) |
Constructor and Description |
---|
Tablet(TabletServer tabletServer,
org.apache.hadoop.io.Text location,
KeyExtent extent,
TabletServerResourceManager.TabletResourceManager trm,
SortedMap<Key,Value> tabletsKeyValues) |
Tablet(TabletServer tabletServer,
org.apache.hadoop.io.Text location,
KeyExtent extent,
TabletServerResourceManager.TabletResourceManager trm,
SortedMap<String,MetadataTable.DataFileValue> datafiles,
String time,
long initFlushID,
long initCompactID) |
Modifier and Type | Method and Description |
---|---|
void |
DfsLogger.defineTablet(int seq,
int tid,
KeyExtent tablet) |
void |
SortedLogRecovery.recover(KeyExtent extent,
List<String> recoveryLogs,
Set<String> tabletFiles,
MutationReceiver mr) |
Constructor and Description |
---|
SplitReportMessage(KeyExtent old_extent,
KeyExtent ne1,
org.apache.hadoop.io.Text np1,
KeyExtent ne2,
org.apache.hadoop.io.Text np2) |
SplitReportMessage(KeyExtent old_extent,
Map<KeyExtent,org.apache.hadoop.io.Text> newExtents) |
TabletStatusMessage(TabletLoadState status,
KeyExtent extent) |
Constructor and Description |
---|
SplitReportMessage(KeyExtent old_extent,
Map<KeyExtent,org.apache.hadoop.io.Text> newExtents) |
Modifier and Type | Field and Description |
---|---|
KeyExtent |
MetadataTable.LogEntry.extent |
Modifier and Type | Method and Description |
---|---|
static KeyExtent |
MetadataTable.fixSplit(org.apache.hadoop.io.Text metadataEntry,
SortedMap<ColumnFQ,Value> columns,
TServerInstance tserver,
TCredentials credentials,
ZooLock lock) |
Modifier and Type | Method and Description |
---|---|
static SortedMap<KeyExtent,org.apache.hadoop.io.Text> |
MetadataTable.getMetadataDirectoryEntries(SortedMap<Key,Value> entries)
convenience method for reading entries from the metadata table
|
Modifier and Type | Method and Description |
---|---|
static void |
MetadataTable.addDeleteEntries(KeyExtent extent,
Set<String> datafilesToDelete,
TCredentials credentials) |
static void |
MetadataTable.addNewTablet(KeyExtent extent,
String path,
TServerInstance location,
Map<String,MetadataTable.DataFileValue> datafileSizes,
Map<String,Long> bulkLoadedFiles,
TCredentials credentials,
String time,
long lastFlushID,
long lastCompactID,
ZooLock zooLock) |
static void |
MetadataTable.addTablet(KeyExtent extent,
String path,
TCredentials credentials,
char timeType,
ZooLock lock) |
static void |
MetadataTable.chopped(KeyExtent extent,
ZooLock zooLock) |
static void |
MetadataTable.finishSplit(KeyExtent extent,
Map<String,MetadataTable.DataFileValue> datafileSizes,
List<String> highDatafilesToRemove,
TCredentials credentials,
ZooLock zooLock) |
static List<String> |
MetadataTable.getBulkFilesLoaded(Connector conn,
KeyExtent extent,
long tid) |
static Map<String,Long> |
MetadataTable.getBulkFilesLoaded(TCredentials credentials,
KeyExtent extent) |
static SortedMap<String,MetadataTable.DataFileValue> |
MetadataTable.getDataFileSizes(KeyExtent extent,
TCredentials credentials) |
static Pair<List<MetadataTable.LogEntry>,SortedMap<String,MetadataTable.DataFileValue>> |
MetadataTable.getFileAndLogEntries(TCredentials credentials,
KeyExtent extent) |
static List<MetadataTable.LogEntry> |
MetadataTable.getLogEntries(TCredentials credentials,
KeyExtent extent) |
static void |
MetadataTable.removeScanFiles(KeyExtent extent,
Set<String> scanFiles,
TCredentials credentials,
ZooLock zooLock) |
static void |
MetadataTable.removeUnusedWALEntries(KeyExtent extent,
List<MetadataTable.LogEntry> logEntries,
ZooLock zooLock) |
static void |
MetadataTable.replaceDatafiles(KeyExtent extent,
Set<String> datafilesToDelete,
Set<String> scanFiles,
String path,
Long compactionId,
MetadataTable.DataFileValue size,
TCredentials credentials,
String address,
TServerInstance lastLocation,
ZooLock zooLock) |
static void |
MetadataTable.replaceDatafiles(KeyExtent extent,
Set<String> datafilesToDelete,
Set<String> scanFiles,
String path,
Long compactionId,
MetadataTable.DataFileValue size,
TCredentials credentials,
String address,
TServerInstance lastLocation,
ZooLock zooLock,
boolean insertDeleteFlags) |
static void |
MetadataTable.splitTablet(KeyExtent extent,
org.apache.hadoop.io.Text oldPrevEndRow,
double splitRatio,
TCredentials credentials,
ZooLock zooLock) |
static void |
MetadataTable.updateTabletCompactID(KeyExtent extent,
long compactID,
TCredentials credentials,
ZooLock zooLock) |
static void |
MetadataTable.updateTabletDataFile(KeyExtent extent,
String path,
String mergeFile,
MetadataTable.DataFileValue dfv,
String time,
TCredentials credentials,
Set<String> filesInUseByScans,
String address,
ZooLock zooLock,
Set<String> unusedWalLogs,
TServerInstance lastLocation,
long flushId)
new data file update function adds one data file to a tablet's list
|
static void |
MetadataTable.updateTabletDataFile(long tid,
KeyExtent extent,
Map<String,MetadataTable.DataFileValue> estSizes,
String time,
TCredentials credentials,
ZooLock zooLock) |
static void |
MetadataTable.updateTabletFlushID(KeyExtent extent,
long flushID,
TCredentials credentials,
ZooLock zooLock) |
static void |
MetadataTable.updateTabletPrevEndRow(KeyExtent extent,
TCredentials credentials) |
Modifier and Type | Method and Description |
---|---|
static void |
CheckForMetadataProblems.checkTable(String tablename,
TreeSet<KeyExtent> tablets,
org.apache.accumulo.server.util.CheckForMetadataProblems.Opts opts) |
Copyright © 2015 Apache Accumulo Project. All Rights Reserved.