BulkLoadHFiles instead. Please
             rewrite your code if you rely on methods other than the run(Map, TableName)
             and run(String, TableName), as all the methods other than them will be
             removed with no replacement.@Deprecated @InterfaceAudience.Public public class LoadIncrementalHFiles extends org.apache.hadoop.conf.Configured implements org.apache.hadoop.util.Tool
BulkLoadHFiles.| Modifier and Type | Class and Description | 
|---|---|
| private static interface  | LoadIncrementalHFiles.BulkHFileVisitor<TFamily>Deprecated.  | 
| static class  | LoadIncrementalHFiles.LoadQueueItemDeprecated. 
 since 2.2.0 and will be removed in 3.0.0. Use  BulkLoadHFilesinstead. | 
| Modifier and Type | Field and Description | 
|---|---|
| static String | ALWAYS_COPY_FILESDeprecated.  | 
| private static String | ASSIGN_SEQ_IDSDeprecated.  | 
| private boolean | assignSeqIdsDeprecated.  | 
| private boolean | bulkLoadByFamilyDeprecated.  | 
| private String | bulkTokenDeprecated.  | 
| private List<String> | clusterIdsDeprecated.  | 
| static String | CREATE_TABLE_CONF_KEYDeprecated.  | 
| private FsDelegationToken | fsDelegationTokenDeprecated.  | 
| static String | IGNORE_UNMATCHED_CF_CONF_KEYDeprecated.  | 
| private static org.slf4j.Logger | LOGDeprecated.  | 
| static String | MAX_FILES_PER_REGION_PER_FAMILYDeprecated.  | 
| private int | maxFilesPerRegionPerFamilyDeprecated.  | 
| static String | NAMEDeprecated. 
 since 2.2.0, will be removed in 3.0.0, with no replacement. End user should not
             depend on this value. | 
| private int | nrThreadsDeprecated.  | 
| private AtomicInteger | numRetriesDeprecated.  | 
| private boolean | replicateDeprecated.  | 
| (package private) static String | RETRY_ON_IO_EXCEPTIONDeprecated.  | 
| private RpcControllerFactory | rpcControllerFactoryDeprecated.  | 
| (package private) static String | TMP_DIRDeprecated.  | 
| private UserProvider | userProviderDeprecated.  | 
| Constructor and Description | 
|---|
| LoadIncrementalHFiles(org.apache.hadoop.conf.Configuration conf)Deprecated.  | 
| Modifier and Type | Method and Description | 
|---|---|
| protected ClientServiceCallable<byte[]> | buildClientServiceCallable(Connection conn,
                          TableName tableName,
                          byte[] first,
                          Collection<LoadIncrementalHFiles.LoadQueueItem> lqis,
                          boolean copyFile)Deprecated.  | 
| protected void | bulkLoadPhase(Table table,
             Connection conn,
             ExecutorService pool,
             Deque<LoadIncrementalHFiles.LoadQueueItem> queue,
             org.apache.hbase.thirdparty.com.google.common.collect.Multimap<ByteBuffer,LoadIncrementalHFiles.LoadQueueItem> regionGroups,
             boolean copyFile,
             Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> item2RegionMap)Deprecated.  This takes the LQI's grouped by likely regions and attempts to bulk load them. | 
| private boolean | checkHFilesCountPerRegionPerFamily(org.apache.hbase.thirdparty.com.google.common.collect.Multimap<ByteBuffer,LoadIncrementalHFiles.LoadQueueItem> regionGroups)Deprecated.  | 
| private void | checkRegionIndexValid(int idx,
                     Pair<byte[][],byte[][]> startEndKeys,
                     TableName tableName)Deprecated.  we can consider there is a region hole in following conditions. | 
| private void | cleanup(Admin admin,
       Deque<LoadIncrementalHFiles.LoadQueueItem> queue,
       ExecutorService pool,
       SecureBulkLoadClient secureClient)Deprecated.  | 
| private static void | copyHFileHalf(org.apache.hadoop.conf.Configuration conf,
             org.apache.hadoop.fs.Path inFile,
             org.apache.hadoop.fs.Path outFile,
             Reference reference,
             ColumnFamilyDescriptor familyDescriptor)Deprecated.  Copy half of an HFile into a new HFile. | 
| private ExecutorService | createExecutorService()Deprecated.  | 
| private void | createTable(TableName tableName,
           org.apache.hadoop.fs.Path hfofDir,
           Admin admin)Deprecated.  If the table is created for the first time, then "completebulkload" reads the files twice. | 
| void | disableReplication()Deprecated.  Disables replication for these bulkloaded files. | 
| private void | discoverLoadQueue(Deque<LoadIncrementalHFiles.LoadQueueItem> ret,
                 org.apache.hadoop.fs.Path hfofDir,
                 boolean validateHFile)Deprecated.  Walk the given directory for all HFiles, and return a Queue containing all such files. | 
| Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> | doBulkLoad(Map<byte[],List<org.apache.hadoop.fs.Path>> map,
          Admin admin,
          Table table,
          RegionLocator regionLocator,
          boolean silence,
          boolean copyFile)Deprecated.  Perform a bulk load of the given directory into the given pre-existing table. | 
| Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> | doBulkLoad(org.apache.hadoop.fs.Path hfofDir,
          Admin admin,
          Table table,
          RegionLocator regionLocator)Deprecated.  Perform a bulk load of the given directory into the given pre-existing table. | 
| Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> | doBulkLoad(org.apache.hadoop.fs.Path hfofDir,
          Admin admin,
          Table table,
          RegionLocator regionLocator,
          boolean silence,
          boolean copyFile)Deprecated.  Perform a bulk load of the given directory into the given pre-existing table. | 
| private int | getRegionIndex(Pair<byte[][],byte[][]> startEndKeys,
              byte[] key)Deprecated.  | 
| private String | getUniqueName()Deprecated.  | 
| private Map<byte[],Collection<LoadIncrementalHFiles.LoadQueueItem>> | groupByFamilies(Collection<LoadIncrementalHFiles.LoadQueueItem> itemsInRegion)Deprecated.  | 
| protected Pair<List<LoadIncrementalHFiles.LoadQueueItem>,String> | groupOrSplit(org.apache.hbase.thirdparty.com.google.common.collect.Multimap<ByteBuffer,LoadIncrementalHFiles.LoadQueueItem> regionGroups,
            LoadIncrementalHFiles.LoadQueueItem item,
            Table table,
            Pair<byte[][],byte[][]> startEndKeys)Deprecated.  Attempt to assign the given load queue item into its target region group. | 
| private Pair<org.apache.hbase.thirdparty.com.google.common.collect.Multimap<ByteBuffer,LoadIncrementalHFiles.LoadQueueItem>,Set<String>> | groupOrSplitPhase(Table table,
                 ExecutorService pool,
                 Deque<LoadIncrementalHFiles.LoadQueueItem> queue,
                 Pair<byte[][],byte[][]> startEndKeys)Deprecated.  | 
| static byte[][] | inferBoundaries(SortedMap<byte[],Integer> bdryMap)Deprecated.  Infers region boundaries for a new table. | 
| void | initialize()Deprecated.  | 
| private boolean | isAlwaysCopyFiles()Deprecated.  | 
| private boolean | isCreateTable()Deprecated.  | 
| private boolean | isSecureBulkLoadEndpointAvailable()Deprecated.  | 
| private boolean | isSilence()Deprecated.  | 
| void | loadHFileQueue(Table table,
              Connection conn,
              Deque<LoadIncrementalHFiles.LoadQueueItem> queue,
              Pair<byte[][],byte[][]> startEndKeys)Deprecated.  Used by the replication sink to load the hfiles from the source cluster. | 
| void | loadHFileQueue(Table table,
              Connection conn,
              Deque<LoadIncrementalHFiles.LoadQueueItem> queue,
              Pair<byte[][],byte[][]> startEndKeys,
              boolean copyFile)Deprecated.  Used by the replication sink to load the hfiles from the source cluster. | 
| static void | main(String[] args)Deprecated.  | 
| private Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> | performBulkLoad(Admin admin,
               Table table,
               RegionLocator regionLocator,
               Deque<LoadIncrementalHFiles.LoadQueueItem> queue,
               ExecutorService pool,
               SecureBulkLoadClient secureClient,
               boolean copyFile)Deprecated.  | 
| private void | populateLoadQueue(Deque<LoadIncrementalHFiles.LoadQueueItem> ret,
                 Map<byte[],List<org.apache.hadoop.fs.Path>> map)Deprecated.  Populate the Queue with given HFiles | 
| void | prepareHFileQueue(Map<byte[],List<org.apache.hadoop.fs.Path>> map,
                 Table table,
                 Deque<LoadIncrementalHFiles.LoadQueueItem> queue,
                 boolean silence)Deprecated.  Prepare a collection of  LoadIncrementalHFiles.LoadQueueItemfrom list of source hfiles contained in the
 passed directory and validates whether the prepared queue has all the valid table column
 families in it. | 
| void | prepareHFileQueue(org.apache.hadoop.fs.Path hfilesDir,
                 Table table,
                 Deque<LoadIncrementalHFiles.LoadQueueItem> queue,
                 boolean validateHFile)Deprecated.  Prepare a collection of  LoadIncrementalHFiles.LoadQueueItemfrom list of source hfiles contained in the
 passed directory and validates whether the prepared queue has all the valid table column
 families in it. | 
| void | prepareHFileQueue(org.apache.hadoop.fs.Path hfilesDir,
                 Table table,
                 Deque<LoadIncrementalHFiles.LoadQueueItem> queue,
                 boolean validateHFile,
                 boolean silence)Deprecated.  Prepare a collection of  LoadIncrementalHFiles.LoadQueueItemfrom list of source hfiles contained in the
 passed directory and validates whether the prepared queue has all the valid table column
 families in it. | 
| Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> | run(Map<byte[],List<org.apache.hadoop.fs.Path>> family2Files,
   TableName tableName)Deprecated.  Perform bulk load on the given table. | 
| protected Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> | run(org.apache.hadoop.fs.Path hfofDir,
   TableName tableName)Deprecated.  | 
| int | run(String[] args)Deprecated.  | 
| Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> | run(String hfofDir,
   TableName tableName)Deprecated.  Perform bulk load on the given table. | 
| void | setBulkToken(String stagingDir)Deprecated.  Called from replication sink, where it manages bulkToken(staging directory) by itself. | 
| void | setClusterIds(List<String> clusterIds)Deprecated.  | 
| private static boolean | shouldCopyHFileMetaKey(byte[] key)Deprecated.  | 
| (package private) static void | splitStoreFile(org.apache.hadoop.conf.Configuration conf,
              org.apache.hadoop.fs.Path inFile,
              ColumnFamilyDescriptor familyDesc,
              byte[] splitKey,
              org.apache.hadoop.fs.Path bottomOut,
              org.apache.hadoop.fs.Path topOut)Deprecated.  Split a storefile into a top and bottom half, maintaining the metadata, recreating bloom
 filters, etc. | 
| private List<LoadIncrementalHFiles.LoadQueueItem> | splitStoreFile(LoadIncrementalHFiles.LoadQueueItem item,
              Table table,
              byte[] startKey,
              byte[] splitKey)Deprecated.  | 
| private String | toString(List<Pair<byte[],String>> list)Deprecated.  | 
| protected List<LoadIncrementalHFiles.LoadQueueItem> | tryAtomicRegionLoad(ClientServiceCallable<byte[]> serviceCallable,
                   TableName tableName,
                   byte[] first,
                   Collection<LoadIncrementalHFiles.LoadQueueItem> lqis)Deprecated. 
 as of release 2.3.0. Use  BulkLoadHFilesinstead. | 
| protected List<LoadIncrementalHFiles.LoadQueueItem> | tryAtomicRegionLoad(Connection conn,
                   TableName tableName,
                   byte[] first,
                   Collection<LoadIncrementalHFiles.LoadQueueItem> lqis,
                   boolean copyFile)Deprecated. 
 as of release 2.3.0. Use  BulkLoadHFilesinstead. | 
| private void | usage()Deprecated.  | 
| private void | validateFamiliesInHFiles(Table table,
                        Deque<LoadIncrementalHFiles.LoadQueueItem> queue,
                        boolean silence)Deprecated.  Checks whether there is any invalid family name in HFiles to be bulk loaded. | 
| private static <TFamily> void | visitBulkHFiles(org.apache.hadoop.fs.FileSystem fs,
               org.apache.hadoop.fs.Path bulkDir,
               LoadIncrementalHFiles.BulkHFileVisitor<TFamily> visitor)Deprecated.  Iterate over the bulkDir hfiles. | 
| private static <TFamily> void | visitBulkHFiles(org.apache.hadoop.fs.FileSystem fs,
               org.apache.hadoop.fs.Path bulkDir,
               LoadIncrementalHFiles.BulkHFileVisitor<TFamily> visitor,
               boolean validateHFile)Deprecated.  Iterate over the bulkDir hfiles. | 
private static final org.slf4j.Logger LOG
@Deprecated public static final String NAME
static final String RETRY_ON_IO_EXCEPTION
public static final String MAX_FILES_PER_REGION_PER_FAMILY
private static final String ASSIGN_SEQ_IDS
public static final String CREATE_TABLE_CONF_KEY
public static final String IGNORE_UNMATCHED_CF_CONF_KEY
public static final String ALWAYS_COPY_FILES
static final String TMP_DIR
private int maxFilesPerRegionPerFamily
private boolean assignSeqIds
private boolean bulkLoadByFamily
private FsDelegationToken fsDelegationToken
private UserProvider userProvider
private int nrThreads
private AtomicInteger numRetries
private RpcControllerFactory rpcControllerFactory
private List<String> clusterIds
private boolean replicate
public LoadIncrementalHFiles(org.apache.hadoop.conf.Configuration conf)
public void initialize()
private void usage()
public void prepareHFileQueue(org.apache.hadoop.fs.Path hfilesDir, Table table, Deque<LoadIncrementalHFiles.LoadQueueItem> queue, boolean validateHFile) throws IOException
LoadIncrementalHFiles.LoadQueueItem from list of source hfiles contained in the
 passed directory and validates whether the prepared queue has all the valid table column
 families in it.hfilesDir - directory containing list of hfiles to be loaded into the tabletable - table to which hfiles should be loadedqueue - queue which needs to be loaded into the tablevalidateHFile - if true hfiles will be validated for its formatIOException - If any I/O or network error occurredpublic void prepareHFileQueue(org.apache.hadoop.fs.Path hfilesDir, Table table, Deque<LoadIncrementalHFiles.LoadQueueItem> queue, boolean validateHFile, boolean silence) throws IOException
LoadIncrementalHFiles.LoadQueueItem from list of source hfiles contained in the
 passed directory and validates whether the prepared queue has all the valid table column
 families in it.hfilesDir - directory containing list of hfiles to be loaded into the tabletable - table to which hfiles should be loadedqueue - queue which needs to be loaded into the tablevalidateHFile - if true hfiles will be validated for its formatsilence - true to ignore unmatched column familiesIOException - If any I/O or network error occurredpublic void prepareHFileQueue(Map<byte[],List<org.apache.hadoop.fs.Path>> map, Table table, Deque<LoadIncrementalHFiles.LoadQueueItem> queue, boolean silence) throws IOException
LoadIncrementalHFiles.LoadQueueItem from list of source hfiles contained in the
 passed directory and validates whether the prepared queue has all the valid table column
 families in it.map - map of family to List of hfilestable - table to which hfiles should be loadedqueue - queue which needs to be loaded into the tablesilence - true to ignore unmatched column familiesIOException - If any I/O or network error occurredpublic Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> doBulkLoad(org.apache.hadoop.fs.Path hfofDir, Admin admin, Table table, RegionLocator regionLocator) throws TableNotFoundException, IOException
hfofDir - the directory that was provided as the output path of a job using
          HFileOutputFormatadmin - the Admintable - the table to load intoregionLocator - region locatorTableNotFoundException - if table does not yet existIOExceptionpublic Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> doBulkLoad(Map<byte[],List<org.apache.hadoop.fs.Path>> map, Admin admin, Table table, RegionLocator regionLocator, boolean silence, boolean copyFile) throws TableNotFoundException, IOException
map - map of family to List of hfilesadmin - the Admintable - the table to load intoregionLocator - region locatorsilence - true to ignore unmatched column familiescopyFile - always copy hfiles if trueTableNotFoundException - if table does not yet existIOExceptionpublic Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> doBulkLoad(org.apache.hadoop.fs.Path hfofDir, Admin admin, Table table, RegionLocator regionLocator, boolean silence, boolean copyFile) throws TableNotFoundException, IOException
hfofDir - the directory that was provided as the output path of a job using
          HFileOutputFormatadmin - the Admintable - the table to load intoregionLocator - region locatorsilence - true to ignore unmatched column familiescopyFile - always copy hfiles if trueTableNotFoundException - if table does not yet existIOExceptionpublic void loadHFileQueue(Table table, Connection conn, Deque<LoadIncrementalHFiles.LoadQueueItem> queue, Pair<byte[][],byte[][]> startEndKeys) throws IOException
table - Table to which these hfiles should be loaded toconn - Connection to usequeue - LoadIncrementalHFiles.LoadQueueItem has hfiles yet to be loadedstartEndKeys - starting and ending row keys of the regionIOExceptionpublic void loadHFileQueue(Table table, Connection conn, Deque<LoadIncrementalHFiles.LoadQueueItem> queue, Pair<byte[][],byte[][]> startEndKeys, boolean copyFile) throws IOException
table - Table to which these hfiles should be loaded toconn - Connection to usequeue - LoadIncrementalHFiles.LoadQueueItem has hfiles yet to be loadedstartEndKeys - starting and ending row keys of the regionIOExceptionprivate Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> performBulkLoad(Admin admin, Table table, RegionLocator regionLocator, Deque<LoadIncrementalHFiles.LoadQueueItem> queue, ExecutorService pool, SecureBulkLoadClient secureClient, boolean copyFile) throws IOException
IOExceptionprivate Map<byte[],Collection<LoadIncrementalHFiles.LoadQueueItem>> groupByFamilies(Collection<LoadIncrementalHFiles.LoadQueueItem> itemsInRegion)
@InterfaceAudience.Private protected void bulkLoadPhase(Table table, Connection conn, ExecutorService pool, Deque<LoadIncrementalHFiles.LoadQueueItem> queue, org.apache.hbase.thirdparty.com.google.common.collect.Multimap<ByteBuffer,LoadIncrementalHFiles.LoadQueueItem> regionGroups, boolean copyFile, Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> item2RegionMap) throws IOException
protected for testing.
IOException@InterfaceAudience.Private protected ClientServiceCallable<byte[]> buildClientServiceCallable(Connection conn, TableName tableName, byte[] first, Collection<LoadIncrementalHFiles.LoadQueueItem> lqis, boolean copyFile)
private boolean checkHFilesCountPerRegionPerFamily(org.apache.hbase.thirdparty.com.google.common.collect.Multimap<ByteBuffer,LoadIncrementalHFiles.LoadQueueItem> regionGroups)
private Pair<org.apache.hbase.thirdparty.com.google.common.collect.Multimap<ByteBuffer,LoadIncrementalHFiles.LoadQueueItem>,Set<String>> groupOrSplitPhase(Table table, ExecutorService pool, Deque<LoadIncrementalHFiles.LoadQueueItem> queue, Pair<byte[][],byte[][]> startEndKeys) throws IOException
table - the table to load intopool - the ExecutorServicequeue - the queue for LoadQueueItemstartEndKeys - start and end keysIOExceptionprivate List<LoadIncrementalHFiles.LoadQueueItem> splitStoreFile(LoadIncrementalHFiles.LoadQueueItem item, Table table, byte[] startKey, byte[] splitKey) throws IOException
IOExceptionprivate int getRegionIndex(Pair<byte[][],byte[][]> startEndKeys, byte[] key)
startEndKeys - the start/end keys of regions belong to this table, the list in ascending
          order by start keykey - the key need to find which region belong toprivate void checkRegionIndexValid(int idx, Pair<byte[][],byte[][]> startEndKeys, TableName tableName) throws IOException
IOException@InterfaceAudience.Private protected Pair<List<LoadIncrementalHFiles.LoadQueueItem>,String> groupOrSplit(org.apache.hbase.thirdparty.com.google.common.collect.Multimap<ByteBuffer,LoadIncrementalHFiles.LoadQueueItem> regionGroups, LoadIncrementalHFiles.LoadQueueItem item, Table table, Pair<byte[][],byte[][]> startEndKeys) throws IOException
protected for testing
IOException - if an IO failure is encountered@Deprecated @InterfaceAudience.Private protected List<LoadIncrementalHFiles.LoadQueueItem> tryAtomicRegionLoad(Connection conn, TableName tableName, byte[] first, Collection<LoadIncrementalHFiles.LoadQueueItem> lqis, boolean copyFile) throws IOException
BulkLoadHFiles instead.NOTE: To maintain row atomicity guarantees, region server callable should succeed atomically and fails atomically.
Protected for testing.
IOException@Deprecated @InterfaceAudience.Private protected List<LoadIncrementalHFiles.LoadQueueItem> tryAtomicRegionLoad(ClientServiceCallable<byte[]> serviceCallable, TableName tableName, byte[] first, Collection<LoadIncrementalHFiles.LoadQueueItem> lqis) throws IOException
BulkLoadHFiles instead.NOTE: To maintain row atomicity guarantees, region server callable should succeed atomically and fails atomically.
Protected for testing.
IOExceptionprivate void createTable(TableName tableName, org.apache.hadoop.fs.Path hfofDir, Admin admin) throws IOException
IOExceptionprivate void cleanup(Admin admin, Deque<LoadIncrementalHFiles.LoadQueueItem> queue, ExecutorService pool, SecureBulkLoadClient secureClient) throws IOException
IOExceptionprivate String getUniqueName()
private void validateFamiliesInHFiles(Table table, Deque<LoadIncrementalHFiles.LoadQueueItem> queue, boolean silence) throws IOException
IOExceptionprivate void populateLoadQueue(Deque<LoadIncrementalHFiles.LoadQueueItem> ret, Map<byte[],List<org.apache.hadoop.fs.Path>> map)
private void discoverLoadQueue(Deque<LoadIncrementalHFiles.LoadQueueItem> ret, org.apache.hadoop.fs.Path hfofDir, boolean validateHFile) throws IOException
IOExceptionprivate static <TFamily> void visitBulkHFiles(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path bulkDir, LoadIncrementalHFiles.BulkHFileVisitor<TFamily> visitor) throws IOException
IOExceptionprivate static <TFamily> void visitBulkHFiles(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path bulkDir, LoadIncrementalHFiles.BulkHFileVisitor<TFamily> visitor, boolean validateHFile) throws IOException
IOExceptionprivate ExecutorService createExecutorService()
private boolean isSecureBulkLoadEndpointAvailable()
@InterfaceAudience.Private static void splitStoreFile(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.Path inFile, ColumnFamilyDescriptor familyDesc, byte[] splitKey, org.apache.hadoop.fs.Path bottomOut, org.apache.hadoop.fs.Path topOut) throws IOException
IOExceptionprivate static void copyHFileHalf(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.Path inFile, org.apache.hadoop.fs.Path outFile, Reference reference, ColumnFamilyDescriptor familyDescriptor) throws IOException
IOExceptionprivate static boolean shouldCopyHFileMetaKey(byte[] key)
private boolean isCreateTable()
private boolean isSilence()
private boolean isAlwaysCopyFiles()
protected final Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> run(org.apache.hadoop.fs.Path hfofDir, TableName tableName) throws IOException
IOExceptionpublic Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> run(String hfofDir, TableName tableName) throws IOException
hfofDir - the directory that was provided as the output path of a job using
          HFileOutputFormattableName - the table to load intoIOExceptionpublic Map<LoadIncrementalHFiles.LoadQueueItem,ByteBuffer> run(Map<byte[],List<org.apache.hadoop.fs.Path>> family2Files, TableName tableName) throws IOException
family2Files - map of family to List of hfilestableName - the table to load intoIOExceptionpublic int run(String[] args) throws Exception
run in interface org.apache.hadoop.util.ToolExceptionpublic void setBulkToken(String stagingDir)
stagingDir - staging directory pathpublic void setClusterIds(List<String> clusterIds)
public void disableReplication()
public static byte[][] inferBoundaries(SortedMap<byte[],Integer> bdryMap)
 Parameter: 
 bdryMap is a map between keys to an integer belonging to {+1, -1}
 
 Algo:
 
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.