|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
Uses of KeyExtent in org.apache.accumulo.core |
---|
Fields in org.apache.accumulo.core declared as KeyExtent | |
---|---|
static KeyExtent |
Constants.ROOT_TABLET_EXTENT
|
Uses of KeyExtent in org.apache.accumulo.core.client |
---|
Methods in org.apache.accumulo.core.client that return types with arguments of type KeyExtent | |
---|---|
java.util.List<KeyExtent> |
MutationsRejectedException.getAuthorizationFailures()
|
Constructor parameters in org.apache.accumulo.core.client with type arguments of type KeyExtent | |
---|---|
MutationsRejectedException(java.util.List<ConstraintViolationSummary> cvsList,
java.util.ArrayList<KeyExtent> af,
java.util.Collection<java.lang.String> serverSideErrors,
int unknownErrors)
|
Uses of KeyExtent in org.apache.accumulo.core.client.admin |
---|
Methods in org.apache.accumulo.core.client.admin that return KeyExtent | |
---|---|
KeyExtent |
ActiveScan.getExtent()
|
Uses of KeyExtent in org.apache.accumulo.core.client.impl |
---|
Fields in org.apache.accumulo.core.client.impl declared as KeyExtent | |
---|---|
KeyExtent |
TabletLocator.TabletLocation.tablet_extent
|
Methods in org.apache.accumulo.core.client.impl that return KeyExtent | |
---|---|
KeyExtent |
Translator.TKeyExtentTranslator.translate(TKeyExtent input)
|
Methods in org.apache.accumulo.core.client.impl that return types with arguments of type KeyExtent | |
---|---|
java.util.Map<KeyExtent,java.util.List<Mutation>> |
TabletLocator.TabletServerMutations.getMutations()
|
Methods in org.apache.accumulo.core.client.impl with parameters of type KeyExtent | |
---|---|
void |
TabletLocator.TabletServerMutations.addMutation(KeyExtent ke,
Mutation m)
|
protected static void |
TabletLocatorImpl.addRange(java.util.Map<java.lang.String,java.util.Map<KeyExtent,java.util.List<Range>>> binnedRanges,
java.lang.String location,
KeyExtent ke,
Range range)
|
static boolean |
ThriftScanner.getBatchFromServer(AuthInfo credentials,
org.apache.hadoop.io.Text startRow,
KeyExtent extent,
java.lang.String server,
java.util.SortedMap<Key,Value> results,
java.util.SortedSet<Column> fetchedColumns,
boolean skipStartKey,
int size,
Authorizations authorizations,
boolean retry,
AccumuloConfiguration conf)
|
void |
TabletLocatorImpl.invalidateCache(KeyExtent failedExtent)
|
void |
RootTabletLocator.invalidateCache(KeyExtent failedExtent)
|
abstract void |
TabletLocator.invalidateCache(KeyExtent failedExtent)
|
TKeyExtent |
Translator.KeyExtentTranslator.translate(KeyExtent input)
|
static TabletType |
TabletType.type(KeyExtent ke)
|
Method parameters in org.apache.accumulo.core.client.impl with type arguments of type KeyExtent | |
---|---|
protected static void |
TabletLocatorImpl.addRange(java.util.Map<java.lang.String,java.util.Map<KeyExtent,java.util.List<Range>>> binnedRanges,
java.lang.String location,
KeyExtent ke,
Range range)
|
java.util.List<Range> |
TabletLocatorImpl.binRanges(java.util.List<Range> ranges,
java.util.Map<java.lang.String,java.util.Map<KeyExtent,java.util.List<Range>>> binnedRanges)
|
java.util.List<Range> |
RootTabletLocator.binRanges(java.util.List<Range> ranges,
java.util.Map<java.lang.String,java.util.Map<KeyExtent,java.util.List<Range>>> binnedRanges)
|
abstract java.util.List<Range> |
TabletLocator.binRanges(java.util.List<Range> ranges,
java.util.Map<java.lang.String,java.util.Map<KeyExtent,java.util.List<Range>>> binnedRanges)
|
void |
TabletLocatorImpl.invalidateCache(java.util.Collection<KeyExtent> keySet)
|
void |
RootTabletLocator.invalidateCache(java.util.Collection<KeyExtent> keySet)
|
abstract void |
TabletLocator.invalidateCache(java.util.Collection<KeyExtent> keySet)
|
java.util.List<TabletLocator.TabletLocation> |
MetadataLocationObtainer.lookupTablets(java.lang.String tserver,
java.util.Map<KeyExtent,java.util.List<Range>> tabletsRanges,
TabletLocator parent)
|
java.util.List<TabletLocator.TabletLocation> |
TabletLocatorImpl.TabletLocationObtainer.lookupTablets(java.lang.String tserver,
java.util.Map<KeyExtent,java.util.List<Range>> map,
TabletLocator parent)
|
static TabletType |
TabletType.type(java.util.Collection<KeyExtent> extents)
|
Constructors in org.apache.accumulo.core.client.impl with parameters of type KeyExtent | |
---|---|
TabletLocator.TabletLocation(KeyExtent tablet_extent,
java.lang.String tablet_location)
|
Uses of KeyExtent in org.apache.accumulo.core.client.mock |
---|
Methods in org.apache.accumulo.core.client.mock with parameters of type KeyExtent | |
---|---|
void |
MockTabletLocator.invalidateCache(KeyExtent failedExtent)
|
Method parameters in org.apache.accumulo.core.client.mock with type arguments of type KeyExtent | |
---|---|
java.util.List<Range> |
MockTabletLocator.binRanges(java.util.List<Range> ranges,
java.util.Map<java.lang.String,java.util.Map<KeyExtent,java.util.List<Range>>> binnedRanges)
|
void |
MockTabletLocator.invalidateCache(java.util.Collection<KeyExtent> keySet)
|
Uses of KeyExtent in org.apache.accumulo.core.data |
---|
Methods in org.apache.accumulo.core.data that return KeyExtent | |
---|---|
static KeyExtent |
KeyExtent.findContainingExtent(KeyExtent extent,
java.util.SortedSet<KeyExtent> extents)
|
Methods in org.apache.accumulo.core.data that return types with arguments of type KeyExtent | |
---|---|
static java.util.SortedSet<KeyExtent> |
KeyExtent.findChildren(KeyExtent ke,
java.util.SortedSet<KeyExtent> tablets)
|
static java.util.Set<KeyExtent> |
KeyExtent.findOverlapping(KeyExtent nke,
java.util.SortedMap<KeyExtent,? extends java.lang.Object> extents)
|
static java.util.Set<KeyExtent> |
KeyExtent.findOverlapping(KeyExtent nke,
java.util.SortedSet<KeyExtent> extents)
|
static java.util.Collection<KeyExtent> |
KeyExtent.getKeyExtentsForRange(org.apache.hadoop.io.Text startRow,
org.apache.hadoop.io.Text endRow,
java.util.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. |
Methods in org.apache.accumulo.core.data with parameters of type KeyExtent | |
---|---|
int |
KeyExtent.compareTo(KeyExtent other)
Compares extents based on rows |
static java.util.SortedSet<KeyExtent> |
KeyExtent.findChildren(KeyExtent ke,
java.util.SortedSet<KeyExtent> tablets)
|
static KeyExtent |
KeyExtent.findContainingExtent(KeyExtent extent,
java.util.SortedSet<KeyExtent> extents)
|
static java.util.Set<KeyExtent> |
KeyExtent.findOverlapping(KeyExtent nke,
java.util.SortedMap<KeyExtent,? extends java.lang.Object> extents)
|
static java.util.Set<KeyExtent> |
KeyExtent.findOverlapping(KeyExtent nke,
java.util.SortedSet<KeyExtent> extents)
|
static org.apache.hadoop.io.Text |
KeyExtent.getMetadataEntry(KeyExtent extent)
|
static Mutation |
KeyExtent.getPrevRowUpdateMutation(KeyExtent ke)
|
Method parameters in org.apache.accumulo.core.data with type arguments of type KeyExtent | |
---|---|
static java.util.SortedSet<KeyExtent> |
KeyExtent.findChildren(KeyExtent ke,
java.util.SortedSet<KeyExtent> tablets)
|
static KeyExtent |
KeyExtent.findContainingExtent(KeyExtent extent,
java.util.SortedSet<KeyExtent> extents)
|
static java.util.Set<KeyExtent> |
KeyExtent.findOverlapping(KeyExtent nke,
java.util.SortedMap<KeyExtent,? extends java.lang.Object> extents)
|
static java.util.Set<KeyExtent> |
KeyExtent.findOverlapping(KeyExtent nke,
java.util.SortedSet<KeyExtent> extents)
|
static java.util.Collection<KeyExtent> |
KeyExtent.getKeyExtentsForRange(org.apache.hadoop.io.Text startRow,
org.apache.hadoop.io.Text endRow,
java.util.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. |
Constructors in org.apache.accumulo.core.data with parameters of type KeyExtent | |
---|---|
KeyExtent(KeyExtent extent)
|
Uses of KeyExtent in org.apache.accumulo.core.file |
---|
Methods in org.apache.accumulo.core.file that return types with arguments of type KeyExtent | |
---|---|
static java.util.Map<KeyExtent,java.lang.Long> |
FileUtil.estimateSizes(org.apache.hadoop.fs.Path mapFile,
long fileSize,
java.util.List<KeyExtent> extents,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs)
|
Method parameters in org.apache.accumulo.core.file with type arguments of type KeyExtent | |
---|---|
static java.util.Map<KeyExtent,java.lang.Long> |
FileUtil.estimateSizes(org.apache.hadoop.fs.Path mapFile,
long fileSize,
java.util.List<KeyExtent> extents,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs)
|
Uses of KeyExtent in org.apache.accumulo.core.iterators |
---|
Methods in org.apache.accumulo.core.iterators with parameters of type KeyExtent | ||
---|---|---|
static
|
IteratorUtil.loadIterators(IteratorUtil.IteratorScope scope,
SortedKeyValueIterator<K,V> source,
KeyExtent extent,
AccumuloConfiguration conf,
IteratorEnvironment env)
|
|
static
|
IteratorUtil.loadIterators(IteratorUtil.IteratorScope scope,
SortedKeyValueIterator<K,V> source,
KeyExtent extent,
AccumuloConfiguration conf,
java.util.List<IterInfo> ssiList,
java.util.Map<java.lang.String,java.util.Map<java.lang.String,java.lang.String>> ssio,
IteratorEnvironment env)
|
Constructors in org.apache.accumulo.core.iterators with parameters of type KeyExtent | |
---|---|
MultiIterator(java.util.List<SortedKeyValueIterator<Key,Value>> iters2,
KeyExtent extent)
|
|
ScanCache(long maxSize,
KeyExtent extent)
|
Uses of KeyExtent in org.apache.accumulo.core.tabletserver.log |
---|
Fields in org.apache.accumulo.core.tabletserver.log declared as KeyExtent | |
---|---|
KeyExtent |
LogEntry.extent
|
Uses of KeyExtent in org.apache.accumulo.core.util |
---|
Methods in org.apache.accumulo.core.util that return types with arguments of type KeyExtent | |
---|---|
static java.util.SortedMap<KeyExtent,org.apache.hadoop.io.Text> |
MetadataTable.getMetadataLocationEntries(java.util.SortedMap<Key,Value> entries)
|
Methods in org.apache.accumulo.core.util with parameters of type KeyExtent | |
---|---|
static void |
MetadataTable.getTabletAndPrevTabletKeyValues(Instance instance,
java.util.SortedMap<Key,Value> tkv,
KeyExtent ke,
java.util.List<ColumnFQ> columns,
AuthInfo credentials)
|
static java.util.SortedMap<org.apache.hadoop.io.Text,java.util.SortedMap<ColumnFQ,Value>> |
MetadataTable.getTabletEntries(Instance instance,
KeyExtent ke,
java.util.List<ColumnFQ> columns,
AuthInfo credentials)
|
static boolean |
MetadataTable.isContiguousRange(KeyExtent ke,
java.util.SortedSet<KeyExtent> children)
|
Method parameters in org.apache.accumulo.core.util with type arguments of type KeyExtent | |
---|---|
static void |
MetadataTable.getEntries(Instance instance,
AuthInfo credentials,
java.lang.String table,
boolean isTid,
java.util.Map<KeyExtent,java.lang.String> locations,
java.util.SortedSet<KeyExtent> tablets)
|
static void |
MetadataTable.getEntries(Instance instance,
AuthInfo credentials,
java.lang.String table,
boolean isTid,
java.util.Map<KeyExtent,java.lang.String> locations,
java.util.SortedSet<KeyExtent> tablets)
|
static boolean |
MetadataTable.isContiguousRange(KeyExtent ke,
java.util.SortedSet<KeyExtent> children)
|
static void |
MetadataTable.validateEntries(java.lang.String tableId,
java.util.SortedSet<KeyExtent> tablets)
|
Uses of KeyExtent in org.apache.accumulo.server.constraints |
---|
Methods in org.apache.accumulo.server.constraints with parameters of type KeyExtent | |
---|---|
Violations |
ConstraintChecker.check(KeyExtent extent,
Mutation m)
|
Uses of KeyExtent in org.apache.accumulo.server.logger |
---|
Fields in org.apache.accumulo.server.logger declared as KeyExtent | |
---|---|
KeyExtent |
LogFileKey.tablet
|
Uses of KeyExtent in org.apache.accumulo.server.master |
---|
Methods in org.apache.accumulo.server.master with parameters of type KeyExtent | |
---|---|
boolean |
CoordinateRecoveryTask.recover(AuthInfo credentials,
KeyExtent extent,
java.util.Collection<java.util.Collection<java.lang.String>> entries)
|
Uses of KeyExtent in org.apache.accumulo.server.master.balancer |
---|
Methods in org.apache.accumulo.server.master.balancer with parameters of type KeyExtent | |
---|---|
TServerInstance |
DefaultLoadBalancer.getAssignment(java.util.SortedMap<TServerInstance,TabletServerStatus> locations,
KeyExtent extent,
TServerInstance last)
|
Method parameters in org.apache.accumulo.server.master.balancer with type arguments of type KeyExtent | |
---|---|
abstract long |
TabletBalancer.balance(java.util.SortedMap<TServerInstance,TabletServerStatus> current,
java.util.Set<KeyExtent> migrations,
java.util.List<TabletMigration> migrationsOut)
Ask the balancer if any migrations are necessary. |
long |
TableLoadBalancer.balance(java.util.SortedMap<TServerInstance,TabletServerStatus> current,
java.util.Set<KeyExtent> migrations,
java.util.List<TabletMigration> migrationsOut)
|
long |
DefaultLoadBalancer.balance(java.util.SortedMap<TServerInstance,TabletServerStatus> current,
java.util.Set<KeyExtent> migrations,
java.util.List<TabletMigration> migrationsOut)
|
abstract void |
TabletBalancer.getAssignments(java.util.SortedMap<TServerInstance,TabletServerStatus> current,
java.util.Map<KeyExtent,TServerInstance> unassigned,
java.util.Map<KeyExtent,TServerInstance> assignments)
Assign tablets to tablet servers |
abstract void |
TabletBalancer.getAssignments(java.util.SortedMap<TServerInstance,TabletServerStatus> current,
java.util.Map<KeyExtent,TServerInstance> unassigned,
java.util.Map<KeyExtent,TServerInstance> assignments)
Assign tablets to tablet servers |
void |
TableLoadBalancer.getAssignments(java.util.SortedMap<TServerInstance,TabletServerStatus> current,
java.util.Map<KeyExtent,TServerInstance> unassigned,
java.util.Map<KeyExtent,TServerInstance> assignments)
|
void |
TableLoadBalancer.getAssignments(java.util.SortedMap<TServerInstance,TabletServerStatus> current,
java.util.Map<KeyExtent,TServerInstance> unassigned,
java.util.Map<KeyExtent,TServerInstance> assignments)
|
void |
DefaultLoadBalancer.getAssignments(java.util.SortedMap<TServerInstance,TabletServerStatus> current,
java.util.Map<KeyExtent,TServerInstance> unassigned,
java.util.Map<KeyExtent,TServerInstance> assignments)
|
void |
DefaultLoadBalancer.getAssignments(java.util.SortedMap<TServerInstance,TabletServerStatus> current,
java.util.Map<KeyExtent,TServerInstance> unassigned,
java.util.Map<KeyExtent,TServerInstance> assignments)
|
Uses of KeyExtent in org.apache.accumulo.server.master.state |
---|
Fields in org.apache.accumulo.server.master.state declared as KeyExtent | |
---|---|
KeyExtent |
TabletLocationState.extent
|
KeyExtent |
TabletMigration.tablet
|
KeyExtent |
Assignment.tablet
|
Constructors in org.apache.accumulo.server.master.state with parameters of type KeyExtent | |
---|---|
Assignment(KeyExtent tablet,
TServerInstance server)
|
|
TabletLocationState(KeyExtent extent,
TServerInstance future,
TServerInstance current,
TServerInstance last,
java.util.Collection<java.util.Collection<java.lang.String>> walogs)
|
|
TabletMigration(KeyExtent extent,
TServerInstance before,
TServerInstance after)
|
Uses of KeyExtent in org.apache.accumulo.server.tabletserver |
---|
Fields in org.apache.accumulo.server.tabletserver with type parameters of type KeyExtent | |
---|---|
java.util.List<KeyExtent> |
MemoryManagementActions.tabletsToMinorCompact
|
Methods in org.apache.accumulo.server.tabletserver that return KeyExtent | |
---|---|
KeyExtent |
TabletState.getExtent()
|
KeyExtent |
Tablet.getExtent()
Returns a KeyExtent object representing this tablet's key range. |
KeyExtent |
Tablet.CommitSession.getExtent()
|
Methods in org.apache.accumulo.server.tabletserver that return types with arguments of type KeyExtent | |
---|---|
java.util.TreeMap<KeyExtent,org.apache.accumulo.server.tabletserver.Tablet.SplitInfo> |
Tablet.split(byte[] sp)
|
static java.util.SortedMap<KeyExtent,org.apache.hadoop.io.Text> |
TabletServer.verifyTabletInformation(KeyExtent extent,
TServerInstance instance,
java.util.SortedMap<Key,Value> tabletsKeyValues,
java.lang.String clientAddress,
ZooLock lock)
|
Methods in org.apache.accumulo.server.tabletserver with parameters of type KeyExtent | |
---|---|
void |
TabletServer.addLoggersToMetadata(java.util.List<RemoteLogger> logs,
KeyExtent extent,
int id)
|
void |
TabletServerResourceManager.addMigration(KeyExtent tablet,
java.lang.Runnable migrationHandler)
|
int |
TabletServer.createLogId(KeyExtent tablet)
|
void |
TabletServerResourceManager.executeMajorCompaction(KeyExtent tablet,
java.lang.Runnable compactionTask)
|
void |
TabletServerResourceManager.TabletResourceManager.executeMajorCompaction(KeyExtent tablet,
java.lang.Runnable compactionTask)
|
void |
TabletServerResourceManager.executeReadAhead(KeyExtent tablet,
java.lang.Runnable task)
|
void |
TabletServerResourceManager.executeSplit(KeyExtent tablet,
java.lang.Runnable splitTask)
|
MetadataTable.DataFileValue |
InMemoryMap.minorCompact(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
java.lang.String dirname,
KeyExtent extent)
Writes the InMemoryMap to a file |
FileManager.ScanFileManager |
FileManager.newScanFileManager(KeyExtent tablet)
|
void |
MemoryManager.tabletClosed(KeyExtent extent)
This method is called when a tablet is closed. |
void |
LargestFirstMemoryManager.tabletClosed(KeyExtent extent)
|
static java.util.SortedMap<KeyExtent,org.apache.hadoop.io.Text> |
TabletServer.verifyTabletInformation(KeyExtent extent,
TServerInstance instance,
java.util.SortedMap<Key,Value> tabletsKeyValues,
java.lang.String clientAddress,
ZooLock lock)
|
Constructors in org.apache.accumulo.server.tabletserver with parameters of type KeyExtent | |
---|---|
Tablet(TabletServer tabletServer,
org.apache.hadoop.io.Text location,
KeyExtent extent,
TabletServerResourceManager.TabletResourceManager trm,
java.util.SortedMap<Key,Value> tabletsKeyValues)
|
|
Tablet(TabletServer tabletServer,
org.apache.hadoop.io.Text location,
KeyExtent extent,
TabletServerResourceManager.TabletResourceManager trm,
java.util.SortedMap<java.lang.String,MetadataTable.DataFileValue> datafiles,
java.lang.String time)
|
Uses of KeyExtent in org.apache.accumulo.server.tabletserver.log |
---|
Methods in org.apache.accumulo.server.tabletserver.log with parameters of type KeyExtent | |
---|---|
void |
RemoteLogger.defineTablet(int seq,
int tid,
KeyExtent tablet)
|
void |
SortedLogRecovery.recover(KeyExtent extent,
java.util.List<java.lang.String> recoveryLogs,
java.util.Set<java.lang.String> tabletFiles,
MutationReceiver mr)
|
Uses of KeyExtent in org.apache.accumulo.server.tabletserver.mastermessage |
---|
Constructors in org.apache.accumulo.server.tabletserver.mastermessage with parameters of type KeyExtent | |
---|---|
SplitReportMessage(KeyExtent old_extent,
KeyExtent ne1,
org.apache.hadoop.io.Text np1,
KeyExtent ne2,
org.apache.hadoop.io.Text np2)
|
|
SplitReportMessage(KeyExtent old_extent,
java.util.Map<KeyExtent,org.apache.hadoop.io.Text> newExtents)
|
|
TabletStatusMessage(TabletLoadState status,
KeyExtent extent)
|
Constructor parameters in org.apache.accumulo.server.tabletserver.mastermessage with type arguments of type KeyExtent | |
---|---|
SplitReportMessage(KeyExtent old_extent,
java.util.Map<KeyExtent,org.apache.hadoop.io.Text> newExtents)
|
Uses of KeyExtent in org.apache.accumulo.server.util |
---|
Fields in org.apache.accumulo.server.util declared as KeyExtent | |
---|---|
KeyExtent |
MetadataTable.LogEntry.extent
|
Methods in org.apache.accumulo.server.util that return KeyExtent | |
---|---|
static KeyExtent |
MetadataTable.fixSplit(org.apache.hadoop.io.Text metadataEntry,
java.util.SortedMap<ColumnFQ,Value> columns,
TServerInstance tserver,
AuthInfo credentials,
ZooLock lock)
|
Methods in org.apache.accumulo.server.util that return types with arguments of type KeyExtent | |
---|---|
static java.util.SortedMap<KeyExtent,org.apache.hadoop.io.Text> |
MetadataTable.getMetadataDirectoryEntries(java.util.SortedMap<Key,Value> entries)
convenience method for reading entries from the metadata table |
Methods in org.apache.accumulo.server.util with parameters of type KeyExtent | |
---|---|
static void |
MetadataTable.addNewTablet(KeyExtent extent,
java.lang.String path,
TServerInstance location,
java.util.Map<java.lang.String,MetadataTable.DataFileValue> datafileSizes,
AuthInfo credentials,
java.lang.String time,
ZooLock zooLock)
|
static void |
MetadataTable.addTablet(KeyExtent extent,
java.lang.String path,
AuthInfo credentials,
char timeType,
ZooLock lock)
|
static void |
MetadataTable.finishSplit(KeyExtent extent,
java.util.Map<java.lang.String,MetadataTable.DataFileValue> datafileSizes,
java.util.List<java.lang.String> highDatafilesToRemove,
AuthInfo credentials,
ZooLock zooLock)
|
static java.util.SortedMap<java.lang.String,MetadataTable.DataFileValue> |
MetadataTable.getDataFileSizes(KeyExtent extent,
AuthInfo credentials)
|
static Pair<java.util.List<MetadataTable.LogEntry>,java.util.SortedMap<java.lang.String,MetadataTable.DataFileValue>> |
MetadataTable.getFileAndLogEntries(AuthInfo credentials,
KeyExtent extent)
|
static java.util.List<MetadataTable.LogEntry> |
MetadataTable.getLogEntries(AuthInfo credentials,
KeyExtent extent)
|
static void |
MetadataTable.getTabletAndPrevTabletKeyValues(java.util.SortedMap<Key,Value> tkv,
KeyExtent ke,
java.util.List<ColumnFQ> columns,
AuthInfo credentials)
|
static java.util.SortedMap<org.apache.hadoop.io.Text,java.util.SortedMap<ColumnFQ,Value>> |
MetadataTable.getTabletEntries(KeyExtent ke,
java.util.List<ColumnFQ> columns,
AuthInfo credentials)
|
static void |
MetadataTable.removeScanFiles(KeyExtent extent,
java.util.Set<java.lang.String> scanFiles,
AuthInfo credentials,
ZooLock zooLock)
|
static void |
MetadataTable.removeUnusedWALEntries(KeyExtent extent,
java.util.List<MetadataTable.LogEntry> logEntries,
ZooLock zooLock)
|
static void |
MetadataTable.replaceDatafiles(KeyExtent extent,
java.util.Set<java.lang.String> datafilesToDelete,
java.util.Set<java.lang.String> scanFiles,
java.lang.String path,
MetadataTable.DataFileValue size,
AuthInfo credentials,
java.lang.String address,
TServerInstance lastLocation,
ZooLock zooLock)
|
static void |
MetadataTable.replaceDatafiles(KeyExtent extent,
java.util.Set<java.lang.String> datafilesToDelete,
java.util.Set<java.lang.String> scanFiles,
java.lang.String path,
MetadataTable.DataFileValue size,
AuthInfo credentials,
java.lang.String address,
TServerInstance lastLocation,
ZooLock zooLock,
boolean insertDeleteFlags)
|
static void |
MetadataTable.splitTablet(KeyExtent extent,
org.apache.hadoop.io.Text oldPrevEndRow,
double splitRatio,
AuthInfo credentials,
ZooLock zooLock)
|
static void |
MetadataTable.updateTabletDataFile(KeyExtent extent,
java.util.Map<java.lang.String,MetadataTable.DataFileValue> estSizes,
AuthInfo credentials,
ZooLock zooLock)
|
static void |
MetadataTable.updateTabletDataFile(KeyExtent extent,
java.lang.String path,
MetadataTable.DataFileValue dfv,
java.lang.String time,
AuthInfo credentials,
java.lang.String address,
ZooLock zooLock,
java.util.Set<java.lang.String> unusedWalLogs,
TServerInstance lastLocation)
new data file update function adds one data file to a tablet's list path should be relative to the table directory |
static void |
MetadataTable.updateTabletPrevEndRow(KeyExtent extent,
AuthInfo credentials)
|
Method parameters in org.apache.accumulo.server.util with type arguments of type KeyExtent | |
---|---|
static void |
CheckForMetadataProblems.checkTable(java.lang.String tablename,
java.util.TreeSet<KeyExtent> tablets,
boolean patch)
|
|
||||||||||
PREV NEXT | FRAMES NO FRAMES |