Uploaded image for project: 'Apache Trafodion (Retired)'
  1. Apache Trafodion (Retired)
  2. TRAFODION-1184

LP Bug: 1445245 - Trafodion initialize failed due to Cloudera Configuration problem

    XMLWordPrintableJSON

Details

    • Bug
    • Status: Closed
    • Critical
    • Resolution: Fixed
    • None
    • None
    • installer
    • None

    Description

      Symptom:
      >>initialize trafodion;

          • ERROR[8448] Unable to access Hbase interface. Call to ExpHbaseInterface::rowExists returned error HBASE_ACCESS_ERROR(-705). Cause:
            java.io.IOException: Problem with calling coprocessor, no regions returned result
            org.apache.hadoop.hbase.client.transactional.TransactionalTable.checkAndPut(TransactionalTable.java:451)
            org.apache.hadoop.hbase.client.transactional.RMInterface.checkAndPut(RMInterface.java:281)
            org.trafodion.sql.HBaseAccess.HTableClient.putRow(HTableClient.java:889)
            org.trafodion.sql.HBaseAccess.HTableClient.checkAndInsertRow(HTableClient.java:965)

      hbase shell list shows trafodion objects stop at TRAFODION.MD.VIEWS_USAGE and

      TRAFODION.REPOS.METRIC_QUERY_AGGR_TABLE
      TRAFODION.REPOS.METRIC_QUERY_TABLE
      TRAFODION.REPOS.METRIC_SESSION_TABLE
      TRAFODION.REPOS.METRIC_TEXT_TABLE

      Cause:
      Presence of both a RegionServer Default Group AND RegionServer Group 1
      After install, only the RegionServer Default Group had coprocessor information
      org.apache.hadoop.hbase.coprocessor.transactional.TrxRegionObserver,org.apache.hadoop.hbase.coprocessor.transactional.TrxRegionEndpoint,org.apache.hadoop.hbase.coprocessor.AggregateImplementation

      Solution:
      remove region server using wrong group and add using Default Group
      remove RegionServer Group 1

      Prevention:

      The install scanner should verify all regionservers used by trafodion use the same RegionServer Default Group

      After the trafodion mods are run, perhaps the regionserver xml files could be checked.

      Attachments

        Activity

          People

            amoran Amanda Moran
            ctjepkema Chris Tjepkema
            Votes:
            0 Vote for this issue
            Watchers:
            2 Start watching this issue

            Dates

              Created:
              Updated:
              Resolved: