You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@phoenix.apache.org by td...@apache.org on 2017/12/20 18:48:01 UTC

phoenix git commit: PHOENIX-4468 Looking up a parent index table of a child view from a different client fails

Repository: phoenix
Updated Branches:
  refs/heads/master 9d8be0e92 -> c935f57f5


PHOENIX-4468 Looking up a parent index table of a child view from a different client fails


Project: http://git-wip-us.apache.org/repos/asf/phoenix/repo
Commit: http://git-wip-us.apache.org/repos/asf/phoenix/commit/c935f57f
Tree: http://git-wip-us.apache.org/repos/asf/phoenix/tree/c935f57f
Diff: http://git-wip-us.apache.org/repos/asf/phoenix/diff/c935f57f

Branch: refs/heads/master
Commit: c935f57f5e7afb42ff8b62a4712ad7d8ffed17cc
Parents: 9d8be0e
Author: Thomas D'Silva <td...@apache.org>
Authored: Mon Dec 18 11:48:39 2017 -0800
Committer: Thomas D'Silva <td...@apache.org>
Committed: Wed Dec 20 10:41:12 2017 -0800

----------------------------------------------------------------------
 .../apache/phoenix/end2end/PhoenixDriverIT.java | 160 +++++++++++++++++++
 .../org/apache/phoenix/end2end/SequenceIT.java  |  29 ----
 phoenix-core/src/main/antlr3/PhoenixSQL.g       |   1 +
 .../apache/phoenix/schema/MetaDataClient.java   |   4 +-
 .../org/apache/phoenix/schema/PTableImpl.java   |   2 +-
 .../org/apache/phoenix/util/PhoenixRuntime.java |  32 +++-
 6 files changed, 189 insertions(+), 39 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/phoenix/blob/c935f57f/phoenix-core/src/it/java/org/apache/phoenix/end2end/PhoenixDriverIT.java
----------------------------------------------------------------------
diff --git a/phoenix-core/src/it/java/org/apache/phoenix/end2end/PhoenixDriverIT.java b/phoenix-core/src/it/java/org/apache/phoenix/end2end/PhoenixDriverIT.java
new file mode 100644
index 0000000..216653c
--- /dev/null
+++ b/phoenix-core/src/it/java/org/apache/phoenix/end2end/PhoenixDriverIT.java
@@ -0,0 +1,160 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.phoenix.end2end;
+
+import static org.junit.Assert.assertEquals;
+import static org.junit.Assert.assertFalse;
+import static org.junit.Assert.assertTrue;
+
+import java.sql.Connection;
+import java.sql.DriverManager;
+import java.sql.PreparedStatement;
+import java.sql.ResultSet;
+import java.sql.SQLException;
+import java.util.Properties;
+
+import org.apache.hadoop.conf.Configuration;
+import org.apache.hadoop.hbase.HBaseConfiguration;
+import org.apache.hadoop.hbase.HBaseTestingUtility;
+import org.apache.phoenix.jdbc.PhoenixDriver;
+import org.apache.phoenix.jdbc.PhoenixStatement;
+import org.apache.phoenix.query.QueryConstants;
+import org.apache.phoenix.query.QueryServices;
+import org.apache.phoenix.query.QueryServicesOptions;
+import org.apache.phoenix.schema.PTable;
+import org.apache.phoenix.util.PhoenixRuntime;
+import org.apache.phoenix.util.SchemaUtil;
+import org.junit.BeforeClass;
+import org.junit.Test;
+
+public class PhoenixDriverIT extends BaseUniqueNamesOwnClusterIT {
+    
+    private static HBaseTestingUtility hbaseTestUtil;
+    private static String zkQuorum;
+    
+    @BeforeClass
+    public static void setUp() throws Exception {
+        Configuration conf = HBaseConfiguration.create();
+        hbaseTestUtil = new HBaseTestingUtility(conf);
+        setUpConfigForMiniCluster(conf);
+        conf.set(QueryServices.EXTRA_JDBC_ARGUMENTS_ATTRIB, QueryServicesOptions.DEFAULT_EXTRA_JDBC_ARGUMENTS);
+        hbaseTestUtil.startMiniCluster();
+        // establish url and quorum. Need to use PhoenixDriver and not PhoenixTestDriver
+        zkQuorum = "localhost:" + hbaseTestUtil.getZkCluster().getClientPort();
+        url = PhoenixRuntime.JDBC_PROTOCOL + PhoenixRuntime.JDBC_PROTOCOL_SEPARATOR + zkQuorum;
+        DriverManager.registerDriver(PhoenixDriver.INSTANCE);
+    }
+    
+    public Connection createConnection(boolean isMultiTenant, boolean isDifferentClient) throws SQLException {
+        Properties props = new Properties();
+        props.setProperty(QueryServices.RETURN_SEQUENCE_VALUES_ATTRIB, "false");
+        // force the use of ConnectionQueryServicesImpl instead of ConnectionQueryServicesTestImpl
+        props.put(QueryServices.EXTRA_JDBC_ARGUMENTS_ATTRIB,
+            QueryServicesOptions.DEFAULT_EXTRA_JDBC_ARGUMENTS);
+        if (isMultiTenant)
+            props.setProperty(PhoenixRuntime.TENANT_ID_ATTRIB, "tenant1");
+        StringBuilder sb = new StringBuilder(url);
+        if (isMultiTenant)
+            sb.append(PhoenixRuntime.JDBC_PROTOCOL_SEPARATOR + "Client2");
+        return DriverManager.getConnection(sb.toString(), props);
+    }
+    
+    @Test
+    public void testReturnAllSequencesNotCalledForNoOpenConnections() throws Exception {
+        String schemaName = "S";
+        String sequenceNameWithoutSchema = generateUniqueSequenceName();
+        String sequenceName = SchemaUtil.getTableName(schemaName, sequenceNameWithoutSchema);
+        
+        Connection conn = createConnection(false, false);
+        conn.createStatement().execute("CREATE SEQUENCE " + sequenceName + " START WITH 3 INCREMENT BY 2 CACHE 5");
+        
+        String query = "SELECT NEXT VALUE FOR " + sequenceName ;
+        ResultSet rs = conn.prepareStatement(query).executeQuery();
+        assertTrue(rs.next());
+        assertEquals(3, rs.getInt(1));
+        assertFalse(rs.next());
+        rs = conn.prepareStatement(query).executeQuery();
+        assertTrue(rs.next());
+        assertEquals(5, rs.getInt(1));
+        assertFalse(rs.next());
+        conn.close();
+        
+        conn = createConnection(false, false);
+        // verify that calling close() does not return sequence values back to the server
+        query = "SELECT CURRENT_VALUE FROM \"SYSTEM\".\"SEQUENCE\" WHERE SEQUENCE_SCHEMA=? AND SEQUENCE_NAME=?";
+        PreparedStatement preparedStatement = conn.prepareStatement(query);
+        preparedStatement.setString(1, schemaName);
+        preparedStatement.setString(2, sequenceNameWithoutSchema);
+        rs = preparedStatement.executeQuery();
+        assertTrue(rs.next());
+        assertEquals(13, rs.getInt(1));
+        assertFalse(rs.next());
+        conn.close();
+    }
+    
+    @Test
+    public void testViewParentIndexLookupMutipleClients() throws Exception {
+        helpTestViewParentIndexLookupMutipleClients(false);
+    }
+    
+    @Test
+    public void testMulitTenantViewParentIndexLookupMutipleClients() throws Exception {
+        helpTestViewParentIndexLookupMutipleClients(true);
+    }
+    
+    public void helpTestViewParentIndexLookupMutipleClients(boolean isMultiTenant) throws Exception {
+        final String baseTableName = generateUniqueName();
+        final String baseTableIndexName = generateUniqueName();
+        final String viewName = generateUniqueName();
+        try (Connection globalConn = createConnection(false, false);
+                Connection conn1 = createConnection(isMultiTenant, false);
+                Connection conn2 = createConnection(isMultiTenant, false)) {
+            // create base table
+            String baseTableDdl = "CREATE TABLE " + baseTableName + " (" +
+                    ( isMultiTenant ? "TENANT_ID VARCHAR(1) NOT NULL," : "") +
+                    "PK CHAR(1) NOT NULL," +
+                    "V1 CHAR(1)," +
+                    "V2 CHAR(1)," +
+                    "V3 CHAR(1)" + 
+                    "CONSTRAINT pk PRIMARY KEY (" + (isMultiTenant ? "TENANT_ID," : "") + " pk))";
+            globalConn.createStatement().execute(baseTableDdl);
+            
+            // create index on parent view
+            globalConn.createStatement().execute("CREATE INDEX " + baseTableIndexName + " ON " + baseTableName + " (V2) INCLUDE (v1, V3)");
+            
+            // create a view on the base table
+            String viewDDL = "CREATE VIEW " + viewName + " AS SELECT * FROM " + baseTableName + " WHERE V1 = 'X'";
+            conn1.createStatement().execute(viewDDL);
+            conn1.commit();
+
+            // ensure we can use parent table index
+            String sql = "SELECT V3 FROM " + viewName +" WHERE V2 = '3'";
+            PhoenixStatement stmt = conn1.createStatement().unwrap(PhoenixStatement.class);
+            stmt.executeQuery(sql);
+            PTable indexTable = stmt.getQueryPlan().getTableRef().getTable();
+            String tableName = indexTable.getName().getString();
+            String expectedTableName = baseTableIndexName + QueryConstants.CHILD_VIEW_INDEX_NAME_SEPARATOR + viewName;
+            assertEquals("Parent Index table is not used ", expectedTableName, tableName);
+            
+            // verify that we can look up the index using PhoenixRuntime from a different client
+            PTable table = PhoenixRuntime.getTable(conn2, tableName);
+            assertEquals(indexTable, table);
+        }
+    }
+    
+}

http://git-wip-us.apache.org/repos/asf/phoenix/blob/c935f57f/phoenix-core/src/it/java/org/apache/phoenix/end2end/SequenceIT.java
----------------------------------------------------------------------
diff --git a/phoenix-core/src/it/java/org/apache/phoenix/end2end/SequenceIT.java b/phoenix-core/src/it/java/org/apache/phoenix/end2end/SequenceIT.java
index 3014e45..9b870e1 100644
--- a/phoenix-core/src/it/java/org/apache/phoenix/end2end/SequenceIT.java
+++ b/phoenix-core/src/it/java/org/apache/phoenix/end2end/SequenceIT.java
@@ -1358,35 +1358,6 @@ public class SequenceIT extends ParallelStatsDisabledIT {
         assertEquals(5, rs.getInt(2));        
     }
     
-    @Test
-    public void testReturnAllSequencesNotCalledForNoOpenConnections() throws Exception {
-        String sequenceName = generateSequenceNameWithSchema();
-        String sequenceNameWithoutSchema = getNameWithoutSchema(sequenceName);
-        String schemaName = getSchemaName(sequenceName);
-        
-        conn.createStatement().execute("CREATE SEQUENCE " + sequenceName + " START WITH 3 INCREMENT BY 2 CACHE 5");
-        
-        String query = "SELECT NEXT VALUE FOR " + sequenceName ;
-        ResultSet rs = conn.prepareStatement(query).executeQuery();
-        assertTrue(rs.next());
-        assertEquals(3, rs.getInt(1));
-        assertFalse(rs.next());
-        rs = conn.prepareStatement(query).executeQuery();
-        assertTrue(rs.next());
-        assertEquals(5, rs.getInt(1));
-        assertFalse(rs.next());
-        
-        // verify that calling close() does not return sequence values back to the server
-        query = "SELECT CURRENT_VALUE FROM \"SYSTEM\".\"SEQUENCE\" WHERE SEQUENCE_SCHEMA=? AND SEQUENCE_NAME=?";
-        PreparedStatement preparedStatement = conn.prepareStatement(query);
-        preparedStatement.setString(1, schemaName);
-        preparedStatement.setString(2, sequenceNameWithoutSchema);
-        rs = preparedStatement.executeQuery();
-        assertTrue(rs.next());
-        assertEquals(13, rs.getInt(1));
-        assertFalse(rs.next());
-    }
-    
     private static String getSchemaName(String tableName) {
     	return tableName.substring(0, tableName.indexOf("."));
     }

http://git-wip-us.apache.org/repos/asf/phoenix/blob/c935f57f/phoenix-core/src/main/antlr3/PhoenixSQL.g
----------------------------------------------------------------------
diff --git a/phoenix-core/src/main/antlr3/PhoenixSQL.g b/phoenix-core/src/main/antlr3/PhoenixSQL.g
index 87153cd..5e64984 100644
--- a/phoenix-core/src/main/antlr3/PhoenixSQL.g
+++ b/phoenix-core/src/main/antlr3/PhoenixSQL.g
@@ -1114,6 +1114,7 @@ from_table_name returns [TableName ret]
 table_identifier returns [String ret]
     :   c=identifier {
            if (c.contains(QueryConstants.NAMESPACE_SEPARATOR) ) { throw new RuntimeException("Table or schema name cannot contain colon"); }
+           if (c.contains(QueryConstants.CHILD_VIEW_INDEX_NAME_SEPARATOR) ) { throw new RuntimeException("Table or schema name cannot contain hash"); }
            $ret = c;
     }
     ;

http://git-wip-us.apache.org/repos/asf/phoenix/blob/c935f57f/phoenix-core/src/main/java/org/apache/phoenix/schema/MetaDataClient.java
----------------------------------------------------------------------
diff --git a/phoenix-core/src/main/java/org/apache/phoenix/schema/MetaDataClient.java b/phoenix-core/src/main/java/org/apache/phoenix/schema/MetaDataClient.java
index 5ec5ac3..403cbfe 100644
--- a/phoenix-core/src/main/java/org/apache/phoenix/schema/MetaDataClient.java
+++ b/phoenix-core/src/main/java/org/apache/phoenix/schema/MetaDataClient.java
@@ -854,8 +854,8 @@ public class MetaDataClient {
             if (containsAllReqdCols) {
                 // Tack on view statement to index to get proper filtering for view
                 String viewStatement = IndexUtil.rewriteViewStatement(connection, index, parentTable, view.getViewStatement());
-                PName modifiedIndexName = PNameFactory.newName(index.getSchemaName().getString() + QueryConstants.CHILD_VIEW_INDEX_NAME_SEPARATOR
-                        + index.getName().getString() + QueryConstants.CHILD_VIEW_INDEX_NAME_SEPARATOR + view.getName().getString());
+                PName modifiedIndexName = PNameFactory.newName(index.getName().getString() 
+                    + QueryConstants.CHILD_VIEW_INDEX_NAME_SEPARATOR + view.getName().getString());
                 // add the index table with a new name so that it does not conflict with the existing index table
                 // also set update cache frequency to never since the renamed index is not present on the server
                 indexesToAdd.add(PTableImpl.makePTable(index, modifiedIndexName, viewStatement, Long.MAX_VALUE, view.getTenantId()));

http://git-wip-us.apache.org/repos/asf/phoenix/blob/c935f57f/phoenix-core/src/main/java/org/apache/phoenix/schema/PTableImpl.java
----------------------------------------------------------------------
diff --git a/phoenix-core/src/main/java/org/apache/phoenix/schema/PTableImpl.java b/phoenix-core/src/main/java/org/apache/phoenix/schema/PTableImpl.java
index 9525127..7df2458 100644
--- a/phoenix-core/src/main/java/org/apache/phoenix/schema/PTableImpl.java
+++ b/phoenix-core/src/main/java/org/apache/phoenix/schema/PTableImpl.java
@@ -267,7 +267,7 @@ public class PTableImpl implements PTable {
     
     public static PTableImpl makePTable(PTable table, PName tableName, long timeStamp, List<PName> physicalNames, List<PTable> indexes, String viewStatement, long updateCacheFrequency, PName tenantId) throws SQLException {
             return new PTableImpl(
-                    tenantId, table.getSchemaName(), tableName, table.getType(), table.getIndexState(), timeStamp,
+                    tenantId, PNameImpl.EMPTY_NAME, tableName, table.getType(), table.getIndexState(), timeStamp,
                     table.getSequenceNumber(), table.getPKName(), table.getBucketNum(), getColumnsToClone(table), table.getParentSchemaName(), table.getParentTableName(),
                     indexes, table.isImmutableRows(), physicalNames, table.getDefaultFamilyName(), viewStatement,
                     table.isWALDisabled(), table.isMultiTenant(), table.getStoreNulls(), table.getViewType(), table.getViewIndexId(), table.getIndexType(),

http://git-wip-us.apache.org/repos/asf/phoenix/blob/c935f57f/phoenix-core/src/main/java/org/apache/phoenix/util/PhoenixRuntime.java
----------------------------------------------------------------------
diff --git a/phoenix-core/src/main/java/org/apache/phoenix/util/PhoenixRuntime.java b/phoenix-core/src/main/java/org/apache/phoenix/util/PhoenixRuntime.java
index 16ef206..31ab194 100644
--- a/phoenix-core/src/main/java/org/apache/phoenix/util/PhoenixRuntime.java
+++ b/phoenix-core/src/main/java/org/apache/phoenix/util/PhoenixRuntime.java
@@ -430,8 +430,15 @@ public class PhoenixRuntime {
         return result.getTable();
 
     }
+    
     /**
-     * 
+     * Returns the table if it is found in the connection metadata cache. If the metadata of this
+     * table has changed since it was put in the cache these changes will not necessarily be
+     * reflected in the returned table. If the table is not found, makes a call to the server to
+     * fetch the latest metadata of the table. This is different than how a table is resolved when
+     * it is referenced from a query (a call is made to the server to fetch the latest metadata of the table
+     * depending on the UPDATE_CACHE_FREQUENCY property)
+     * See https://issues.apache.org/jira/browse/PHOENIX-4475
      * @param conn
      * @param name requires a pre-normalized table name or a pre-normalized schema and table name
      * @return
@@ -443,13 +450,24 @@ public class PhoenixRuntime {
         try {
             table = pconn.getTable(new PTableKey(pconn.getTenantId(), name));
         } catch (TableNotFoundException e) {
-            String schemaName = SchemaUtil.getSchemaNameFromFullName(name);
-            String tableName = SchemaUtil.getTableNameFromFullName(name);
-            MetaDataMutationResult result = new MetaDataClient(pconn).updateCache(schemaName, tableName);
-            if (result.getMutationCode() != MutationCode.TABLE_ALREADY_EXISTS) {
-                throw e;
+            // parent indexes on child view metadata rows are not present on the server
+            if (name.contains(QueryConstants.CHILD_VIEW_INDEX_NAME_SEPARATOR)) {
+                String viewName =
+                        SchemaUtil.getTableNameFromFullName(name,
+                            QueryConstants.CHILD_VIEW_INDEX_NAME_SEPARATOR);
+                // resolve the view which should also load any parent indexes
+                getTable(conn, viewName);
+                table = pconn.getTable(new PTableKey(pconn.getTenantId(), name));
+            } else {
+                String schemaName = SchemaUtil.getSchemaNameFromFullName(name);
+                String tableName = SchemaUtil.getTableNameFromFullName(name);
+                MetaDataMutationResult result =
+                        new MetaDataClient(pconn).updateCache(schemaName, tableName);
+                if (result.getMutationCode() != MutationCode.TABLE_ALREADY_EXISTS) {
+                    throw e;
+                }
+                table = result.getTable();
             }
-            table = result.getTable();
         }
         return table;
     }