You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@phoenix.apache.org by el...@apache.org on 2018/01/03 17:20:53 UTC

phoenix git commit: PHOENIX-4512 Cell.DataType was renamed to Cell.Type

Repository: phoenix
Updated Branches:
  refs/heads/5.x-HBase-2.0 69611a983 -> cf3e370ee


PHOENIX-4512 Cell.DataType was renamed to Cell.Type

Signed-off-by: Sergey Soldatov <ss...@apache.org>


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

Branch: refs/heads/5.x-HBase-2.0
Commit: cf3e370ee1c98d0a06475a66e5ccd3a4ad7d0239
Parents: 69611a9
Author: Josh Elser <el...@apache.org>
Authored: Tue Jan 2 18:11:39 2018 -0500
Committer: Josh Elser <el...@apache.org>
Committed: Wed Jan 3 11:58:18 2018 -0500

----------------------------------------------------------------------
 .../src/main/java/org/apache/phoenix/util/IndexUtil.java  |  2 +-
 .../java/org/apache/phoenix/util/PhoenixKeyValueUtil.java | 10 +++++-----
 .../hadoop/hbase/ipc/PhoenixIndexRpcSchedulerTest.java    |  3 ++-
 .../org/apache/phoenix/execute/UnnestArrayPlanTest.java   |  2 +-
 .../query/EncodedColumnQualifierCellsListTest.java        |  2 +-
 5 files changed, 10 insertions(+), 9 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/phoenix/blob/cf3e370e/phoenix-core/src/main/java/org/apache/phoenix/util/IndexUtil.java
----------------------------------------------------------------------
diff --git a/phoenix-core/src/main/java/org/apache/phoenix/util/IndexUtil.java b/phoenix-core/src/main/java/org/apache/phoenix/util/IndexUtil.java
index 6925ac6..5e97ce6 100644
--- a/phoenix-core/src/main/java/org/apache/phoenix/util/IndexUtil.java
+++ b/phoenix-core/src/main/java/org/apache/phoenix/util/IndexUtil.java
@@ -661,7 +661,7 @@ public class IndexUtil {
                 }
 
                 @Override
-                public DataType getType() {
+                public Type getType() {
                     return cell.getType();
                 }
             };

http://git-wip-us.apache.org/repos/asf/phoenix/blob/cf3e370e/phoenix-core/src/main/java/org/apache/phoenix/util/PhoenixKeyValueUtil.java
----------------------------------------------------------------------
diff --git a/phoenix-core/src/main/java/org/apache/phoenix/util/PhoenixKeyValueUtil.java b/phoenix-core/src/main/java/org/apache/phoenix/util/PhoenixKeyValueUtil.java
index d041f55..84525fd 100644
--- a/phoenix-core/src/main/java/org/apache/phoenix/util/PhoenixKeyValueUtil.java
+++ b/phoenix-core/src/main/java/org/apache/phoenix/util/PhoenixKeyValueUtil.java
@@ -25,7 +25,7 @@ import java.util.Map;
 import java.util.Map.Entry;
 
 import org.apache.hadoop.hbase.Cell;
-import org.apache.hadoop.hbase.Cell.DataType;
+import org.apache.hadoop.hbase.Cell.Type;
 import org.apache.hadoop.hbase.CellBuilderFactory;
 import org.apache.hadoop.hbase.CellBuilderType;
 import org.apache.hadoop.hbase.CellUtil;
@@ -57,26 +57,26 @@ public class PhoenixKeyValueUtil {
 
     public static Cell newKeyValue(byte[] key, byte[] cf, byte[] cq, long ts, byte[] value, int valueOffset, int valueLength) {
         return CellBuilderFactory.create(CellBuilderType.DEEP_COPY).setRow(key).setFamily(cf)
-                .setQualifier(cq).setTimestamp(ts).setType(DataType.Put)
+                .setQualifier(cq).setTimestamp(ts).setType(Type.Put)
                 .setValue(value, valueOffset, valueLength).build();
     }
 
     public static Cell newKeyValue(ImmutableBytesWritable key, byte[] cf, byte[] cq, long ts, byte[] value, int valueOffset, int valueLength) {
         return CellBuilderFactory.create(CellBuilderType.DEEP_COPY)
                 .setRow(key.get(), key.getOffset(), key.getLength()).setFamily(cf).setQualifier(cq)
-                .setTimestamp(ts).setType(DataType.Put).setValue(value, valueOffset, valueLength)
+                .setTimestamp(ts).setType(Type.Put).setValue(value, valueOffset, valueLength)
                 .build();
     }
 
     public static Cell newKeyValue(byte[] key, int keyOffset, int keyLength, byte[] cf, byte[] cq, long ts, byte[] value, int valueOffset, int valueLength) {
         return CellBuilderFactory.create(CellBuilderType.DEEP_COPY)
                 .setRow(key, keyOffset, keyLength).setFamily(cf).setQualifier(cq).setTimestamp(ts)
-                .setType(DataType.Put).setValue(value, valueOffset, valueLength).build();
+                .setType(Type.Put).setValue(value, valueOffset, valueLength).build();
     }
     
     public static Cell newKeyValue(byte[] key, int keyOffset, int keyLength, byte[] cf, 
         int cfOffset, int cfLength, byte[] cq, int cqOffset, int cqLength, long ts, byte[] value, 
-        int valueOffset, int valueLength,DataType type) {
+        int valueOffset, int valueLength,Type type) {
         return CellBuilderFactory.create(CellBuilderType.DEEP_COPY)
                 .setRow(key, keyOffset, keyLength).setFamily(cf, cfOffset, cfLength)
                 .setQualifier(cq, cqOffset, cqLength).setTimestamp(ts)

http://git-wip-us.apache.org/repos/asf/phoenix/blob/cf3e370e/phoenix-core/src/test/java/org/apache/hadoop/hbase/ipc/PhoenixIndexRpcSchedulerTest.java
----------------------------------------------------------------------
diff --git a/phoenix-core/src/test/java/org/apache/hadoop/hbase/ipc/PhoenixIndexRpcSchedulerTest.java b/phoenix-core/src/test/java/org/apache/hadoop/hbase/ipc/PhoenixIndexRpcSchedulerTest.java
index 3b80159..d129afd 100644
--- a/phoenix-core/src/test/java/org/apache/hadoop/hbase/ipc/PhoenixIndexRpcSchedulerTest.java
+++ b/phoenix-core/src/test/java/org/apache/hadoop/hbase/ipc/PhoenixIndexRpcSchedulerTest.java
@@ -32,11 +32,12 @@ import org.apache.hadoop.hbase.Abortable;
 import org.apache.hadoop.hbase.HBaseConfiguration;
 import org.apache.hadoop.hbase.ipc.RpcScheduler.Context;
 import org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterface;
-import org.apache.hadoop.hbase.shaded.com.google.common.collect.Lists;
 import org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.RequestHeader;
 import org.junit.Test;
 import org.mockito.Mockito;
 
+import com.google.common.collect.Lists;
+
 /**
  * Test that the rpc scheduler schedules index writes to the index handler queue and sends
  * everything else to the standard queues

http://git-wip-us.apache.org/repos/asf/phoenix/blob/cf3e370e/phoenix-core/src/test/java/org/apache/phoenix/execute/UnnestArrayPlanTest.java
----------------------------------------------------------------------
diff --git a/phoenix-core/src/test/java/org/apache/phoenix/execute/UnnestArrayPlanTest.java b/phoenix-core/src/test/java/org/apache/phoenix/execute/UnnestArrayPlanTest.java
index 1b521e1..2894e92 100644
--- a/phoenix-core/src/test/java/org/apache/phoenix/execute/UnnestArrayPlanTest.java
+++ b/phoenix-core/src/test/java/org/apache/phoenix/execute/UnnestArrayPlanTest.java
@@ -161,7 +161,7 @@ public class UnnestArrayPlanTest {
         for (Object[] array : arrays) {
             PhoenixArray pArray = new PhoenixArray(baseType, array);
             byte[] bytes = arrayType.toBytes(pArray);            
-            tuples.add(new SingleKeyValueTuple(PhoenixKeyValueUtil.newKeyValue(bytes, 0, bytes.length, bytes, 0, 0, bytes, 0, 0, 0, bytes, 0, 0, Cell.DataType.Put)));
+            tuples.add(new SingleKeyValueTuple(PhoenixKeyValueUtil.newKeyValue(bytes, 0, bytes.length, bytes, 0, 0, bytes, 0, 0, 0, bytes, 0, 0, Cell.Type.Put)));
         }
         
         return tuples;

http://git-wip-us.apache.org/repos/asf/phoenix/blob/cf3e370e/phoenix-core/src/test/java/org/apache/phoenix/query/EncodedColumnQualifierCellsListTest.java
----------------------------------------------------------------------
diff --git a/phoenix-core/src/test/java/org/apache/phoenix/query/EncodedColumnQualifierCellsListTest.java b/phoenix-core/src/test/java/org/apache/phoenix/query/EncodedColumnQualifierCellsListTest.java
index 51dd3b9..95e038b 100644
--- a/phoenix-core/src/test/java/org/apache/phoenix/query/EncodedColumnQualifierCellsListTest.java
+++ b/phoenix-core/src/test/java/org/apache/phoenix/query/EncodedColumnQualifierCellsListTest.java
@@ -579,7 +579,7 @@ public class EncodedColumnQualifierCellsListTest {
         }
 
         @Override
-        public DataType getType() {
+        public Type getType() {
             return delegate.getType();
         }
     }