You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@hbase.apache.org by "NihalJain (via GitHub)" <gi...@apache.org> on 2023/08/04 07:33:50 UTC

[GitHub] [hbase-connectors] NihalJain opened a new pull request, #119: HBASE-27178 Use spotless to format code (including scala code)

NihalJain opened a new pull request, #119:
URL: https://github.com/apache/hbase-connectors/pull/119

   - Added the base plugin to pom.xml (similar to other hbase repos)
   - Extended the plugin to support formatting of scala code / headers
   - Added the files required by the base plugin ( copying them from hbase repo)
   - Added the scalafrm.conf required by scala (copied from spark repo)


-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@hbase.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [hbase-connectors] NihalJain commented on a diff in pull request #119: HBASE-27178 Use spotless to format code (including scala code)

Posted by "NihalJain (via GitHub)" <gi...@apache.org>.
NihalJain commented on code in PR #119:
URL: https://github.com/apache/hbase-connectors/pull/119#discussion_r1284278160


##########
dev-support/.scalafmt.conf:
##########
@@ -0,0 +1,38 @@
+#
+# 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.
+#
+
+# Template based off apache spark: https://github.com/apache/spark/blob/master/dev/.scalafmt.conf
+align = none
+align.openParenDefnSite = false
+align.openParenCallSite = false
+align.tokens = []
+importSelectors = "singleLine"
+optIn = {
+  configStyleArguments = false
+}
+danglingParentheses.preset = false
+docstrings.style = Asterisk
+# See https://github.com/scalameta/scalafmt/issues/1387
+docstrings.wrap = no
+maxColumn = 98
+runner.dialect = scala212
+fileOverride {

Review Comment:
   Need feedback: IMHO we can drop this as we do not have this directory/mulipel scala implementation similar to how spark has: https://github.com/apache/spark/tree/master/core/src/main/scala-2.13



-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@hbase.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [hbase-connectors] NihalJain commented on a diff in pull request #119: HBASE-27178 Use spotless to format code (including scala code)

Posted by "NihalJain (via GitHub)" <gi...@apache.org>.
NihalJain commented on code in PR #119:
URL: https://github.com/apache/hbase-connectors/pull/119#discussion_r1284278160


##########
dev-support/.scalafmt.conf:
##########
@@ -0,0 +1,38 @@
+#
+# 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.
+#
+
+# Template based off apache spark: https://github.com/apache/spark/blob/master/dev/.scalafmt.conf
+align = none
+align.openParenDefnSite = false
+align.openParenCallSite = false
+align.tokens = []
+importSelectors = "singleLine"
+optIn = {
+  configStyleArguments = false
+}
+danglingParentheses.preset = false
+docstrings.style = Asterisk
+# See https://github.com/scalameta/scalafmt/issues/1387
+docstrings.wrap = no
+maxColumn = 98
+runner.dialect = scala212
+fileOverride {

Review Comment:
   Need feedback: IMHO we can drop this as we do not have this directory/muliple scala implementations similar to how spark has: https://github.com/apache/spark/tree/master/core/src/main/scala-2.13



-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@hbase.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [hbase-connectors] Apache-HBase commented on pull request #119: HBASE-27178 Use spotless to format code (including scala code)

Posted by "Apache-HBase (via GitHub)" <gi...@apache.org>.
Apache-HBase commented on PR #119:
URL: https://github.com/apache/hbase-connectors/pull/119#issuecomment-1665192186

   :confetti_ball: **+1 overall**
   
   
   
   
   
   
   | Vote | Subsystem | Runtime | Comment |
   |:----:|----------:|--------:|:--------|
   | +0 :ok: |  reexec  |   1m 26s |  Docker mode activated.  |
   ||| _ Prechecks _ |
   | +1 :green_heart: |  dupname  |   0m  1s |  No case conflicting files found.  |
   | +0 :ok: |  markdownlint  |   0m  1s |  markdownlint was not available.  |
   | +0 :ok: |  shelldocs  |   0m  1s |  Shelldocs was not available.  |
   | +0 :ok: |  spotbugs  |   0m  0s |  spotbugs executables are not available.  |
   | +1 :green_heart: |  @author  |   0m  0s |  The patch does not contain any @author tags.  |
   | +1 :green_heart: |  test4tests  |   0m  0s |  The patch appears to include 20 new or modified test files.  |
   ||| _ master Compile Tests _ |
   | +0 :ok: |  mvndep  |   0m 27s |  Maven dependency ordering for branch  |
   | +1 :green_heart: |  mvninstall  |   1m 45s |  master passed  |
   | +1 :green_heart: |  compile  |   1m  1s |  master passed  |
   | +1 :green_heart: |  javadoc  |   0m 57s |  master passed  |
   | +1 :green_heart: |  scaladoc  |   0m  0s |  master passed  |
   ||| _ Patch Compile Tests _ |
   | +0 :ok: |  mvndep  |   0m  7s |  Maven dependency ordering for patch  |
   | +1 :green_heart: |  mvninstall  |   0m 53s |  the patch passed  |
   | +1 :green_heart: |  compile  |   1m 12s |  the patch passed  |
   | +1 :green_heart: |  javac  |   1m 12s |  the patch passed  |
   | +1 :green_heart: |  scalac  |   1m 12s |  the patch passed  |
   | +1 :green_heart: |  shellcheck  |   0m  0s |  There were no new shellcheck issues.  |
   | +1 :green_heart: |  whitespace  |   0m  0s |  The patch has no whitespace issues.  |
   | +1 :green_heart: |  xml  |   0m 10s |  The patch has no ill-formed XML file.  |
   | +1 :green_heart: |  javadoc  |   1m  0s |  the patch passed  |
   | +1 :green_heart: |  scaladoc  |   0m  0s |  the patch passed  |
   ||| _ Other Tests _ |
   | +1 :green_heart: |  unit  |   9m  3s |  root in the patch passed.  |
   |  |   |  19m 29s |   |
   
   
   | Subsystem | Report/Notes |
   |----------:|:-------------|
   | Docker | ClientAPI=1.43 ServerAPI=1.43 base: https://ci-hbase.apache.org/job/HBase-Connectors-PreCommit/job/PR-119/1/artifact/yetus-precommit-check/output/Dockerfile |
   | GITHUB PR | https://github.com/apache/hbase-connectors/pull/119 |
   | Optional Tests | dupname markdownlint xml shellcheck shelldocs javac javadoc unit compile spotbugs findbugs scalac scaladoc |
   | uname | Linux ff88f39620be 5.4.0-1103-aws #111~18.04.1-Ubuntu SMP Tue May 23 20:04:10 UTC 2023 x86_64 GNU/Linux |
   | Build tool | hb_maven |
   | Personality | dev-support/jenkins/hbase-personality.sh |
   | git revision | master / bfcdf68 |
   | Default Java | Oracle Corporation-1.8.0_282-b08 |
   |  Test Results | https://ci-hbase.apache.org/job/HBase-Connectors-PreCommit/job/PR-119/1/testReport/ |
   | Max. process+thread count | 954 (vs. ulimit of 12500) |
   | modules | C: kafka kafka/hbase-kafka-model kafka/hbase-kafka-proxy spark spark/hbase-spark-protocol spark/hbase-spark-protocol-shaded spark/hbase-spark spark/hbase-spark-it hbase-connectors-assembly . test-reporting U: . |
   | Console output | https://ci-hbase.apache.org/job/HBase-Connectors-PreCommit/job/PR-119/1/console |
   | versions | git=2.20.1 shellcheck=0.5.0 |
   | Powered by | Apache Yetus 0.12.0 https://yetus.apache.org |
   
   
   This message was automatically generated.
   
   


-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@hbase.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [hbase-connectors] NihalJain commented on pull request #119: HBASE-27178 Use spotless to format code (including scala code)

Posted by "NihalJain (via GitHub)" <gi...@apache.org>.
NihalJain commented on PR #119:
URL: https://github.com/apache/hbase-connectors/pull/119#issuecomment-1665359545

   Reverted 2nd commit and fix scala param issue. The changes 
   
   > Commit 1: Added plug-in along with required files (including support for scala code) Commit 2: Ran mvn spotless:apply and staged all file changes. We can decide if we want to do this as a separate change to keep things clean.
   > 
   > Let me know what do you all think of this change.
   > 
   > CC: @duo @ndimiduk @wchevreuil @petersomogyi @Reidddddd
   
   Dropped 2nd commit as discuused with @Reidddddd. Will raise a WIP-PR with results after applying commit 1 here and running 'mvn spotless:apply'.


-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@hbase.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [hbase-connectors] NihalJain commented on a diff in pull request #119: HBASE-27178 Use spotless to format code (including scala code)

Posted by "NihalJain (via GitHub)" <gi...@apache.org>.
NihalJain commented on code in PR #119:
URL: https://github.com/apache/hbase-connectors/pull/119#discussion_r1284277208


##########
dev-support/.scalafmt.conf:
##########
@@ -0,0 +1,38 @@
+#
+# 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.
+#
+
+# Template based off apache spark: https://github.com/apache/spark/blob/master/dev/.scalafmt.conf
+align = none
+align.openParenDefnSite = false
+align.openParenCallSite = false
+align.tokens = []
+importSelectors = "singleLine"
+optIn = {
+  configStyleArguments = false
+}
+danglingParentheses.preset = false
+docstrings.style = Asterisk
+# See https://github.com/scalameta/scalafmt/issues/1387
+docstrings.wrap = no
+maxColumn = 98

Review Comment:
   Need feedback: should we make this 100, similar to setting that we have for java? Or keep it same as spark project?



-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@hbase.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [hbase-connectors] NihalJain commented on a diff in pull request #119: HBASE-27178 Use spotless to format code (including scala code)

Posted by "NihalJain (via GitHub)" <gi...@apache.org>.
NihalJain commented on code in PR #119:
URL: https://github.com/apache/hbase-connectors/pull/119#discussion_r1284189084


##########
spark/hbase-spark/src/main/scala/org/apache/hadoop/hbase/spark/datasources/JavaBytesEncoder.scala:
##########
@@ -25,84 +25,101 @@ import org.apache.yetus.audience.InterfaceStability
 import org.apache.spark.sql.types._
 
 /**
-  * The ranges for the data type whose size is known. Whether the bound is inclusive
-  * or exclusive is undefind, and upper to the caller to decide.
-  *
-  * @param low: the lower bound of the range.
-  * @param upper: the upper bound of the range.
-  */
+ * The ranges for the data type whose size is known. Whether the bound is inclusive or exclusive
+ * is undefind, and upper to the caller to decide.
+ *
+ * @param low:
+ *   the lower bound of the range.
+ * @param upper:
+ *   the upper bound of the range.
+ */
 @InterfaceAudience.LimitedPrivate(Array(HBaseInterfaceAudience.SPARK))
 @InterfaceStability.Evolving
-case class BoundRange(low: Array[Byte],upper: Array[Byte])
+case class BoundRange(low: Array[Byte], upper: Array[Byte])
 
 /**
-  * The class identifies the ranges for a java primitive type. The caller needs
-  * to decide the bound is either inclusive or exclusive on its own.
-  * information
-  *
-  * @param less: the set of ranges for LessThan/LessOrEqualThan
-  * @param greater: the set of ranges for GreaterThan/GreaterThanOrEqualTo
-  * @param value: the byte array of the original value
-  */
+ * The class identifies the ranges for a java primitive type. The caller needs to decide the bound
+ * is either inclusive or exclusive on its own. information
+ *
+ * @param less:
+ *   the set of ranges for LessThan/LessOrEqualThan
+ * @param greater:
+ *   the set of ranges for GreaterThan/GreaterThanOrEqualTo
+ * @param value:
+ *   the byte array of the original value
+ */
 @InterfaceAudience.LimitedPrivate(Array(HBaseInterfaceAudience.SPARK))
 @InterfaceStability.Evolving
 case class BoundRanges(less: Array[BoundRange], greater: Array[BoundRange], value: Array[Byte])
 
 /**
-  * The trait to support plugin architecture for different encoder/decoder.
-  * encode is used for serializing the data type to byte array and the filter is
-  * used to filter out the unnecessary records.
-  */
+ * The trait to support plugin architecture for different encoder/decoder. encode is used for
+ * serializing the data type to byte array and the filter is used to filter out the unnecessary
+ * records.
+ */
 @InterfaceAudience.LimitedPrivate(Array(HBaseInterfaceAudience.SPARK))
 @InterfaceStability.Evolving
 trait BytesEncoder {
   def encode(dt: DataType, value: Any): Array[Byte]
 
   /**
-    * The function performing real filtering operations. The format of filterBytes depends on the
-    * implementation of the BytesEncoder.
-    *
-    * @param input: the current input byte array that needs to be filtered out
-    * @param offset1: the starting offset of the input byte array.
-    * @param length1: the length of the input byte array.
-    * @param filterBytes: the byte array provided by query condition.
-    * @param offset2: the starting offset in the filterBytes.
-    * @param length2: the length of the bytes in the filterBytes
-    * @param ops: The operation of the filter operator.
-    * @return true: the record satisfies the predicates
-    *         false: the record does not satisfy the predicates.
-    */
-  def filter(input: Array[Byte], offset1: Int, length1: Int,
-             filterBytes: Array[Byte], offset2: Int, length2: Int,
-             ops: JavaBytesEncoder): Boolean
+   * The function performing real filtering operations. The format of filterBytes depends on the
+   * implementation of the BytesEncoder.
+   *
+   * @param input:

Review Comment:
   its an issue with scalafmt plugin version we are using: https://github.com/scalameta/scalafmt/issues/1387
   Will try to bump up to fixed version and update here: https://github.com/scalameta/scalafmt/pull/1987 or apply workaround (as last resort)



-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@hbase.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [hbase-connectors] NihalJain commented on pull request #119: HBASE-27178 Use spotless to format code (including scala code)

Posted by "NihalJain (via GitHub)" <gi...@apache.org>.
NihalJain commented on PR #119:
URL: https://github.com/apache/hbase-connectors/pull/119#issuecomment-1665146240

   Commit 1: Added plug-in along with required files (including support for scala code)
   Commit 2:
   Ran mvn spotless:apply and staged all file changes. We can decide if we want to do this as a separate change to keep things clean.
   
   Let me know what do you all think of this change.
   
   CC: @duo @ndimiduk @wchevreuil @petersomogyi @Reidddddd 


-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@hbase.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [hbase-connectors] NihalJain commented on a diff in pull request #119: HBASE-27178 Use spotless to format code (including scala code)

Posted by "NihalJain (via GitHub)" <gi...@apache.org>.
NihalJain commented on code in PR #119:
URL: https://github.com/apache/hbase-connectors/pull/119#discussion_r1287550789


##########
dev-support/.scalafmt.conf:
##########
@@ -0,0 +1,38 @@
+#
+# 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.
+#
+
+# Template based off apache spark: https://github.com/apache/spark/blob/master/dev/.scalafmt.conf
+align = none
+align.openParenDefnSite = false
+align.openParenCallSite = false
+align.tokens = []
+importSelectors = "singleLine"
+optIn = {
+  configStyleArguments = false
+}
+danglingParentheses.preset = false
+docstrings.style = Asterisk
+# See https://github.com/scalameta/scalafmt/issues/1387
+docstrings.wrap = no
+maxColumn = 98

Review Comment:
   fixed in commit 2



##########
dev-support/.scalafmt.conf:
##########
@@ -0,0 +1,38 @@
+#
+# 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.
+#
+
+# Template based off apache spark: https://github.com/apache/spark/blob/master/dev/.scalafmt.conf
+align = none
+align.openParenDefnSite = false
+align.openParenCallSite = false
+align.tokens = []
+importSelectors = "singleLine"
+optIn = {
+  configStyleArguments = false
+}
+danglingParentheses.preset = false
+docstrings.style = Asterisk
+# See https://github.com/scalameta/scalafmt/issues/1387
+docstrings.wrap = no
+maxColumn = 98
+runner.dialect = scala212
+fileOverride {

Review Comment:
   fixed in commit 2



-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@hbase.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [hbase-connectors] NihalJain commented on a diff in pull request #119: HBASE-27178 Use spotless to format code (including scala code)

Posted by "NihalJain (via GitHub)" <gi...@apache.org>.
NihalJain commented on code in PR #119:
URL: https://github.com/apache/hbase-connectors/pull/119#discussion_r1284092957


##########
spark/hbase-spark/src/main/java/org/apache/hadoop/hbase/spark/example/hbasecontext/JavaHBaseBulkLoadExample.java:
##########
@@ -35,19 +36,17 @@
 import org.apache.yetus.audience.InterfaceAudience;
 
 /**
- * Run this example using command below:

Review Comment:
   wrap in code block



-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@hbase.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [hbase-connectors] Reidddddd commented on pull request #119: HBASE-27178 Use spotless to format code (including scala code)

Posted by "Reidddddd (via GitHub)" <gi...@apache.org>.
Reidddddd commented on PR #119:
URL: https://github.com/apache/hbase-connectors/pull/119#issuecomment-1665194213

   >> if we want to do this as a separate change to keep things clean.
   
   I'd like the separation


-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@hbase.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [hbase-connectors] NihalJain commented on pull request #119: HBASE-27178 Use spotless to format code (including scala code)

Posted by "NihalJain (via GitHub)" <gi...@apache.org>.
NihalJain commented on PR #119:
URL: https://github.com/apache/hbase-connectors/pull/119#issuecomment-1674156758

   Thanks for review / merge. @Reidddddd / @wForget 
   I have rebased https://github.com/apache/hbase-connectors/pull/120 with this change.


-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@hbase.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [hbase-connectors] NihalJain commented on a diff in pull request #119: HBASE-27178 Use spotless to format code (including scala code)

Posted by "NihalJain (via GitHub)" <gi...@apache.org>.
NihalJain commented on code in PR #119:
URL: https://github.com/apache/hbase-connectors/pull/119#discussion_r1287550542


##########
dev-support/.scalafmt.conf:
##########
@@ -0,0 +1,38 @@
+#
+# 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.
+#
+
+# Template based off apache spark: https://github.com/apache/spark/blob/master/dev/.scalafmt.conf
+align = none
+align.openParenDefnSite = false
+align.openParenCallSite = false
+align.tokens = []
+importSelectors = "singleLine"
+optIn = {
+  configStyleArguments = false
+}
+danglingParentheses.preset = false
+docstrings.style = Asterisk
+# See https://github.com/scalameta/scalafmt/issues/1387
+docstrings.wrap = no
+maxColumn = 98
+runner.dialect = scala212
+fileOverride {
+  "glob:**/src/**/scala-2.13/**.scala" {
+    runner.dialect = scala213
+  }
+}
+version = 3.7.12

Review Comment:
   fixed



-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@hbase.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [hbase-connectors] Apache-HBase commented on pull request #119: HBASE-27178 Use spotless to format code (including scala code)

Posted by "Apache-HBase (via GitHub)" <gi...@apache.org>.
Apache-HBase commented on PR #119:
URL: https://github.com/apache/hbase-connectors/pull/119#issuecomment-1670217397

   :confetti_ball: **+1 overall**
   
   
   
   
   
   
   | Vote | Subsystem | Runtime | Comment |
   |:----:|----------:|--------:|:--------|
   | +0 :ok: |  reexec  |   1m 29s |  Docker mode activated.  |
   ||| _ Prechecks _ |
   | +1 :green_heart: |  dupname  |   0m  0s |  No case conflicting files found.  |
   | +0 :ok: |  shelldocs  |   0m  0s |  Shelldocs was not available.  |
   | +1 :green_heart: |  @author  |   0m  0s |  The patch does not contain any @author tags.  |
   | -0 :warning: |  test4tests  |   0m  0s |  The patch doesn't appear to include any new or modified tests. Please justify why no new tests are needed for this patch. Also please list what manual steps were performed to verify this patch.  |
   ||| _ master Compile Tests _ |
   | +1 :green_heart: |  mvninstall  |   1m 33s |  master passed  |
   | +1 :green_heart: |  compile  |   0m 54s |  master passed  |
   | +1 :green_heart: |  javadoc  |   0m 51s |  master passed  |
   ||| _ Patch Compile Tests _ |
   | +1 :green_heart: |  mvninstall  |   0m 49s |  the patch passed  |
   | +1 :green_heart: |  compile  |   0m 52s |  the patch passed  |
   | +1 :green_heart: |  javac  |   0m 52s |  the patch passed  |
   | +1 :green_heart: |  shellcheck  |   0m  0s |  There were no new shellcheck issues.  |
   | +1 :green_heart: |  whitespace  |   0m  0s |  The patch has no whitespace issues.  |
   | +1 :green_heart: |  xml  |   0m  2s |  The patch has no ill-formed XML file.  |
   | +1 :green_heart: |  javadoc  |   0m 51s |  the patch passed  |
   ||| _ Other Tests _ |
   | +1 :green_heart: |  unit  |   8m 56s |  root in the patch passed.  |
   |  |   |  17m 15s |   |
   
   
   | Subsystem | Report/Notes |
   |----------:|:-------------|
   | Docker | ClientAPI=1.43 ServerAPI=1.43 base: https://ci-hbase.apache.org/job/HBase-Connectors-PreCommit/job/PR-119/3/artifact/yetus-precommit-check/output/Dockerfile |
   | GITHUB PR | https://github.com/apache/hbase-connectors/pull/119 |
   | Optional Tests | dupname xml shellcheck shelldocs javac javadoc unit compile |
   | uname | Linux 0152dd29d01b 5.4.0-152-generic #169-Ubuntu SMP Tue Jun 6 22:23:09 UTC 2023 x86_64 GNU/Linux |
   | Build tool | hb_maven |
   | Personality | dev-support/jenkins/hbase-personality.sh |
   | git revision | master / bfcdf68 |
   | Default Java | Oracle Corporation-1.8.0_282-b08 |
   |  Test Results | https://ci-hbase.apache.org/job/HBase-Connectors-PreCommit/job/PR-119/3/testReport/ |
   | Max. process+thread count | 959 (vs. ulimit of 12500) |
   | modules | C: . U: . |
   | Console output | https://ci-hbase.apache.org/job/HBase-Connectors-PreCommit/job/PR-119/3/console |
   | versions | git=2.20.1 shellcheck=0.5.0 |
   | Powered by | Apache Yetus 0.12.0 https://yetus.apache.org |
   
   
   This message was automatically generated.
   
   


-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@hbase.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [hbase-connectors] Reidddddd commented on pull request #119: HBASE-27178 Use spotless to format code (including scala code)

Posted by "Reidddddd (via GitHub)" <gi...@apache.org>.
Reidddddd commented on PR #119:
URL: https://github.com/apache/hbase-connectors/pull/119#issuecomment-1665186728

   > Commit 1: Added plug-in along with required files (including support for scala code) Commit 2: Ran mvn spotless:apply and staged all file changes. We can decide if we want to do this as a separate change to keep things clean.
   > 
   > Let me know what do you all think of this change.
   > 
   > CC: @duo @ndimiduk @wchevreuil @petersomogyi @Reidddddd
   
   duo is this account: @Apache9 


-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@hbase.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [hbase-connectors] NihalJain commented on pull request #119: HBASE-27178 Use spotless to format code (including scala code)

Posted by "NihalJain (via GitHub)" <gi...@apache.org>.
NihalJain commented on PR #119:
URL: https://github.com/apache/hbase-connectors/pull/119#issuecomment-1665294332

   > > > if we want to do this as a separate change to keep things clean.
   > 
   > I'd like the separation
   
   Sure will force push and drop 2nd commit once it looks good to others


-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@hbase.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [hbase-connectors] Reidddddd commented on a diff in pull request #119: HBASE-27178 Use spotless to format code (including scala code)

Posted by "Reidddddd (via GitHub)" <gi...@apache.org>.
Reidddddd commented on code in PR #119:
URL: https://github.com/apache/hbase-connectors/pull/119#discussion_r1286547800


##########
dev-support/.scalafmt.conf:
##########
@@ -0,0 +1,38 @@
+#
+# 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.
+#
+
+# Template based off apache spark: https://github.com/apache/spark/blob/master/dev/.scalafmt.conf
+align = none
+align.openParenDefnSite = false
+align.openParenCallSite = false
+align.tokens = []
+importSelectors = "singleLine"
+optIn = {
+  configStyleArguments = false
+}
+danglingParentheses.preset = false
+docstrings.style = Asterisk
+# See https://github.com/scalameta/scalafmt/issues/1387
+docstrings.wrap = no
+maxColumn = 98
+runner.dialect = scala212
+fileOverride {

Review Comment:
   +1



-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@hbase.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [hbase-connectors] NihalJain commented on a diff in pull request #119: HBASE-27178 Use spotless to format code (including scala code)

Posted by "NihalJain (via GitHub)" <gi...@apache.org>.
NihalJain commented on code in PR #119:
URL: https://github.com/apache/hbase-connectors/pull/119#discussion_r1284113860


##########
spark/hbase-spark/src/main/scala/org/apache/hadoop/hbase/spark/datasources/JavaBytesEncoder.scala:
##########
@@ -25,84 +25,101 @@ import org.apache.yetus.audience.InterfaceStability
 import org.apache.spark.sql.types._
 
 /**
-  * The ranges for the data type whose size is known. Whether the bound is inclusive
-  * or exclusive is undefind, and upper to the caller to decide.
-  *
-  * @param low: the lower bound of the range.
-  * @param upper: the upper bound of the range.
-  */
+ * The ranges for the data type whose size is known. Whether the bound is inclusive or exclusive
+ * is undefind, and upper to the caller to decide.
+ *
+ * @param low:
+ *   the lower bound of the range.
+ * @param upper:
+ *   the upper bound of the range.
+ */
 @InterfaceAudience.LimitedPrivate(Array(HBaseInterfaceAudience.SPARK))
 @InterfaceStability.Evolving
-case class BoundRange(low: Array[Byte],upper: Array[Byte])
+case class BoundRange(low: Array[Byte], upper: Array[Byte])
 
 /**
-  * The class identifies the ranges for a java primitive type. The caller needs
-  * to decide the bound is either inclusive or exclusive on its own.
-  * information
-  *
-  * @param less: the set of ranges for LessThan/LessOrEqualThan
-  * @param greater: the set of ranges for GreaterThan/GreaterThanOrEqualTo
-  * @param value: the byte array of the original value
-  */
+ * The class identifies the ranges for a java primitive type. The caller needs to decide the bound
+ * is either inclusive or exclusive on its own. information
+ *
+ * @param less:
+ *   the set of ranges for LessThan/LessOrEqualThan
+ * @param greater:
+ *   the set of ranges for GreaterThan/GreaterThanOrEqualTo
+ * @param value:
+ *   the byte array of the original value
+ */
 @InterfaceAudience.LimitedPrivate(Array(HBaseInterfaceAudience.SPARK))
 @InterfaceStability.Evolving
 case class BoundRanges(less: Array[BoundRange], greater: Array[BoundRange], value: Array[Byte])
 
 /**
-  * The trait to support plugin architecture for different encoder/decoder.
-  * encode is used for serializing the data type to byte array and the filter is
-  * used to filter out the unnecessary records.
-  */
+ * The trait to support plugin architecture for different encoder/decoder. encode is used for
+ * serializing the data type to byte array and the filter is used to filter out the unnecessary
+ * records.
+ */
 @InterfaceAudience.LimitedPrivate(Array(HBaseInterfaceAudience.SPARK))
 @InterfaceStability.Evolving
 trait BytesEncoder {
   def encode(dt: DataType, value: Any): Array[Byte]
 
   /**
-    * The function performing real filtering operations. The format of filterBytes depends on the
-    * implementation of the BytesEncoder.
-    *
-    * @param input: the current input byte array that needs to be filtered out
-    * @param offset1: the starting offset of the input byte array.
-    * @param length1: the length of the input byte array.
-    * @param filterBytes: the byte array provided by query condition.
-    * @param offset2: the starting offset in the filterBytes.
-    * @param length2: the length of the bytes in the filterBytes
-    * @param ops: The operation of the filter operator.
-    * @return true: the record satisfies the predicates
-    *         false: the record does not satisfy the predicates.
-    */
-  def filter(input: Array[Byte], offset1: Int, length1: Int,
-             filterBytes: Array[Byte], offset2: Int, length2: Int,
-             ops: JavaBytesEncoder): Boolean
+   * The function performing real filtering operations. The format of filterBytes depends on the
+   * implementation of the BytesEncoder.
+   *
+   * @param input:

Review Comment:
   this does no look right



##########
spark/hbase-spark/src/main/scala/org/apache/hadoop/hbase/spark/datasources/JavaBytesEncoder.scala:
##########
@@ -25,84 +25,101 @@ import org.apache.yetus.audience.InterfaceStability
 import org.apache.spark.sql.types._
 
 /**
-  * The ranges for the data type whose size is known. Whether the bound is inclusive
-  * or exclusive is undefind, and upper to the caller to decide.
-  *
-  * @param low: the lower bound of the range.
-  * @param upper: the upper bound of the range.
-  */
+ * The ranges for the data type whose size is known. Whether the bound is inclusive or exclusive
+ * is undefind, and upper to the caller to decide.
+ *
+ * @param low:
+ *   the lower bound of the range.
+ * @param upper:
+ *   the upper bound of the range.
+ */
 @InterfaceAudience.LimitedPrivate(Array(HBaseInterfaceAudience.SPARK))
 @InterfaceStability.Evolving
-case class BoundRange(low: Array[Byte],upper: Array[Byte])
+case class BoundRange(low: Array[Byte], upper: Array[Byte])
 
 /**
-  * The class identifies the ranges for a java primitive type. The caller needs
-  * to decide the bound is either inclusive or exclusive on its own.
-  * information
-  *
-  * @param less: the set of ranges for LessThan/LessOrEqualThan
-  * @param greater: the set of ranges for GreaterThan/GreaterThanOrEqualTo
-  * @param value: the byte array of the original value
-  */
+ * The class identifies the ranges for a java primitive type. The caller needs to decide the bound
+ * is either inclusive or exclusive on its own. information
+ *
+ * @param less:
+ *   the set of ranges for LessThan/LessOrEqualThan
+ * @param greater:
+ *   the set of ranges for GreaterThan/GreaterThanOrEqualTo
+ * @param value:
+ *   the byte array of the original value
+ */
 @InterfaceAudience.LimitedPrivate(Array(HBaseInterfaceAudience.SPARK))
 @InterfaceStability.Evolving
 case class BoundRanges(less: Array[BoundRange], greater: Array[BoundRange], value: Array[Byte])
 
 /**
-  * The trait to support plugin architecture for different encoder/decoder.
-  * encode is used for serializing the data type to byte array and the filter is
-  * used to filter out the unnecessary records.
-  */
+ * The trait to support plugin architecture for different encoder/decoder. encode is used for
+ * serializing the data type to byte array and the filter is used to filter out the unnecessary
+ * records.
+ */
 @InterfaceAudience.LimitedPrivate(Array(HBaseInterfaceAudience.SPARK))
 @InterfaceStability.Evolving
 trait BytesEncoder {
   def encode(dt: DataType, value: Any): Array[Byte]
 
   /**
-    * The function performing real filtering operations. The format of filterBytes depends on the
-    * implementation of the BytesEncoder.
-    *
-    * @param input: the current input byte array that needs to be filtered out
-    * @param offset1: the starting offset of the input byte array.
-    * @param length1: the length of the input byte array.
-    * @param filterBytes: the byte array provided by query condition.
-    * @param offset2: the starting offset in the filterBytes.
-    * @param length2: the length of the bytes in the filterBytes
-    * @param ops: The operation of the filter operator.
-    * @return true: the record satisfies the predicates
-    *         false: the record does not satisfy the predicates.
-    */
-  def filter(input: Array[Byte], offset1: Int, length1: Int,
-             filterBytes: Array[Byte], offset2: Int, length2: Int,
-             ops: JavaBytesEncoder): Boolean
+   * The function performing real filtering operations. The format of filterBytes depends on the
+   * implementation of the BytesEncoder.
+   *
+   * @param input:

Review Comment:
   this does not look right



-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@hbase.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [hbase-connectors] NihalJain commented on a diff in pull request #119: HBASE-27178 Use spotless to format code (including scala code)

Posted by "NihalJain (via GitHub)" <gi...@apache.org>.
NihalJain commented on code in PR #119:
URL: https://github.com/apache/hbase-connectors/pull/119#discussion_r1284278160


##########
dev-support/.scalafmt.conf:
##########
@@ -0,0 +1,38 @@
+#
+# 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.
+#
+
+# Template based off apache spark: https://github.com/apache/spark/blob/master/dev/.scalafmt.conf
+align = none
+align.openParenDefnSite = false
+align.openParenCallSite = false
+align.tokens = []
+importSelectors = "singleLine"
+optIn = {
+  configStyleArguments = false
+}
+danglingParentheses.preset = false
+docstrings.style = Asterisk
+# See https://github.com/scalameta/scalafmt/issues/1387
+docstrings.wrap = no
+maxColumn = 98
+runner.dialect = scala212
+fileOverride {

Review Comment:
   Need feedback: IMHO we can drop this as we do not have this directory/implementation as spark has: https://github.com/apache/spark/tree/master/core/src/main/scala-2.13



-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@hbase.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [hbase-connectors] NihalJain commented on a diff in pull request #119: HBASE-27178 Use spotless to format code (including scala code)

Posted by "NihalJain (via GitHub)" <gi...@apache.org>.
NihalJain commented on code in PR #119:
URL: https://github.com/apache/hbase-connectors/pull/119#discussion_r1284266677


##########
spark/hbase-spark/src/main/scala/org/apache/hadoop/hbase/spark/datasources/JavaBytesEncoder.scala:
##########
@@ -25,84 +25,101 @@ import org.apache.yetus.audience.InterfaceStability
 import org.apache.spark.sql.types._
 
 /**
-  * The ranges for the data type whose size is known. Whether the bound is inclusive
-  * or exclusive is undefind, and upper to the caller to decide.
-  *
-  * @param low: the lower bound of the range.
-  * @param upper: the upper bound of the range.
-  */
+ * The ranges for the data type whose size is known. Whether the bound is inclusive or exclusive
+ * is undefind, and upper to the caller to decide.
+ *
+ * @param low:
+ *   the lower bound of the range.
+ * @param upper:
+ *   the upper bound of the range.
+ */
 @InterfaceAudience.LimitedPrivate(Array(HBaseInterfaceAudience.SPARK))
 @InterfaceStability.Evolving
-case class BoundRange(low: Array[Byte],upper: Array[Byte])
+case class BoundRange(low: Array[Byte], upper: Array[Byte])
 
 /**
-  * The class identifies the ranges for a java primitive type. The caller needs
-  * to decide the bound is either inclusive or exclusive on its own.
-  * information
-  *
-  * @param less: the set of ranges for LessThan/LessOrEqualThan
-  * @param greater: the set of ranges for GreaterThan/GreaterThanOrEqualTo
-  * @param value: the byte array of the original value
-  */
+ * The class identifies the ranges for a java primitive type. The caller needs to decide the bound
+ * is either inclusive or exclusive on its own. information
+ *
+ * @param less:
+ *   the set of ranges for LessThan/LessOrEqualThan
+ * @param greater:
+ *   the set of ranges for GreaterThan/GreaterThanOrEqualTo
+ * @param value:
+ *   the byte array of the original value
+ */
 @InterfaceAudience.LimitedPrivate(Array(HBaseInterfaceAudience.SPARK))
 @InterfaceStability.Evolving
 case class BoundRanges(less: Array[BoundRange], greater: Array[BoundRange], value: Array[Byte])
 
 /**
-  * The trait to support plugin architecture for different encoder/decoder.
-  * encode is used for serializing the data type to byte array and the filter is
-  * used to filter out the unnecessary records.
-  */
+ * The trait to support plugin architecture for different encoder/decoder. encode is used for
+ * serializing the data type to byte array and the filter is used to filter out the unnecessary
+ * records.
+ */
 @InterfaceAudience.LimitedPrivate(Array(HBaseInterfaceAudience.SPARK))
 @InterfaceStability.Evolving
 trait BytesEncoder {
   def encode(dt: DataType, value: Any): Array[Byte]
 
   /**
-    * The function performing real filtering operations. The format of filterBytes depends on the
-    * implementation of the BytesEncoder.
-    *
-    * @param input: the current input byte array that needs to be filtered out
-    * @param offset1: the starting offset of the input byte array.
-    * @param length1: the length of the input byte array.
-    * @param filterBytes: the byte array provided by query condition.
-    * @param offset2: the starting offset in the filterBytes.
-    * @param length2: the length of the bytes in the filterBytes
-    * @param ops: The operation of the filter operator.
-    * @return true: the record satisfies the predicates
-    *         false: the record does not satisfy the predicates.
-    */
-  def filter(input: Array[Byte], offset1: Int, length1: Int,
-             filterBytes: Array[Byte], offset2: Int, length2: Int,
-             ops: JavaBytesEncoder): Boolean
+   * The function performing real filtering operations. The format of filterBytes depends on the
+   * implementation of the BytesEncoder.
+   *
+   * @param input:

Review Comment:
   update: bumping did not work, so had to apply workaround



-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@hbase.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [hbase-connectors] Reidddddd commented on a diff in pull request #119: HBASE-27178 Use spotless to format code (including scala code)

Posted by "Reidddddd (via GitHub)" <gi...@apache.org>.
Reidddddd commented on code in PR #119:
URL: https://github.com/apache/hbase-connectors/pull/119#discussion_r1286547599


##########
dev-support/.scalafmt.conf:
##########
@@ -0,0 +1,38 @@
+#
+# 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.
+#
+
+# Template based off apache spark: https://github.com/apache/spark/blob/master/dev/.scalafmt.conf
+align = none
+align.openParenDefnSite = false
+align.openParenCallSite = false
+align.tokens = []
+importSelectors = "singleLine"
+optIn = {
+  configStyleArguments = false
+}
+danglingParentheses.preset = false
+docstrings.style = Asterisk
+# See https://github.com/scalameta/scalafmt/issues/1387
+docstrings.wrap = no
+maxColumn = 98

Review Comment:
   let's align with hbase project



-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@hbase.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [hbase-connectors] Reidddddd commented on pull request #119: HBASE-27178 Use spotless to format code (including scala code)

Posted by "Reidddddd (via GitHub)" <gi...@apache.org>.
Reidddddd commented on PR #119:
URL: https://github.com/apache/hbase-connectors/pull/119#issuecomment-1672476519

   let's wait some time whether there are other 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.

To unsubscribe, e-mail: issues-unsubscribe@hbase.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [hbase-connectors] Reidddddd merged pull request #119: HBASE-27178 Use spotless to format code (including scala code)

Posted by "Reidddddd (via GitHub)" <gi...@apache.org>.
Reidddddd merged PR #119:
URL: https://github.com/apache/hbase-connectors/pull/119


-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@hbase.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [hbase-connectors] wForget commented on a diff in pull request #119: HBASE-27178 Use spotless to format code (including scala code)

Posted by "wForget (via GitHub)" <gi...@apache.org>.
wForget commented on code in PR #119:
URL: https://github.com/apache/hbase-connectors/pull/119#discussion_r1284241577


##########
dev-support/.scalafmt.conf:
##########
@@ -0,0 +1,38 @@
+#
+# 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.
+#
+
+# Template based off apache spark: https://github.com/apache/spark/blob/master/dev/.scalafmt.conf
+align = none
+align.openParenDefnSite = false
+align.openParenCallSite = false
+align.tokens = []
+importSelectors = "singleLine"
+optIn = {
+  configStyleArguments = false
+}
+danglingParentheses.preset = false
+docstrings.style = Asterisk
+# See https://github.com/scalameta/scalafmt/issues/1387
+docstrings.wrap = no
+maxColumn = 98
+runner.dialect = scala212
+fileOverride {
+  "glob:**/src/**/scala-2.13/**.scala" {
+    runner.dialect = scala213
+  }
+}
+version = 3.7.12

Review Comment:
   nit: end with newline



-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@hbase.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [hbase-connectors] Apache-HBase commented on pull request #119: HBASE-27178 Use spotless to format code (including scala code)

Posted by "Apache-HBase (via GitHub)" <gi...@apache.org>.
Apache-HBase commented on PR #119:
URL: https://github.com/apache/hbase-connectors/pull/119#issuecomment-1665381814

   :confetti_ball: **+1 overall**
   
   
   
   
   
   
   | Vote | Subsystem | Runtime | Comment |
   |:----:|----------:|--------:|:--------|
   | +0 :ok: |  reexec  |   1m 35s |  Docker mode activated.  |
   ||| _ Prechecks _ |
   | +1 :green_heart: |  dupname  |   0m  0s |  No case conflicting files found.  |
   | +0 :ok: |  shelldocs  |   0m  0s |  Shelldocs was not available.  |
   | +1 :green_heart: |  @author  |   0m  0s |  The patch does not contain any @author tags.  |
   | -0 :warning: |  test4tests  |   0m  0s |  The patch doesn't appear to include any new or modified tests. Please justify why no new tests are needed for this patch. Also please list what manual steps were performed to verify this patch.  |
   ||| _ master Compile Tests _ |
   | +1 :green_heart: |  mvninstall  |   1m 40s |  master passed  |
   | +1 :green_heart: |  compile  |   1m 16s |  master passed  |
   | +1 :green_heart: |  javadoc  |   1m 28s |  master passed  |
   ||| _ Patch Compile Tests _ |
   | +1 :green_heart: |  mvninstall  |   1m  5s |  the patch passed  |
   | +1 :green_heart: |  compile  |   1m 11s |  the patch passed  |
   | +1 :green_heart: |  javac  |   1m 11s |  the patch passed  |
   | +1 :green_heart: |  shellcheck  |   0m  0s |  There were no new shellcheck issues.  |
   | +1 :green_heart: |  whitespace  |   0m  0s |  The patch has no whitespace issues.  |
   | +1 :green_heart: |  xml  |   0m  2s |  The patch has no ill-formed XML file.  |
   | +1 :green_heart: |  javadoc  |   1m  5s |  the patch passed  |
   ||| _ Other Tests _ |
   | +1 :green_heart: |  unit  |   9m 28s |  root in the patch passed.  |
   |  |   |  19m 58s |   |
   
   
   | Subsystem | Report/Notes |
   |----------:|:-------------|
   | Docker | ClientAPI=1.43 ServerAPI=1.43 base: https://ci-hbase.apache.org/job/HBase-Connectors-PreCommit/job/PR-119/2/artifact/yetus-precommit-check/output/Dockerfile |
   | GITHUB PR | https://github.com/apache/hbase-connectors/pull/119 |
   | Optional Tests | dupname xml shellcheck shelldocs javac javadoc unit compile |
   | uname | Linux 6dbfd1e806e7 5.4.0-152-generic #169-Ubuntu SMP Tue Jun 6 22:23:09 UTC 2023 x86_64 GNU/Linux |
   | Build tool | hb_maven |
   | Personality | dev-support/jenkins/hbase-personality.sh |
   | git revision | master / bfcdf68 |
   | Default Java | Oracle Corporation-1.8.0_282-b08 |
   |  Test Results | https://ci-hbase.apache.org/job/HBase-Connectors-PreCommit/job/PR-119/2/testReport/ |
   | Max. process+thread count | 959 (vs. ulimit of 12500) |
   | modules | C: . U: . |
   | Console output | https://ci-hbase.apache.org/job/HBase-Connectors-PreCommit/job/PR-119/2/console |
   | versions | git=2.20.1 shellcheck=0.5.0 |
   | Powered by | Apache Yetus 0.12.0 https://yetus.apache.org |
   
   
   This message was automatically generated.
   
   


-- 
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.

To unsubscribe, e-mail: issues-unsubscribe@hbase.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org