| Package | Description | 
|---|---|
| org.apache.hadoop.hbase.master.region | |
| org.apache.hadoop.hbase.regionserver | |
| org.apache.hadoop.hbase.replication | Multi Cluster Replication | 
| org.apache.hadoop.hbase.replication.regionserver | |
| org.apache.hadoop.hbase.wal | 
| Modifier and Type | Field and Description | 
|---|---|
| private WALFactory | MasterRegion. walFactory | 
| Modifier and Type | Method and Description | 
|---|---|
| private static HRegion | MasterRegion. bootstrap(org.apache.hadoop.conf.Configuration conf,
         TableDescriptor td,
         org.apache.hadoop.fs.FileSystem fs,
         org.apache.hadoop.fs.Path rootDir,
         org.apache.hadoop.fs.FileSystem walFs,
         org.apache.hadoop.fs.Path walRootDir,
         WALFactory walFactory,
         MasterRegionWALRoller walRoller,
         String serverName) | 
| private static WAL | MasterRegion. createWAL(WALFactory walFactory,
         MasterRegionWALRoller walRoller,
         String serverName,
         org.apache.hadoop.fs.FileSystem walFs,
         org.apache.hadoop.fs.Path walRootDir,
         RegionInfo regionInfo) | 
| private static HRegion | MasterRegion. open(org.apache.hadoop.conf.Configuration conf,
    TableDescriptor td,
    org.apache.hadoop.fs.FileSystem fs,
    org.apache.hadoop.fs.Path rootDir,
    org.apache.hadoop.fs.FileSystem walFs,
    org.apache.hadoop.fs.Path walRootDir,
    WALFactory walFactory,
    MasterRegionWALRoller walRoller,
    String serverName) | 
| Constructor and Description | 
|---|
| MasterRegion(HRegion region,
            WALFactory walFactory,
            MasterRegionFlusherAndCompactor flusherAndCompactor,
            MasterRegionWALRoller walRoller) | 
| Modifier and Type | Field and Description | 
|---|---|
| private WALFactory | HRegionServer. walFactory | 
| Modifier and Type | Method and Description | 
|---|---|
| (package private) WALFactory | HRegionServer. getWalFactory() | 
| Modifier and Type | Method and Description | 
|---|---|
| private static void | HRegionServer. createNewReplicationInstance(org.apache.hadoop.conf.Configuration conf,
                            HRegionServer server,
                            org.apache.hadoop.fs.FileSystem walFs,
                            org.apache.hadoop.fs.Path walDir,
                            org.apache.hadoop.fs.Path oldWALDir,
                            WALFactory walFactory)Load the replication executorService objects, if any | 
| void | ReplicationService. initialize(Server rs,
          org.apache.hadoop.fs.FileSystem fs,
          org.apache.hadoop.fs.Path logdir,
          org.apache.hadoop.fs.Path oldLogDir,
          WALFactory walFactory)Initializes the replication service object. | 
| private static <T extends ReplicationService> | HRegionServer. newReplicationInstance(String classname,
                      Class<T> xface,
                      org.apache.hadoop.conf.Configuration conf,
                      HRegionServer server,
                      org.apache.hadoop.fs.FileSystem walFs,
                      org.apache.hadoop.fs.Path logDir,
                      org.apache.hadoop.fs.Path oldLogDir,
                      WALFactory walFactory) | 
| (package private) static SplitLogWorker.TaskExecutor.Status | SplitLogWorker. splitLog(String filename,
        CancelableProgressable p,
        org.apache.hadoop.conf.Configuration conf,
        RegionServerServices server,
        LastSequenceId sequenceIdChecker,
        WALFactory factory)Deprecated.  | 
| Constructor and Description | 
|---|
| SplitLogWorker(org.apache.hadoop.conf.Configuration conf,
              RegionServerServices server,
              LastSequenceId sequenceIdChecker,
              WALFactory factory)Deprecated.  | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ReplicationSinkServiceImpl. initialize(Server server,
          org.apache.hadoop.fs.FileSystem fs,
          org.apache.hadoop.fs.Path logdir,
          org.apache.hadoop.fs.Path oldLogDir,
          WALFactory walFactory) | 
| Modifier and Type | Field and Description | 
|---|---|
| private WALFactory | ReplicationSourceManager. walFactory | 
| Modifier and Type | Method and Description | 
|---|---|
| void | Replication. initialize(Server server,
          org.apache.hadoop.fs.FileSystem fs,
          org.apache.hadoop.fs.Path logDir,
          org.apache.hadoop.fs.Path oldLogDir,
          WALFactory walFactory) | 
| Constructor and Description | 
|---|
| ReplicationSourceManager(ReplicationQueueStorage queueStorage,
                        ReplicationPeers replicationPeers,
                        ReplicationTracker replicationTracker,
                        org.apache.hadoop.conf.Configuration conf,
                        Server server,
                        org.apache.hadoop.fs.FileSystem fs,
                        org.apache.hadoop.fs.Path logDir,
                        org.apache.hadoop.fs.Path oldLogDir,
                        UUID clusterId,
                        WALFactory walFactory,
                        MetricsReplicationGlobalSourceSource globalMetrics)Creates a replication manager and sets the watch on all the other registered region servers | 
| Modifier and Type | Field and Description | 
|---|---|
| private WALFactory | RegionGroupingProvider. factory | 
| protected WALFactory | AbstractFSWALProvider. factory | 
| private WALFactory | WALSplitter. walFactory | 
| Modifier and Type | Field and Description | 
|---|---|
| private static AtomicReference<WALFactory> | WALFactory. singleton | 
| Modifier and Type | Method and Description | 
|---|---|
| static WALFactory | WALFactory. getInstance(org.apache.hadoop.conf.Configuration configuration) | 
| (package private) WALFactory | WALSplitter. getWalFactory() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | RegionGroupingProvider. init(WALFactory factory,
    org.apache.hadoop.conf.Configuration conf,
    String providerId,
    Abortable abortable) | 
| void | WALProvider. init(WALFactory factory,
    org.apache.hadoop.conf.Configuration conf,
    String providerId,
    Abortable abortable)Set up the provider to create wals. | 
| void | DisabledWALProvider. init(WALFactory factory,
    org.apache.hadoop.conf.Configuration conf,
    String providerId,
    Abortable abortable) | 
| void | AbstractFSWALProvider. init(WALFactory factory,
    org.apache.hadoop.conf.Configuration conf,
    String providerId,
    Abortable abortable) | 
| static List<org.apache.hadoop.fs.Path> | WALSplitter. split(org.apache.hadoop.fs.Path walRootDir,
     org.apache.hadoop.fs.Path walsDir,
     org.apache.hadoop.fs.Path archiveDir,
     org.apache.hadoop.fs.FileSystem walFS,
     org.apache.hadoop.conf.Configuration conf,
     WALFactory factory)Split a folder of WAL files. | 
| static boolean | WALSplitter. splitLogFile(org.apache.hadoop.fs.Path walDir,
            org.apache.hadoop.fs.FileStatus logfile,
            org.apache.hadoop.fs.FileSystem walFS,
            org.apache.hadoop.conf.Configuration conf,
            CancelableProgressable reporter,
            LastSequenceId idChecker,
            SplitLogWorkerCoordination splitLogWorkerCoordination,
            WALFactory factory,
            RegionServerServices rsServices)Splits a WAL file. | 
| Constructor and Description | 
|---|
| WALSplitter(WALFactory factory,
           org.apache.hadoop.conf.Configuration conf,
           org.apache.hadoop.fs.Path walRootDir,
           org.apache.hadoop.fs.FileSystem walFS,
           org.apache.hadoop.fs.Path rootDir,
           org.apache.hadoop.fs.FileSystem rootFS) | 
| WALSplitter(WALFactory factory,
           org.apache.hadoop.conf.Configuration conf,
           org.apache.hadoop.fs.Path walRootDir,
           org.apache.hadoop.fs.FileSystem walFS,
           org.apache.hadoop.fs.Path rootDir,
           org.apache.hadoop.fs.FileSystem rootFS,
           LastSequenceId idChecker,
           SplitLogWorkerCoordination splitLogWorkerCoordination,
           RegionServerServices rsServices) | 
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.