Class ProcedureWALFormatReader

java.lang.Object
org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormatReader

Deprecated.
Since 2.3.0, will be removed in 4.0.0. Keep here only for rolling upgrading, now we use the new region based procedure store.
Helper class that loads the procedures stored in a WAL.
  • Field Details

    • LOG

      private static final org.slf4j.Logger LOG
      Deprecated.
    • localProcedureMap

      Deprecated.
      We will use the localProcedureMap to track the active procedures for the current proc wal file, and when we finished reading one proc wal file, we will merge he localProcedureMap to the procedureMap, which tracks the global active procedures.

      See the comments of WALProcedureMap for more details.

      After reading all the proc wal files, we will use the procedures in the procedureMap to build a ProcedureTree, and then give the result to the upper layer. See the comments of ProcedureTree and the code in finish() for more details.

    • procedureMap

      Deprecated.
    • loader

      Deprecated.
    • tracker

      Deprecated.
      Global tracker that will be used by the WALProcedureStore after load. If the last WAL was closed cleanly we already have a full tracker ready to be used. If the last WAL was truncated (e.g. master killed) the tracker will be empty and the 'partial' flag will be set. In this case, on WAL replay we are going to rebuild the tracker.
    • localTracker

      Deprecated.
      If tracker for a log file is partial (see ProcedureStoreTracker.partial), we re-build the list of procedures modified in that WAL because we need it for log cleaning purposes. If all procedures modified in a WAL are found to be obsolete, it can be safely deleted. (see WALProcedureStore.removeInactiveLogs()).

      Notice that, the deleted part for this tracker will not be global valid as we can only count the deletes in the current file, but it is not big problem as finally, the above tracker will have the global state of deleted, and it will also be used to build the cleanup tracker.

    • maxProcId

      private long maxProcId
      Deprecated.
  • Constructor Details

  • Method Details

    • read

      public void read(ProcedureWALFile log) throws IOException
      Deprecated.
      Throws:
      IOException
    • finish

      public void finish() throws IOException
      Deprecated.
      Throws:
      IOException
    • setDeletedIfPartial

      private void setDeletedIfPartial(ProcedureStoreTracker tracker, long procId)
      Deprecated.
    • insertIfPartial

      private void insertIfPartial(ProcedureStoreTracker tracker, org.apache.hadoop.hbase.shaded.protobuf.generated.ProcedureProtos.Procedure proc)
      Deprecated.
    • loadProcedure

      private void loadProcedure(org.apache.hadoop.hbase.shaded.protobuf.generated.ProcedureProtos.ProcedureWALEntry entry, org.apache.hadoop.hbase.shaded.protobuf.generated.ProcedureProtos.Procedure proc)
      Deprecated.
    • readInitEntry

      private void readInitEntry(org.apache.hadoop.hbase.shaded.protobuf.generated.ProcedureProtos.ProcedureWALEntry entry)
      Deprecated.
    • readInsertEntry

      private void readInsertEntry(org.apache.hadoop.hbase.shaded.protobuf.generated.ProcedureProtos.ProcedureWALEntry entry)
      Deprecated.
    • readUpdateEntry

      private void readUpdateEntry(org.apache.hadoop.hbase.shaded.protobuf.generated.ProcedureProtos.ProcedureWALEntry entry)
      Deprecated.
    • readDeleteEntry

      private void readDeleteEntry(org.apache.hadoop.hbase.shaded.protobuf.generated.ProcedureProtos.ProcedureWALEntry entry)
      Deprecated.
    • deleteEntry

      private void deleteEntry(long procId)
      Deprecated.
    • isDeleted

      private boolean isDeleted(long procId)
      Deprecated.
    • isRequired

      private boolean isRequired(long procId)
      Deprecated.