Uploaded image for project: 'Phoenix'
  1. Phoenix
  2. PHOENIX-5941

org.apache.phoenix.query.ConnectionQueryServices.getAdmin()Lorg/apache/hadoop/hbase/client/HBaseAdmin

    XMLWordPrintableJSON

Details

    • Bug
    • Status: Resolved
    • Major
    • Resolution: Cannot Reproduce
    • 5.0.0
    • None
    • spark-connector
    • None

    Description

      Error while trying to execute a show from a DataFrame created with Phoenix table.
       
      scala> df.filter(df("COL1") === "test_row_1" && df("ID") === 1L).select(df("ID")).show
      java.lang.NoSuchMethodError: org.apache.phoenix.query.ConnectionQueryServices.getAdmin()Lorg/apache/hadoop/hbase/client/HBaseAdmin;
        at org.apache.phoenix.spark.datasource.v2.reader.PhoenixDataSourceReader.planInputPartitions(PhoenixDataSourceReader.java:165)
        at org.apache.spark.sql.execution.datasources.v2.DataSourceV2ScanExec.partitions$lzycompute(DataSourceV2ScanExec.scala:76)
        at org.apache.spark.sql.execution.datasources.v2.DataSourceV2ScanExec.partitions(DataSourceV2ScanExec.scala:75)
        at org.apache.spark.sql.execution.datasources.v2.DataSourceV2ScanExec.outputPartitioning(DataSourceV2ScanExec.scala:65)
        at org.apache.spark.sql.execution.exchange.EnsureRequirements$$anonfun$org$apache$spark$sql$execution$exchange$EnsureRequirements$$ensureDistributionAndOrdering$1.apply(EnsureRequirements.scala:149)
        at org.apache.spark.sql.execution.exchange.EnsureRequirements$$anonfun$org$apache$spark$sql$execution$exchange$EnsureRequirements$$ensureDistributionAndOrdering$1.apply(EnsureRequirements.scala:148)
        at scala.collection.TraversableLike$$anonfun$map$1.apply(TraversableLike.scala:234)
        at scala.collection.TraversableLike$$anonfun$map$1.apply(TraversableLike.scala:234)
        at scala.collection.immutable.List.foreach(List.scala:392)
        at scala.collection.TraversableLike$class.map(TraversableLike.scala:234)
        at scala.collection.immutable.List.map(List.scala:296)
        at

      Attachments

        Activity

          People

            Unassigned Unassigned
            jlunna Lunna
            Votes:
            0 Vote for this issue
            Watchers:
            2 Start watching this issue

            Dates

              Created:
              Updated:
              Resolved: