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

Packages that use KeyExtent
org.apache.accumulo.core   
org.apache.accumulo.core.client   
org.apache.accumulo.core.client.admin   
org.apache.accumulo.core.client.impl   
org.apache.accumulo.core.client.mock   
org.apache.accumulo.core.constraints   
org.apache.accumulo.core.data   
org.apache.accumulo.core.file   
org.apache.accumulo.core.iterators   
org.apache.accumulo.core.iterators.system   
org.apache.accumulo.core.tabletserver.log   
org.apache.accumulo.core.util   
org.apache.accumulo.server.client   
org.apache.accumulo.server.logger   
org.apache.accumulo.server.master   
org.apache.accumulo.server.master.balancer   
org.apache.accumulo.server.master.state   
org.apache.accumulo.server.tabletserver   
org.apache.accumulo.server.tabletserver.log   
org.apache.accumulo.server.tabletserver.mastermessage   
org.apache.accumulo.server.util   
 

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
 List<KeyExtent> MutationsRejectedException.getAuthorizationFailures()
           
 

Constructor parameters in org.apache.accumulo.core.client with type arguments of type KeyExtent
MutationsRejectedException(List<ConstraintViolationSummary> cvsList, ArrayList<KeyExtent> af, Collection<String> serverSideErrors, int unknownErrors, Throwable cause)
           
 

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
 Map<KeyExtent,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(Map<String,Map<KeyExtent,List<Range>>> binnedRanges, String location, KeyExtent ke, Range range)
           
static boolean ThriftScanner.getBatchFromServer(AuthInfo credentials, org.apache.hadoop.io.Text startRow, KeyExtent extent, String server, SortedMap<Key,Value> results, 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(Map<String,Map<KeyExtent,List<Range>>> binnedRanges, String location, KeyExtent ke, Range range)
           
 List<Range> TabletLocatorImpl.binRanges(List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
           
 List<Range> RootTabletLocator.binRanges(List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
           
abstract  List<Range> TabletLocator.binRanges(List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
           
 void TabletLocatorImpl.invalidateCache(Collection<KeyExtent> keySet)
           
 void RootTabletLocator.invalidateCache(Collection<KeyExtent> keySet)
           
abstract  void TabletLocator.invalidateCache(Collection<KeyExtent> keySet)
           
 List<TabletLocator.TabletLocation> MetadataLocationObtainer.lookupTablets(String tserver, Map<KeyExtent,List<Range>> tabletsRanges, TabletLocator parent)
           
 List<TabletLocator.TabletLocation> TabletLocatorImpl.TabletLocationObtainer.lookupTablets(String tserver, Map<KeyExtent,List<Range>> map, TabletLocator parent)
           
static TabletType TabletType.type(Collection<KeyExtent> extents)
           
 

Constructors in org.apache.accumulo.core.client.impl with parameters of type KeyExtent
TabletLocator.TabletLocation(KeyExtent tablet_extent, 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
 List<Range> MockTabletLocator.binRanges(List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
           
 void MockTabletLocator.invalidateCache(Collection<KeyExtent> keySet)
           
 

Uses of KeyExtent in org.apache.accumulo.core.constraints
 

Methods in org.apache.accumulo.core.constraints that return KeyExtent
 KeyExtent Constraint.Environment.getExtent()
           
 

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, SortedSet<KeyExtent> extents)
           
 

Methods in org.apache.accumulo.core.data that return types with arguments of type KeyExtent
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.
 

Methods in org.apache.accumulo.core.data with parameters of type KeyExtent
 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)
           
 

Method parameters in org.apache.accumulo.core.data with type arguments of type KeyExtent
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.
 

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 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)
           
 

Method parameters in org.apache.accumulo.core.file with type arguments of type KeyExtent
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)
           
 

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

Methods in org.apache.accumulo.core.iterators with parameters of type KeyExtent
static
<K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable>
SortedKeyValueIterator<K,V>
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>
SortedKeyValueIterator<K,V>
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>
SortedKeyValueIterator<K,V>
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)
           
 

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

Constructors in org.apache.accumulo.core.iterators.system with parameters of type KeyExtent
MultiIterator(List<SortedKeyValueIterator<Key,Value>> iters2, 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 SortedMap<KeyExtent,org.apache.hadoop.io.Text> MetadataTable.getMetadataLocationEntries(SortedMap<Key,Value> entries)
           
 

Methods in org.apache.accumulo.core.util with parameters of type KeyExtent
static void MetadataTable.getTabletAndPrevTabletKeyValues(Instance instance, SortedMap<Key,Value> tkv, KeyExtent ke, List<ColumnFQ> columns, AuthInfo credentials)
           
static SortedMap<org.apache.hadoop.io.Text,SortedMap<ColumnFQ,Value>> MetadataTable.getTabletEntries(Instance instance, KeyExtent ke, List<ColumnFQ> columns, AuthInfo credentials)
           
static boolean MetadataTable.isContiguousRange(KeyExtent ke, 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, String table, boolean isTid, Map<KeyExtent,String> locations, SortedSet<KeyExtent> tablets)
           
static void MetadataTable.getEntries(Instance instance, AuthInfo 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)
           
 

Constructors in org.apache.accumulo.core.util with parameters of type KeyExtent
Merge.Size(KeyExtent extent, long size)
           
 

Uses of KeyExtent in org.apache.accumulo.server.client
 

Methods in org.apache.accumulo.server.client with parameters of type KeyExtent
static List<TabletLocator.TabletLocation> BulkImporter.findOverlappingTablets(AccumuloConfiguration acuConf, org.apache.hadoop.fs.FileSystem fs, TabletLocator locator, org.apache.hadoop.fs.Path file, KeyExtent failed)
           
 

Uses of KeyExtent in org.apache.accumulo.server.logger
 

Fields in org.apache.accumulo.server.logger declared as KeyExtent
 KeyExtent LogFileKey.tablet
           
 

Methods in org.apache.accumulo.server.logger with parameters of type KeyExtent
static void LogReader.printLogEvent(LogFileKey key, LogFileValue value, org.apache.hadoop.io.Text row, Matcher rowMatcher, KeyExtent ke, Set<Integer> tabletIds, int maxMutations)
           
 

Uses of KeyExtent in org.apache.accumulo.server.master
 

Methods in org.apache.accumulo.server.master with parameters of type KeyExtent
 void LiveTServerSet.TServerConnection.assignTablet(ZooLock lock, KeyExtent extent)
           
 void LiveTServerSet.TServerConnection.chop(ZooLock lock, KeyExtent extent)
           
 void LiveTServerSet.TServerConnection.flushTablet(ZooLock lock, KeyExtent extent)
           
 boolean CoordinateRecoveryTask.recover(AuthInfo credentials, KeyExtent extent, Collection<Collection<String>> entries, org.apache.accumulo.server.master.CoordinateRecoveryTask.JobComplete notify)
           
 void LiveTServerSet.TServerConnection.splitTablet(ZooLock lock, KeyExtent extent, org.apache.hadoop.io.Text splitPoint)
           
 void LiveTServerSet.TServerConnection.unloadTablet(ZooLock lock, KeyExtent extent, boolean save)
           
 

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(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(SortedMap<TServerInstance,TabletServerStatus> current, Set<KeyExtent> migrations, List<TabletMigration> migrationsOut)
          Ask the balancer if any migrations are necessary.
 long TableLoadBalancer.balance(SortedMap<TServerInstance,TabletServerStatus> current, Set<KeyExtent> migrations, List<TabletMigration> migrationsOut)
           
 long ChaoticLoadBalancer.balance(SortedMap<TServerInstance,TabletServerStatus> current, Set<KeyExtent> migrations, List<TabletMigration> migrationsOut)
          Will balance randomly, maintaining distribution
 long DefaultLoadBalancer.balance(SortedMap<TServerInstance,TabletServerStatus> current, Set<KeyExtent> migrations, List<TabletMigration> migrationsOut)
           
abstract  void TabletBalancer.getAssignments(SortedMap<TServerInstance,TabletServerStatus> current, Map<KeyExtent,TServerInstance> unassigned, Map<KeyExtent,TServerInstance> assignments)
          Assign tablets to tablet servers.
abstract  void TabletBalancer.getAssignments(SortedMap<TServerInstance,TabletServerStatus> current, Map<KeyExtent,TServerInstance> unassigned, Map<KeyExtent,TServerInstance> assignments)
          Assign tablets to tablet servers.
 void TableLoadBalancer.getAssignments(SortedMap<TServerInstance,TabletServerStatus> current, Map<KeyExtent,TServerInstance> unassigned, Map<KeyExtent,TServerInstance> assignments)
           
 void TableLoadBalancer.getAssignments(SortedMap<TServerInstance,TabletServerStatus> current, Map<KeyExtent,TServerInstance> unassigned, Map<KeyExtent,TServerInstance> assignments)
           
 void ChaoticLoadBalancer.getAssignments(SortedMap<TServerInstance,TabletServerStatus> current, Map<KeyExtent,TServerInstance> unassigned, Map<KeyExtent,TServerInstance> assignments)
           
 void ChaoticLoadBalancer.getAssignments(SortedMap<TServerInstance,TabletServerStatus> current, Map<KeyExtent,TServerInstance> unassigned, Map<KeyExtent,TServerInstance> assignments)
           
 void DefaultLoadBalancer.getAssignments(SortedMap<TServerInstance,TabletServerStatus> current, Map<KeyExtent,TServerInstance> unassigned, Map<KeyExtent,TServerInstance> assignments)
           
 void DefaultLoadBalancer.getAssignments(SortedMap<TServerInstance,TabletServerStatus> current, Map<KeyExtent,TServerInstance> unassigned, 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
           
 

Methods in org.apache.accumulo.server.master.state that return KeyExtent
 KeyExtent MergeInfo.getRange()
           
 

Methods in org.apache.accumulo.server.master.state with parameters of type KeyExtent
 boolean MergeInfo.needsToBeChopped(KeyExtent extent)
           
 boolean MergeInfo.overlaps(KeyExtent extent)
           
 void MergeStats.update(KeyExtent ke, TabletState state, boolean chopped, boolean hasWALs)
           
 

Constructors in org.apache.accumulo.server.master.state with parameters of type KeyExtent
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)
           
 

Uses of KeyExtent in org.apache.accumulo.server.tabletserver
 

Fields in org.apache.accumulo.server.tabletserver with type parameters of type KeyExtent
 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
 TreeMap<KeyExtent,org.apache.accumulo.server.tabletserver.Tablet.SplitInfo> Tablet.split(byte[] sp)
           
static SortedMap<KeyExtent,org.apache.hadoop.io.Text> TabletServer.verifyTabletInformation(KeyExtent extent, TServerInstance instance, SortedMap<Key,Value> tabletsKeyValues, String clientAddress, ZooLock lock)
           
 

Methods in org.apache.accumulo.server.tabletserver with parameters of type KeyExtent
 void TabletServer.addLoggersToMetadata(List<RemoteLogger> 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)
           
 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 SortedMap<KeyExtent,org.apache.hadoop.io.Text> TabletServer.verifyTabletInformation(KeyExtent extent, TServerInstance instance, SortedMap<Key,Value> tabletsKeyValues, 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, 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)
           
 

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, List<String> recoveryLogs, Set<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, 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, 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, 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 SortedMap<KeyExtent,org.apache.hadoop.io.Text> MetadataTable.getMetadataDirectoryEntries(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.addDeleteEntries(KeyExtent extent, Set<String> datafilesToDelete, AuthInfo credentials)
           
static void MetadataTable.addNewTablet(KeyExtent extent, String path, TServerInstance location, Map<String,MetadataTable.DataFileValue> datafileSizes, Map<String,Long> bulkLoadedFiles, AuthInfo credentials, String time, long lastFlushID, long lastCompactID, ZooLock zooLock)
           
static void MetadataTable.addTablet(KeyExtent extent, String path, AuthInfo 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, AuthInfo credentials, ZooLock zooLock)
           
static Map<String,Long> MetadataTable.getBulkFilesLoaded(AuthInfo credentials, KeyExtent extent)
           
static List<String> MetadataTable.getBulkFilesLoaded(Connector conn, KeyExtent extent, long tid)
           
static SortedMap<String,MetadataTable.DataFileValue> MetadataTable.getDataFileSizes(KeyExtent extent, AuthInfo credentials)
           
static Pair<List<MetadataTable.LogEntry>,SortedMap<String,MetadataTable.DataFileValue>> MetadataTable.getFileAndLogEntries(AuthInfo credentials, KeyExtent extent)
           
static List<MetadataTable.LogEntry> MetadataTable.getLogEntries(AuthInfo credentials, KeyExtent extent)
           
static void MetadataTable.getTabletAndPrevTabletKeyValues(SortedMap<Key,Value> tkv, KeyExtent ke, List<ColumnFQ> columns, AuthInfo credentials)
           
static SortedMap<org.apache.hadoop.io.Text,SortedMap<ColumnFQ,Value>> MetadataTable.getTabletEntries(KeyExtent ke, List<ColumnFQ> columns, AuthInfo credentials)
           
static void MetadataTable.removeScanFiles(KeyExtent extent, Set<String> scanFiles, AuthInfo 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, AuthInfo 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, AuthInfo credentials, 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.updateTabletCompactID(KeyExtent extent, long compactID, AuthInfo credentials, ZooLock zooLock)
           
static void MetadataTable.updateTabletDataFile(KeyExtent extent, String path, String mergeFile, MetadataTable.DataFileValue dfv, String time, AuthInfo 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 path should be relative to the table directory
static void MetadataTable.updateTabletDataFile(long tid, KeyExtent extent, Map<String,MetadataTable.DataFileValue> estSizes, String time, AuthInfo credentials, ZooLock zooLock)
           
static void MetadataTable.updateTabletFlushID(KeyExtent extent, long flushID, AuthInfo credentials, ZooLock zooLock)
           
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(String tablename, TreeSet<KeyExtent> tablets, boolean patch)
           
 



Copyright © 2012 The Apache Software Foundation. All Rights Reserved.