You are viewing a plain text version of this content. The canonical link for it is here.
Posted to notifications@shardingsphere.apache.org by GitBox <gi...@apache.org> on 2020/03/20 18:36:25 UTC

[GitHub] [incubator-shardingsphere] ranjeet-floyd opened a new pull request #4871: Fixed issue- #4645 | Use YAML configuration for java AbstractEncrypt…

ranjeet-floyd opened a new pull request #4871: Fixed issue- #4645 | Use YAML configuration for java  AbstractEncrypt…
URL: https://github.com/apache/incubator-shardingsphere/pull/4871
 
 
   
   
   Fixes #4645.
   
   Changes proposed in this pull request:
   -  Used YAML configuration instead of java configuration for AbstractEncryptJDBCDatabaseAndTableTest.java
   
   

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [incubator-shardingsphere] kimmking commented on a change in pull request #4871: Fixed issue- #4645 | Use YAML configuration for java AbstractEncrypt…

Posted by GitBox <gi...@apache.org>.
kimmking commented on a change in pull request #4871: Fixed issue- #4645 | Use YAML configuration for java  AbstractEncrypt…
URL: https://github.com/apache/incubator-shardingsphere/pull/4871#discussion_r395984495
 
 

 ##########
 File path: sharding-jdbc/sharding-jdbc-core/src/test/resources/encrypt_data.yaml
 ##########
 @@ -0,0 +1,52 @@
+#/*
+#  * 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.
+#  */
+
+RunScript: "DELETE FROM t_encrypt; \n
+  DELETE FROM t_query_encrypt; \n
+  DELETE FROM t_encrypt_contains_column; \n
+  INSERT INTO t_encrypt VALUES(1, 'plainValue'); \n
+  INSERT INTO t_encrypt VALUES(5, 'plainValue'); \n
+  INSERT INTO t_query_encrypt VALUES(1, 'plainValue'); \n
+  INSERT INTO t_query_encrypt VALUES(5, 'plainValue'); \n
+  INSERT INTO t_encrypt_contains_column VALUES(1, 'plainValue', 'plainValue');"
+
+t_encrypt:
+    plainColumn: "plain_pwd"
+    cipherColumn: "cipher_pwd"
+    assistedQueryColumn: ""
+    encryptor: "test"
+
+t_query_encrypt:
+    plainColumn: ""
+    cipherColumn: "cipher_pwd"
+    assistedQueryColumn: "assist_pwd"
+    encryptor: "assistedTest"
+
+t_encrypt1:
+    plainColumn: "plain_pwd"
+    cipherColumn: "cipher_pwd"
+    assistedQueryColumn: ""
+    encryptor: "test"
+t_encrypt2:
+    plainColumn: "plain_pwd2"
+    cipherColumn: "cipher_pwd2"
+    assistedQueryColumn: ""
+    encryptor: "test"
+
 
 Review comment:
   only one empty line at the tail.

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [incubator-shardingsphere] terrymanu commented on issue #4871: Fixed issue- #4645 | Use YAML configuration for java AbstractEncrypt…

Posted by GitBox <gi...@apache.org>.
terrymanu commented on issue #4871: Fixed issue- #4645 | Use YAML configuration for java  AbstractEncrypt…
URL: https://github.com/apache/incubator-shardingsphere/pull/4871#issuecomment-603137173
 
 
   @ranjeet-floyd  Thank you, Please fix CI.

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [incubator-shardingsphere] ranjeet-floyd commented on a change in pull request #4871: Fixed issue- #4645 | Use YAML configuration for java AbstractEncrypt…

Posted by GitBox <gi...@apache.org>.
ranjeet-floyd commented on a change in pull request #4871: Fixed issue- #4645 | Use YAML configuration for java  AbstractEncrypt…
URL: https://github.com/apache/incubator-shardingsphere/pull/4871#discussion_r396677315
 
 

 ##########
 File path: sharding-jdbc/sharding-jdbc-core/src/test/java/org/apache/shardingsphere/shardingjdbc/common/base/AbstractEncryptJDBCDatabaseAndTableTest.java
 ##########
 @@ -17,87 +17,90 @@
 
 package org.apache.shardingsphere.shardingjdbc.common.base;
 
+import com.google.common.base.Preconditions;
 import com.google.common.collect.Maps;
+import java.io.File;
+import java.io.IOException;
+import java.io.InputStreamReader;
+import java.sql.SQLException;
+import java.util.Collections;
+import java.util.LinkedHashMap;
+import java.util.List;
+import java.util.Map;
+import java.util.Properties;
+import javax.sql.DataSource;
 import org.apache.shardingsphere.encrypt.api.EncryptColumnRuleConfiguration;
 import org.apache.shardingsphere.encrypt.api.EncryptRuleConfiguration;
 import org.apache.shardingsphere.encrypt.api.EncryptTableRuleConfiguration;
 import org.apache.shardingsphere.encrypt.api.EncryptorRuleConfiguration;
 import org.apache.shardingsphere.encrypt.rule.EncryptRule;
+import org.apache.shardingsphere.encrypt.yaml.config.YamlEncryptColumnRuleConfiguration;
+import org.apache.shardingsphere.encrypt.yaml.config.YamlEncryptRuleConfiguration;
+import org.apache.shardingsphere.encrypt.yaml.config.YamlEncryptTableRuleConfiguration;
+import org.apache.shardingsphere.encrypt.yaml.config.YamlEncryptorRuleConfiguration;
 import org.apache.shardingsphere.shardingjdbc.jdbc.core.connection.EncryptConnection;
 import org.apache.shardingsphere.shardingjdbc.jdbc.core.datasource.EncryptDataSource;
 import org.apache.shardingsphere.underlying.common.config.properties.ConfigurationPropertyKey;
+import org.apache.shardingsphere.underlying.common.yaml.engine.YamlEngine;
 import org.h2.tools.RunScript;
 import org.junit.AfterClass;
 import org.junit.Before;
 import org.junit.BeforeClass;
 
-import javax.sql.DataSource;
-import java.io.InputStreamReader;
-import java.sql.SQLException;
-import java.util.Collections;
-import java.util.LinkedHashMap;
-import java.util.List;
-import java.util.Map;
-import java.util.Properties;
-
 public abstract class AbstractEncryptJDBCDatabaseAndTableTest extends AbstractSQLTest {
-    
+
     private static EncryptDataSource encryptDataSource;
-    
+
     private static EncryptDataSource encryptDataSourceWithProps;
-    
+
     private static final List<String> ENCRYPT_DB_NAMES = Collections.singletonList("encrypt");
-    
+
+    private static YamlEncryptRuleConfiguration encryptRuleConfig;
+
     @BeforeClass
-    public static void initEncryptDataSource() throws SQLException {
+    public static void initEncryptDataSource() throws SQLException, IOException {
+        encryptRuleConfig = getEncryptRuleConfig(getFile("encrypt_config.yaml"));
+        System.out.println(encryptRuleConfig);
         if (null != encryptDataSource && null != encryptDataSourceWithProps) {
             return;
         }
         Map<String, DataSource> dataSources = getDataSources();
         encryptDataSource = new EncryptDataSource(dataSources.values().iterator().next(), new EncryptRule(createEncryptRuleConfiguration()), new Properties());
         encryptDataSourceWithProps = new EncryptDataSource(dataSources.values().iterator().next(), new EncryptRule(createEncryptRuleConfiguration()), createProperties());
     }
-    
+
     private static Properties createProperties() {
         Properties result = new Properties();
         result.put(ConfigurationPropertyKey.SQL_SHOW.getKey(), true);
         result.put(ConfigurationPropertyKey.QUERY_WITH_CIPHER_COLUMN.getKey(), false);
         return result;
     }
-    
+
     private static Map<String, DataSource> getDataSources() {
         return Maps.filterKeys(getDatabaseTypeMap().values().iterator().next(), ENCRYPT_DB_NAMES::contains);
     }
-    
+
     private static EncryptRuleConfiguration createEncryptRuleConfiguration() {
         EncryptRuleConfiguration result = new EncryptRuleConfiguration();
-        result.getEncryptors().put("test", new EncryptorRuleConfiguration("test", new Properties()));
-        result.getEncryptors().put("assistedTest", new EncryptorRuleConfiguration("assistedTest", new Properties()));
-        result.getTables().put("t_encrypt", createEncryptTableRule());
-        result.getTables().put("t_query_encrypt", createQueryEncryptTableRule());
-        result.getTables().put("t_encrypt_contains_column", createEncryptContainsColumnTableRule());
+        for (Map.Entry<String, YamlEncryptorRuleConfiguration> entry : encryptRuleConfig.getEncryptors().entrySet()) {
+            result.getEncryptors().put(entry.getKey(), new EncryptorRuleConfiguration(entry.getValue().getType(), entry.getValue().getProps()));
+        }
+
+        for (Map.Entry<String, YamlEncryptTableRuleConfiguration> tableMap : encryptRuleConfig.getTables().entrySet()) {
+            Map<String, EncryptColumnRuleConfiguration> columns = new LinkedHashMap<>(2, 1);
+            for (Map.Entry<String, YamlEncryptColumnRuleConfiguration> columnMap : tableMap.getValue().getColumns().entrySet()) {
+                YamlEncryptColumnRuleConfiguration yamlConfig = columnMap.getValue();
+                EncryptColumnRuleConfiguration columnRuleConfiguration = new EncryptColumnRuleConfiguration(yamlConfig.getPlainColumn(), yamlConfig.getCipherColumn(),
+                    yamlConfig.getAssistedQueryColumn(),
+                    yamlConfig.getEncryptor());
+                columns.put(columnMap.getKey(), columnRuleConfiguration);
+            }
+            result.getTables().put(tableMap.getKey(), new EncryptTableRuleConfiguration(columns));
+        }
+
         return result;
     }
 
 Review comment:
   @terrymanu  Modified as per comment. Pls check. 

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [incubator-shardingsphere] coveralls edited a comment on issue #4871: Fixed issue- #4645 | Use YAML configuration for java AbstractEncrypt…

Posted by GitBox <gi...@apache.org>.
coveralls edited a comment on issue #4871: Fixed issue- #4645 | Use YAML configuration for java  AbstractEncrypt…
URL: https://github.com/apache/incubator-shardingsphere/pull/4871#issuecomment-601873248
 
 
   ## Pull Request Test Coverage Report for [Build 10477](https://coveralls.io/builds/29529556)
   
   * **0** of **0**   changed or added relevant lines in **0** files are covered.
   * **6** unchanged lines in **2** files lost coverage.
   * Overall coverage decreased (**-0.005%**) to **58.193%**
   
   ---
   
   
   |  Files with Coverage Reduction | New Missed Lines | % |
   | :-----|--------------|--: |
   | [sharding-core/sharding-core-entry/src/main/java/org/apache/shardingsphere/core/shard/BaseShardingEngine.java](https://coveralls.io/builds/29529556/source?filename=sharding-core%2Fsharding-core-entry%2Fsrc%2Fmain%2Fjava%2Forg%2Fapache%2Fshardingsphere%2Fcore%2Fshard%2FBaseShardingEngine.java#L118) | 3 | 93.48% |
   | [sharding-orchestration/sharding-orchestration-core/sharding-orchestration-core-registrycenter/src/main/java/org/apache/shardingsphere/orchestration/core/registrycenter/util/IpUtils.java](https://coveralls.io/builds/29529556/source?filename=sharding-orchestration%2Fsharding-orchestration-core%2Fsharding-orchestration-core-registrycenter%2Fsrc%2Fmain%2Fjava%2Forg%2Fapache%2Fshardingsphere%2Forchestration%2Fcore%2Fregistrycenter%2Futil%2FIpUtils.java#L63) | 3 | 76.0% |
   <!-- | **Total:** | **6** |  | -->
   
   |  Totals | [![Coverage Status](https://coveralls.io/builds/29529556/badge)](https://coveralls.io/builds/29529556) |
   | :-- | --: |
   | Change from base [Build 1139](https://coveralls.io/builds/29519726): |  -0.005% |
   | Covered Lines: | 11869 |
   | Relevant Lines: | 20396 |
   
   ---
   ##### 💛  - [Coveralls](https://coveralls.io)
   

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [incubator-shardingsphere] ranjeet-floyd commented on issue #4871: Fixed issue- #4645 | Use YAML configuration for java AbstractEncrypt…

Posted by GitBox <gi...@apache.org>.
ranjeet-floyd commented on issue #4871: Fixed issue- #4645 | Use YAML configuration for java  AbstractEncrypt…
URL: https://github.com/apache/incubator-shardingsphere/pull/4871#issuecomment-602085307
 
 
   Got it, will update PR .  

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [incubator-shardingsphere] ranjeet-floyd commented on a change in pull request #4871: Fixed issue- #4645 | Use YAML configuration for java AbstractEncrypt…

Posted by GitBox <gi...@apache.org>.
ranjeet-floyd commented on a change in pull request #4871: Fixed issue- #4645 | Use YAML configuration for java  AbstractEncrypt…
URL: https://github.com/apache/incubator-shardingsphere/pull/4871#discussion_r396121580
 
 

 ##########
 File path: sharding-jdbc/sharding-jdbc-core/src/test/java/org/apache/shardingsphere/shardingjdbc/common/base/AbstractEncryptJDBCDatabaseAndTableTest.java
 ##########
 @@ -30,93 +41,103 @@
 import org.junit.AfterClass;
 import org.junit.Before;
 import org.junit.BeforeClass;
-
-import javax.sql.DataSource;
-import java.io.InputStreamReader;
-import java.sql.SQLException;
-import java.util.Collections;
-import java.util.LinkedHashMap;
-import java.util.List;
-import java.util.Map;
-import java.util.Properties;
+import org.yaml.snakeyaml.Yaml;
 
 public abstract class AbstractEncryptJDBCDatabaseAndTableTest extends AbstractSQLTest {
-    
+
 
 Review comment:
   Got it. Thanks

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [incubator-shardingsphere] terrymanu commented on a change in pull request #4871: Fixed issue- #4645 | Use YAML configuration for java AbstractEncrypt…

Posted by GitBox <gi...@apache.org>.
terrymanu commented on a change in pull request #4871: Fixed issue- #4645 | Use YAML configuration for java  AbstractEncrypt…
URL: https://github.com/apache/incubator-shardingsphere/pull/4871#discussion_r396229707
 
 

 ##########
 File path: sharding-jdbc/sharding-jdbc-core/src/test/java/org/apache/shardingsphere/shardingjdbc/common/base/AbstractEncryptJDBCDatabaseAndTableTest.java
 ##########
 @@ -17,87 +17,90 @@
 
 package org.apache.shardingsphere.shardingjdbc.common.base;
 
+import com.google.common.base.Preconditions;
 import com.google.common.collect.Maps;
+import java.io.File;
+import java.io.IOException;
+import java.io.InputStreamReader;
+import java.sql.SQLException;
+import java.util.Collections;
+import java.util.LinkedHashMap;
+import java.util.List;
+import java.util.Map;
+import java.util.Properties;
+import javax.sql.DataSource;
 import org.apache.shardingsphere.encrypt.api.EncryptColumnRuleConfiguration;
 import org.apache.shardingsphere.encrypt.api.EncryptRuleConfiguration;
 import org.apache.shardingsphere.encrypt.api.EncryptTableRuleConfiguration;
 import org.apache.shardingsphere.encrypt.api.EncryptorRuleConfiguration;
 import org.apache.shardingsphere.encrypt.rule.EncryptRule;
+import org.apache.shardingsphere.encrypt.yaml.config.YamlEncryptColumnRuleConfiguration;
+import org.apache.shardingsphere.encrypt.yaml.config.YamlEncryptRuleConfiguration;
+import org.apache.shardingsphere.encrypt.yaml.config.YamlEncryptTableRuleConfiguration;
+import org.apache.shardingsphere.encrypt.yaml.config.YamlEncryptorRuleConfiguration;
 import org.apache.shardingsphere.shardingjdbc.jdbc.core.connection.EncryptConnection;
 import org.apache.shardingsphere.shardingjdbc.jdbc.core.datasource.EncryptDataSource;
 import org.apache.shardingsphere.underlying.common.config.properties.ConfigurationPropertyKey;
+import org.apache.shardingsphere.underlying.common.yaml.engine.YamlEngine;
 import org.h2.tools.RunScript;
 import org.junit.AfterClass;
 import org.junit.Before;
 import org.junit.BeforeClass;
 
-import javax.sql.DataSource;
-import java.io.InputStreamReader;
-import java.sql.SQLException;
-import java.util.Collections;
-import java.util.LinkedHashMap;
-import java.util.List;
-import java.util.Map;
-import java.util.Properties;
-
 public abstract class AbstractEncryptJDBCDatabaseAndTableTest extends AbstractSQLTest {
-    
+
     private static EncryptDataSource encryptDataSource;
-    
+
     private static EncryptDataSource encryptDataSourceWithProps;
-    
+
     private static final List<String> ENCRYPT_DB_NAMES = Collections.singletonList("encrypt");
-    
+
+    private static YamlEncryptRuleConfiguration encryptRuleConfig;
+
     @BeforeClass
-    public static void initEncryptDataSource() throws SQLException {
+    public static void initEncryptDataSource() throws SQLException, IOException {
+        encryptRuleConfig = getEncryptRuleConfig(getFile("encrypt_config.yaml"));
+        System.out.println(encryptRuleConfig);
         if (null != encryptDataSource && null != encryptDataSourceWithProps) {
             return;
         }
         Map<String, DataSource> dataSources = getDataSources();
         encryptDataSource = new EncryptDataSource(dataSources.values().iterator().next(), new EncryptRule(createEncryptRuleConfiguration()), new Properties());
         encryptDataSourceWithProps = new EncryptDataSource(dataSources.values().iterator().next(), new EncryptRule(createEncryptRuleConfiguration()), createProperties());
     }
-    
+
     private static Properties createProperties() {
         Properties result = new Properties();
         result.put(ConfigurationPropertyKey.SQL_SHOW.getKey(), true);
         result.put(ConfigurationPropertyKey.QUERY_WITH_CIPHER_COLUMN.getKey(), false);
         return result;
     }
-    
+
     private static Map<String, DataSource> getDataSources() {
         return Maps.filterKeys(getDatabaseTypeMap().values().iterator().next(), ENCRYPT_DB_NAMES::contains);
     }
-    
+
     private static EncryptRuleConfiguration createEncryptRuleConfiguration() {
         EncryptRuleConfiguration result = new EncryptRuleConfiguration();
-        result.getEncryptors().put("test", new EncryptorRuleConfiguration("test", new Properties()));
-        result.getEncryptors().put("assistedTest", new EncryptorRuleConfiguration("assistedTest", new Properties()));
-        result.getTables().put("t_encrypt", createEncryptTableRule());
-        result.getTables().put("t_query_encrypt", createQueryEncryptTableRule());
-        result.getTables().put("t_encrypt_contains_column", createEncryptContainsColumnTableRule());
+        for (Map.Entry<String, YamlEncryptorRuleConfiguration> entry : encryptRuleConfig.getEncryptors().entrySet()) {
+            result.getEncryptors().put(entry.getKey(), new EncryptorRuleConfiguration(entry.getValue().getType(), entry.getValue().getProps()));
+        }
+
+        for (Map.Entry<String, YamlEncryptTableRuleConfiguration> tableMap : encryptRuleConfig.getTables().entrySet()) {
+            Map<String, EncryptColumnRuleConfiguration> columns = new LinkedHashMap<>(2, 1);
+            for (Map.Entry<String, YamlEncryptColumnRuleConfiguration> columnMap : tableMap.getValue().getColumns().entrySet()) {
+                YamlEncryptColumnRuleConfiguration yamlConfig = columnMap.getValue();
+                EncryptColumnRuleConfiguration columnRuleConfiguration = new EncryptColumnRuleConfiguration(yamlConfig.getPlainColumn(), yamlConfig.getCipherColumn(),
+                    yamlConfig.getAssistedQueryColumn(),
+                    yamlConfig.getEncryptor());
+                columns.put(columnMap.getKey(), columnRuleConfiguration);
+            }
+            result.getTables().put(tableMap.getKey(), new EncryptTableRuleConfiguration(columns));
+        }
+
         return result;
     }
 
 Review comment:
   You may use `YamlEncryptDataSourceFactory.createDataSource()` to load YAML directly.
   We can just make sure the format of YAML file are correct and then use ShardingSphere's public API to load yaml and create EncryptDataSource.

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [incubator-shardingsphere] coveralls edited a comment on issue #4871: Fixed issue- #4645 | Use YAML configuration for java AbstractEncrypt…

Posted by GitBox <gi...@apache.org>.
coveralls edited a comment on issue #4871: Fixed issue- #4645 | Use YAML configuration for java  AbstractEncrypt…
URL: https://github.com/apache/incubator-shardingsphere/pull/4871#issuecomment-601873248
 
 
   ## Pull Request Test Coverage Report for [Build 10539](https://coveralls.io/builds/29588331)
   
   * **0** of **0**   changed or added relevant lines in **0** files are covered.
   * **135** unchanged lines in **12** files lost coverage.
   * Overall coverage decreased (**-0.03%**) to **58.082%**
   
   ---
   
   
   |  Files with Coverage Reduction | New Missed Lines | % |
   | :-----|--------------|--: |
   | [sharding-core/sharding-core-rewrite/src/main/java/org/apache/shardingsphere/sharding/rewrite/engine/ShardingSQLRewriteEngine.java](https://coveralls.io/builds/29588331/source?filename=sharding-core%2Fsharding-core-rewrite%2Fsrc%2Fmain%2Fjava%2Forg%2Fapache%2Fshardingsphere%2Fsharding%2Frewrite%2Fengine%2FShardingSQLRewriteEngine.java#L71) | 1 | 94.44% |
   | [sharding-core/sharding-core-rewrite/src/main/java/org/apache/shardingsphere/sharding/rewrite/token/generator/impl/keygen/GeneratedKeyInsertValuesTokenGenerator.java](https://coveralls.io/builds/29588331/source?filename=sharding-core%2Fsharding-core-rewrite%2Fsrc%2Fmain%2Fjava%2Forg%2Fapache%2Fshardingsphere%2Fsharding%2Frewrite%2Ftoken%2Fgenerator%2Fimpl%2Fkeygen%2FGeneratedKeyInsertValuesTokenGenerator.java#L75) | 1 | 95.65% |
   | [sharding-jdbc/sharding-jdbc-orchestration/src/main/java/org/apache/shardingsphere/shardingjdbc/orchestration/internal/datasource/AbstractOrchestrationDataSource.java](https://coveralls.io/builds/29588331/source?filename=sharding-jdbc%2Fsharding-jdbc-orchestration%2Fsrc%2Fmain%2Fjava%2Forg%2Fapache%2Fshardingsphere%2Fshardingjdbc%2Forchestration%2Finternal%2Fdatasource%2FAbstractOrchestrationDataSource.java#L85) | 1 | 96.97% |
   | [sharding-core/sharding-core-entry/src/main/java/org/apache/shardingsphere/core/shard/BaseShardingEngine.java](https://coveralls.io/builds/29588331/source?filename=sharding-core%2Fsharding-core-entry%2Fsrc%2Fmain%2Fjava%2Forg%2Fapache%2Fshardingsphere%2Fcore%2Fshard%2FBaseShardingEngine.java#L117) | 2 | 93.48% |
   | [sharding-core/sharding-core-common/src/main/java/org/apache/shardingsphere/core/rule/TableRule.java](https://coveralls.io/builds/29588331/source?filename=sharding-core%2Fsharding-core-common%2Fsrc%2Fmain%2Fjava%2Forg%2Fapache%2Fshardingsphere%2Fcore%2Frule%2FTableRule.java#L164) | 3 | 90.53% |
   | [shardingsphere-sql-parser/shardingsphere-sql-parser-binder/src/main/java/org/apache/shardingsphere/sql/parser/binder/statement/dml/InsertStatementContext.java](https://coveralls.io/builds/29588331/source?filename=shardingsphere-sql-parser%2Fshardingsphere-sql-parser-binder%2Fsrc%2Fmain%2Fjava%2Forg%2Fapache%2Fshardingsphere%2Fsql%2Fparser%2Fbinder%2Fstatement%2Fdml%2FInsertStatementContext.java#L80) | 3 | 86.36% |
   | [sharding-core/sharding-core-common/src/main/java/org/apache/shardingsphere/core/rule/ShardingRule.java](https://coveralls.io/builds/29588331/source?filename=sharding-core%2Fsharding-core-common%2Fsrc%2Fmain%2Fjava%2Forg%2Fapache%2Fshardingsphere%2Fcore%2Frule%2FShardingRule.java#L371) | 12 | 85.21% |
   | [sharding-jdbc/sharding-jdbc-core/src/main/java/org/apache/shardingsphere/shardingjdbc/jdbc/core/statement/ShardingPreparedStatement.java](https://coveralls.io/builds/29588331/source?filename=sharding-jdbc%2Fsharding-jdbc-core%2Fsrc%2Fmain%2Fjava%2Forg%2Fapache%2Fshardingsphere%2Fshardingjdbc%2Fjdbc%2Fcore%2Fstatement%2FShardingPreparedStatement.java#L87) | 15 | 84.48% |
   | [sharding-core/sharding-core-route/src/main/java/org/apache/shardingsphere/sharding/route/engine/condition/engine/InsertClauseShardingConditionEngine.java](https://coveralls.io/builds/29588331/source?filename=sharding-core%2Fsharding-core-route%2Fsrc%2Fmain%2Fjava%2Forg%2Fapache%2Fshardingsphere%2Fsharding%2Froute%2Fengine%2Fcondition%2Fengine%2FInsertClauseShardingConditionEngine.java#L69) | 16 | 59.52% |
   | [sharding-core/sharding-core-route/src/main/java/org/apache/shardingsphere/sharding/route/engine/ShardingRouteDecorator.java](https://coveralls.io/builds/29588331/source?filename=sharding-core%2Fsharding-core-route%2Fsrc%2Fmain%2Fjava%2Forg%2Fapache%2Fshardingsphere%2Fsharding%2Froute%2Fengine%2FShardingRouteDecorator.java#L66) | 20 | 32.14% |
   <!-- | **Total:** | **135** |  | -->
   
   |  Totals | [![Coverage Status](https://coveralls.io/builds/29588331/badge)](https://coveralls.io/builds/29588331) |
   | :-- | --: |
   | Change from base [Build 10493](https://coveralls.io/builds/29542363): |  -0.03% |
   | Covered Lines: | 11880 |
   | Relevant Lines: | 20454 |
   
   ---
   ##### 💛  - [Coveralls](https://coveralls.io)
   

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [incubator-shardingsphere] terrymanu merged pull request #4871: Fixed issue- #4645 | Use YAML configuration for java AbstractEncrypt…

Posted by GitBox <gi...@apache.org>.
terrymanu merged pull request #4871: Fixed issue- #4645 | Use YAML configuration for java  AbstractEncrypt…
URL: https://github.com/apache/incubator-shardingsphere/pull/4871
 
 
   

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [incubator-shardingsphere] ranjeet-floyd commented on a change in pull request #4871: Fixed issue- #4645 | Use YAML configuration for java AbstractEncrypt…

Posted by GitBox <gi...@apache.org>.
ranjeet-floyd commented on a change in pull request #4871: Fixed issue- #4645 | Use YAML configuration for java  AbstractEncrypt…
URL: https://github.com/apache/incubator-shardingsphere/pull/4871#discussion_r396677045
 
 

 ##########
 File path: sharding-jdbc/sharding-jdbc-core/src/test/java/org/apache/shardingsphere/shardingjdbc/common/base/AbstractEncryptJDBCDatabaseAndTableTest.java
 ##########
 @@ -17,87 +17,90 @@
 
 package org.apache.shardingsphere.shardingjdbc.common.base;
 
+import com.google.common.base.Preconditions;
 import com.google.common.collect.Maps;
+import java.io.File;
+import java.io.IOException;
+import java.io.InputStreamReader;
+import java.sql.SQLException;
+import java.util.Collections;
+import java.util.LinkedHashMap;
+import java.util.List;
+import java.util.Map;
+import java.util.Properties;
+import javax.sql.DataSource;
 import org.apache.shardingsphere.encrypt.api.EncryptColumnRuleConfiguration;
 import org.apache.shardingsphere.encrypt.api.EncryptRuleConfiguration;
 import org.apache.shardingsphere.encrypt.api.EncryptTableRuleConfiguration;
 import org.apache.shardingsphere.encrypt.api.EncryptorRuleConfiguration;
 import org.apache.shardingsphere.encrypt.rule.EncryptRule;
+import org.apache.shardingsphere.encrypt.yaml.config.YamlEncryptColumnRuleConfiguration;
+import org.apache.shardingsphere.encrypt.yaml.config.YamlEncryptRuleConfiguration;
+import org.apache.shardingsphere.encrypt.yaml.config.YamlEncryptTableRuleConfiguration;
+import org.apache.shardingsphere.encrypt.yaml.config.YamlEncryptorRuleConfiguration;
 import org.apache.shardingsphere.shardingjdbc.jdbc.core.connection.EncryptConnection;
 import org.apache.shardingsphere.shardingjdbc.jdbc.core.datasource.EncryptDataSource;
 import org.apache.shardingsphere.underlying.common.config.properties.ConfigurationPropertyKey;
+import org.apache.shardingsphere.underlying.common.yaml.engine.YamlEngine;
 import org.h2.tools.RunScript;
 import org.junit.AfterClass;
 import org.junit.Before;
 import org.junit.BeforeClass;
 
-import javax.sql.DataSource;
-import java.io.InputStreamReader;
-import java.sql.SQLException;
-import java.util.Collections;
-import java.util.LinkedHashMap;
-import java.util.List;
-import java.util.Map;
-import java.util.Properties;
-
 public abstract class AbstractEncryptJDBCDatabaseAndTableTest extends AbstractSQLTest {
-    
+
     private static EncryptDataSource encryptDataSource;
-    
+
     private static EncryptDataSource encryptDataSourceWithProps;
-    
+
     private static final List<String> ENCRYPT_DB_NAMES = Collections.singletonList("encrypt");
-    
+
+    private static YamlEncryptRuleConfiguration encryptRuleConfig;
+
     @BeforeClass
-    public static void initEncryptDataSource() throws SQLException {
+    public static void initEncryptDataSource() throws SQLException, IOException {
+        encryptRuleConfig = getEncryptRuleConfig(getFile("encrypt_config.yaml"));
+        System.out.println(encryptRuleConfig);
         if (null != encryptDataSource && null != encryptDataSourceWithProps) {
             return;
         }
         Map<String, DataSource> dataSources = getDataSources();
         encryptDataSource = new EncryptDataSource(dataSources.values().iterator().next(), new EncryptRule(createEncryptRuleConfiguration()), new Properties());
         encryptDataSourceWithProps = new EncryptDataSource(dataSources.values().iterator().next(), new EncryptRule(createEncryptRuleConfiguration()), createProperties());
     }
-    
+
     private static Properties createProperties() {
         Properties result = new Properties();
         result.put(ConfigurationPropertyKey.SQL_SHOW.getKey(), true);
         result.put(ConfigurationPropertyKey.QUERY_WITH_CIPHER_COLUMN.getKey(), false);
         return result;
     }
 
 Review comment:
   Added properties in yaml config

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [incubator-shardingsphere] terrymanu commented on a change in pull request #4871: Fixed issue- #4645 | Use YAML configuration for java AbstractEncrypt…

Posted by GitBox <gi...@apache.org>.
terrymanu commented on a change in pull request #4871: Fixed issue- #4645 | Use YAML configuration for java  AbstractEncrypt…
URL: https://github.com/apache/incubator-shardingsphere/pull/4871#discussion_r396229035
 
 

 ##########
 File path: sharding-jdbc/sharding-jdbc-core/src/test/java/org/apache/shardingsphere/shardingjdbc/common/base/AbstractEncryptJDBCDatabaseAndTableTest.java
 ##########
 @@ -17,87 +17,90 @@
 
 package org.apache.shardingsphere.shardingjdbc.common.base;
 
+import com.google.common.base.Preconditions;
 import com.google.common.collect.Maps;
+import java.io.File;
+import java.io.IOException;
+import java.io.InputStreamReader;
+import java.sql.SQLException;
+import java.util.Collections;
+import java.util.LinkedHashMap;
+import java.util.List;
+import java.util.Map;
+import java.util.Properties;
+import javax.sql.DataSource;
 import org.apache.shardingsphere.encrypt.api.EncryptColumnRuleConfiguration;
 import org.apache.shardingsphere.encrypt.api.EncryptRuleConfiguration;
 import org.apache.shardingsphere.encrypt.api.EncryptTableRuleConfiguration;
 import org.apache.shardingsphere.encrypt.api.EncryptorRuleConfiguration;
 import org.apache.shardingsphere.encrypt.rule.EncryptRule;
+import org.apache.shardingsphere.encrypt.yaml.config.YamlEncryptColumnRuleConfiguration;
+import org.apache.shardingsphere.encrypt.yaml.config.YamlEncryptRuleConfiguration;
+import org.apache.shardingsphere.encrypt.yaml.config.YamlEncryptTableRuleConfiguration;
+import org.apache.shardingsphere.encrypt.yaml.config.YamlEncryptorRuleConfiguration;
 import org.apache.shardingsphere.shardingjdbc.jdbc.core.connection.EncryptConnection;
 import org.apache.shardingsphere.shardingjdbc.jdbc.core.datasource.EncryptDataSource;
 import org.apache.shardingsphere.underlying.common.config.properties.ConfigurationPropertyKey;
+import org.apache.shardingsphere.underlying.common.yaml.engine.YamlEngine;
 import org.h2.tools.RunScript;
 import org.junit.AfterClass;
 import org.junit.Before;
 import org.junit.BeforeClass;
 
-import javax.sql.DataSource;
-import java.io.InputStreamReader;
-import java.sql.SQLException;
-import java.util.Collections;
-import java.util.LinkedHashMap;
-import java.util.List;
-import java.util.Map;
-import java.util.Properties;
-
 public abstract class AbstractEncryptJDBCDatabaseAndTableTest extends AbstractSQLTest {
-    
+
     private static EncryptDataSource encryptDataSource;
-    
+
     private static EncryptDataSource encryptDataSourceWithProps;
-    
+
     private static final List<String> ENCRYPT_DB_NAMES = Collections.singletonList("encrypt");
-    
+
+    private static YamlEncryptRuleConfiguration encryptRuleConfig;
+
     @BeforeClass
-    public static void initEncryptDataSource() throws SQLException {
+    public static void initEncryptDataSource() throws SQLException, IOException {
+        encryptRuleConfig = getEncryptRuleConfig(getFile("encrypt_config.yaml"));
+        System.out.println(encryptRuleConfig);
         if (null != encryptDataSource && null != encryptDataSourceWithProps) {
             return;
         }
         Map<String, DataSource> dataSources = getDataSources();
         encryptDataSource = new EncryptDataSource(dataSources.values().iterator().next(), new EncryptRule(createEncryptRuleConfiguration()), new Properties());
         encryptDataSourceWithProps = new EncryptDataSource(dataSources.values().iterator().next(), new EncryptRule(createEncryptRuleConfiguration()), createProperties());
     }
-    
+
     private static Properties createProperties() {
         Properties result = new Properties();
         result.put(ConfigurationPropertyKey.SQL_SHOW.getKey(), true);
         result.put(ConfigurationPropertyKey.QUERY_WITH_CIPHER_COLUMN.getKey(), false);
         return result;
     }
 
 Review comment:
   Please use YAML to config properties too.

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [incubator-shardingsphere] coveralls commented on issue #4871: Fixed issue- #4645 | Use YAML configuration for java AbstractEncrypt…

Posted by GitBox <gi...@apache.org>.
coveralls commented on issue #4871: Fixed issue- #4645 | Use YAML configuration for java  AbstractEncrypt…
URL: https://github.com/apache/incubator-shardingsphere/pull/4871#issuecomment-601873248
 
 
   ## Pull Request Test Coverage Report for [Build 10453](https://coveralls.io/builds/29509107)
   
   * **0** of **0**   changed or added relevant lines in **0** files are covered.
   * **18** unchanged lines in **3** files lost coverage.
   * Overall coverage decreased (**-0.08%**) to **58.577%**
   
   ---
   
   
   |  Files with Coverage Reduction | New Missed Lines | % |
   | :-----|--------------|--: |
   | [sharding-orchestration/sharding-orchestration-core/sharding-orchestration-core-registrycenter/src/main/java/org/apache/shardingsphere/orchestration/core/registrycenter/util/IpUtils.java](https://coveralls.io/builds/29509107/source?filename=sharding-orchestration%2Fsharding-orchestration-core%2Fsharding-orchestration-core-registrycenter%2Fsrc%2Fmain%2Fjava%2Forg%2Fapache%2Fshardingsphere%2Forchestration%2Fcore%2Fregistrycenter%2Futil%2FIpUtils.java#L63) | 3 | 76.0% |
   | [sharding-scaling/sharding-scaling-core/src/main/java/org/apache/shardingsphere/shardingscaling/core/synctask/history/HistoryDataSyncTask.java](https://coveralls.io/builds/29509107/source?filename=sharding-scaling%2Fsharding-scaling-core%2Fsrc%2Fmain%2Fjava%2Forg%2Fapache%2Fshardingsphere%2Fshardingscaling%2Fcore%2Fsynctask%2Fhistory%2FHistoryDataSyncTask.java#L116) | 7 | 76.47% |
   | [sharding-scaling/sharding-scaling-core/src/main/java/org/apache/shardingsphere/shardingscaling/core/execute/executor/channel/MemoryChannel.java](https://coveralls.io/builds/29509107/source?filename=sharding-scaling%2Fsharding-scaling-core%2Fsrc%2Fmain%2Fjava%2Forg%2Fapache%2Fshardingsphere%2Fshardingscaling%2Fcore%2Fexecute%2Fexecutor%2Fchannel%2FMemoryChannel.java#L61) | 8 | 51.85% |
   <!-- | **Total:** | **18** |  | -->
   
   |  Totals | [![Coverage Status](https://coveralls.io/builds/29509107/badge)](https://coveralls.io/builds/29509107) |
   | :-- | --: |
   | Change from base [Build 1132](https://coveralls.io/builds/29504108): |  -0.08% |
   | Covered Lines: | 11887 |
   | Relevant Lines: | 20293 |
   
   ---
   ##### 💛  - [Coveralls](https://coveralls.io)
   

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [incubator-shardingsphere] kimmking commented on a change in pull request #4871: Fixed issue- #4645 | Use YAML configuration for java AbstractEncrypt…

Posted by GitBox <gi...@apache.org>.
kimmking commented on a change in pull request #4871: Fixed issue- #4645 | Use YAML configuration for java  AbstractEncrypt…
URL: https://github.com/apache/incubator-shardingsphere/pull/4871#discussion_r395984374
 
 

 ##########
 File path: sharding-jdbc/sharding-jdbc-core/src/test/java/org/apache/shardingsphere/shardingjdbc/common/base/AbstractEncryptJDBCDatabaseAndTableTest.java
 ##########
 @@ -30,93 +41,103 @@
 import org.junit.AfterClass;
 import org.junit.Before;
 import org.junit.BeforeClass;
-
-import javax.sql.DataSource;
-import java.io.InputStreamReader;
-import java.sql.SQLException;
-import java.util.Collections;
-import java.util.LinkedHashMap;
-import java.util.List;
-import java.util.Map;
-import java.util.Properties;
+import org.yaml.snakeyaml.Yaml;
 
 public abstract class AbstractEncryptJDBCDatabaseAndTableTest extends AbstractSQLTest {
-    
+
 
 Review comment:
   should keep 4 blankspace 

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [incubator-shardingsphere] kimmking commented on a change in pull request #4871: Fixed issue- #4645 | Use YAML configuration for java AbstractEncrypt…

Posted by GitBox <gi...@apache.org>.
kimmking commented on a change in pull request #4871: Fixed issue- #4645 | Use YAML configuration for java  AbstractEncrypt…
URL: https://github.com/apache/incubator-shardingsphere/pull/4871#discussion_r396099632
 
 

 ##########
 File path: sharding-jdbc/sharding-jdbc-core/src/test/java/org/apache/shardingsphere/shardingjdbc/common/base/AbstractEncryptJDBCDatabaseAndTableTest.java
 ##########
 @@ -30,93 +41,103 @@
 import org.junit.AfterClass;
 import org.junit.Before;
 import org.junit.BeforeClass;
-
-import javax.sql.DataSource;
-import java.io.InputStreamReader;
-import java.sql.SQLException;
-import java.util.Collections;
-import java.util.LinkedHashMap;
-import java.util.List;
-import java.util.Map;
-import java.util.Properties;
+import org.yaml.snakeyaml.Yaml;
 
 public abstract class AbstractEncryptJDBCDatabaseAndTableTest extends AbstractSQLTest {
-    
+
 
 Review comment:
   plz keep origin style here with 4 blankspaces

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [incubator-shardingsphere] ranjeet-floyd commented on a change in pull request #4871: Fixed issue- #4645 | Use YAML configuration for java AbstractEncrypt…

Posted by GitBox <gi...@apache.org>.
ranjeet-floyd commented on a change in pull request #4871: Fixed issue- #4645 | Use YAML configuration for java  AbstractEncrypt…
URL: https://github.com/apache/incubator-shardingsphere/pull/4871#discussion_r396074659
 
 

 ##########
 File path: sharding-jdbc/sharding-jdbc-core/src/test/java/org/apache/shardingsphere/shardingjdbc/common/base/AbstractEncryptJDBCDatabaseAndTableTest.java
 ##########
 @@ -30,93 +41,103 @@
 import org.junit.AfterClass;
 import org.junit.Before;
 import org.junit.BeforeClass;
-
-import javax.sql.DataSource;
-import java.io.InputStreamReader;
-import java.sql.SQLException;
-import java.util.Collections;
-import java.util.LinkedHashMap;
-import java.util.List;
-import java.util.Map;
-import java.util.Properties;
+import org.yaml.snakeyaml.Yaml;
 
 public abstract class AbstractEncryptJDBCDatabaseAndTableTest extends AbstractSQLTest {
-    
+
 
 Review comment:
   sorry , can't get you . I used project check-style config.

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [incubator-shardingsphere] codecov-io commented on issue #4871: Fixed issue- #4645 | Use YAML configuration for java AbstractEncrypt…

Posted by GitBox <gi...@apache.org>.
codecov-io commented on issue #4871: Fixed issue- #4645 | Use YAML configuration for java  AbstractEncrypt…
URL: https://github.com/apache/incubator-shardingsphere/pull/4871#issuecomment-602173010
 
 
   # [Codecov](https://codecov.io/gh/apache/incubator-shardingsphere/pull/4871?src=pr&el=h1) Report
   > Merging [#4871](https://codecov.io/gh/apache/incubator-shardingsphere/pull/4871?src=pr&el=desc) into [master](https://codecov.io/gh/apache/incubator-shardingsphere/commit/175aef14b4dfd3156c5c3b058c4339d525543188&el=desc) will **not change** coverage by `%`.
   > The diff coverage is `n/a`.
   
   [![Impacted file tree graph](https://codecov.io/gh/apache/incubator-shardingsphere/pull/4871/graphs/tree.svg?width=650&height=150&src=pr&token=ZvlXpWa7so)](https://codecov.io/gh/apache/incubator-shardingsphere/pull/4871?src=pr&el=tree)
   
   ```diff
   @@            Coverage Diff            @@
   ##             master    #4871   +/-   ##
   =========================================
     Coverage     54.68%   54.68%           
     Complexity      436      436           
   =========================================
     Files          1138     1138           
     Lines         20396    20396           
     Branches       3748     3748           
   =========================================
     Hits          11153    11153           
     Misses         8539     8539           
     Partials        704      704           
   ```
   
   
   | [Impacted Files](https://codecov.io/gh/apache/incubator-shardingsphere/pull/4871?src=pr&el=tree) | Coverage Δ | Complexity Δ | |
   |---|---|---|---|
   | [.../shardingsphere/core/shard/BaseShardingEngine.java](https://codecov.io/gh/apache/incubator-shardingsphere/pull/4871/diff?src=pr&el=tree#diff-c2hhcmRpbmctY29yZS9zaGFyZGluZy1jb3JlLWVudHJ5L3NyYy9tYWluL2phdmEvb3JnL2FwYWNoZS9zaGFyZGluZ3NwaGVyZS9jb3JlL3NoYXJkL0Jhc2VTaGFyZGluZ0VuZ2luZS5qYXZh) | `86.95% <0.00%> (ø)` | `0.00% <0.00%> (ø%)` | |
   
   ------
   
   [Continue to review full report at Codecov](https://codecov.io/gh/apache/incubator-shardingsphere/pull/4871?src=pr&el=continue).
   > **Legend** - [Click here to learn more](https://docs.codecov.io/docs/codecov-delta)
   > `Δ = absolute <relative> (impact)`, `ø = not affected`, `? = missing data`
   > Powered by [Codecov](https://codecov.io/gh/apache/incubator-shardingsphere/pull/4871?src=pr&el=footer). Last update [175aef1...6820df2](https://codecov.io/gh/apache/incubator-shardingsphere/pull/4871?src=pr&el=lastupdated). Read the [comment docs](https://docs.codecov.io/docs/pull-request-comments).
   

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [incubator-shardingsphere] ranjeet-floyd commented on a change in pull request #4871: Fixed issue- #4645 | Use YAML configuration for java AbstractEncrypt…

Posted by GitBox <gi...@apache.org>.
ranjeet-floyd commented on a change in pull request #4871: Fixed issue- #4645 | Use YAML configuration for java  AbstractEncrypt…
URL: https://github.com/apache/incubator-shardingsphere/pull/4871#discussion_r396121580
 
 

 ##########
 File path: sharding-jdbc/sharding-jdbc-core/src/test/java/org/apache/shardingsphere/shardingjdbc/common/base/AbstractEncryptJDBCDatabaseAndTableTest.java
 ##########
 @@ -30,93 +41,103 @@
 import org.junit.AfterClass;
 import org.junit.Before;
 import org.junit.BeforeClass;
-
-import javax.sql.DataSource;
-import java.io.InputStreamReader;
-import java.sql.SQLException;
-import java.util.Collections;
-import java.util.LinkedHashMap;
-import java.util.List;
-import java.util.Map;
-import java.util.Properties;
+import org.yaml.snakeyaml.Yaml;
 
 public abstract class AbstractEncryptJDBCDatabaseAndTableTest extends AbstractSQLTest {
-    
+
 
 Review comment:
   Used same checkstyle. Do you any difference.  

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [incubator-shardingsphere] kimmking commented on a change in pull request #4871: Fixed issue- #4645 | Use YAML configuration for java AbstractEncrypt…

Posted by GitBox <gi...@apache.org>.
kimmking commented on a change in pull request #4871: Fixed issue- #4645 | Use YAML configuration for java  AbstractEncrypt…
URL: https://github.com/apache/incubator-shardingsphere/pull/4871#discussion_r396099632
 
 

 ##########
 File path: sharding-jdbc/sharding-jdbc-core/src/test/java/org/apache/shardingsphere/shardingjdbc/common/base/AbstractEncryptJDBCDatabaseAndTableTest.java
 ##########
 @@ -30,93 +41,103 @@
 import org.junit.AfterClass;
 import org.junit.Before;
 import org.junit.BeforeClass;
-
-import javax.sql.DataSource;
-import java.io.InputStreamReader;
-import java.sql.SQLException;
-import java.util.Collections;
-import java.util.LinkedHashMap;
-import java.util.List;
-import java.util.Map;
-import java.util.Properties;
+import org.yaml.snakeyaml.Yaml;
 
 public abstract class AbstractEncryptJDBCDatabaseAndTableTest extends AbstractSQLTest {
-    
+
 
 Review comment:
   plz let origin style here with 4 blankspaces

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [incubator-shardingsphere] coveralls edited a comment on issue #4871: Fixed issue- #4645 | Use YAML configuration for java AbstractEncrypt…

Posted by GitBox <gi...@apache.org>.
coveralls edited a comment on issue #4871: Fixed issue- #4645 | Use YAML configuration for java  AbstractEncrypt…
URL: https://github.com/apache/incubator-shardingsphere/pull/4871#issuecomment-601873248
 
 
   ## Pull Request Test Coverage Report for [Build 10476](https://coveralls.io/builds/29529368)
   
   * **0** of **0**   changed or added relevant lines in **0** files are covered.
   * **6** unchanged lines in **2** files lost coverage.
   * Overall coverage decreased (**-0.005%**) to **58.193%**
   
   ---
   
   
   |  Files with Coverage Reduction | New Missed Lines | % |
   | :-----|--------------|--: |
   | [sharding-core/sharding-core-entry/src/main/java/org/apache/shardingsphere/core/shard/BaseShardingEngine.java](https://coveralls.io/builds/29529368/source?filename=sharding-core%2Fsharding-core-entry%2Fsrc%2Fmain%2Fjava%2Forg%2Fapache%2Fshardingsphere%2Fcore%2Fshard%2FBaseShardingEngine.java#L118) | 3 | 93.48% |
   | [sharding-orchestration/sharding-orchestration-core/sharding-orchestration-core-registrycenter/src/main/java/org/apache/shardingsphere/orchestration/core/registrycenter/util/IpUtils.java](https://coveralls.io/builds/29529368/source?filename=sharding-orchestration%2Fsharding-orchestration-core%2Fsharding-orchestration-core-registrycenter%2Fsrc%2Fmain%2Fjava%2Forg%2Fapache%2Fshardingsphere%2Forchestration%2Fcore%2Fregistrycenter%2Futil%2FIpUtils.java#L63) | 3 | 76.0% |
   <!-- | **Total:** | **6** |  | -->
   
   |  Totals | [![Coverage Status](https://coveralls.io/builds/29529368/badge)](https://coveralls.io/builds/29529368) |
   | :-- | --: |
   | Change from base [Build 1139](https://coveralls.io/builds/29519726): |  -0.005% |
   | Covered Lines: | 11869 |
   | Relevant Lines: | 20396 |
   
   ---
   ##### 💛  - [Coveralls](https://coveralls.io)
   

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services