You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@orc.apache.org by do...@apache.org on 2021/09/12 22:09:34 UTC

[orc] branch branch-1.5 updated: MINOR: Fix typos in project (#892)

This is an automated email from the ASF dual-hosted git repository.

dongjoon pushed a commit to branch branch-1.5
in repository https://gitbox.apache.org/repos/asf/orc.git


The following commit(s) were added to refs/heads/branch-1.5 by this push:
     new ffc68c3  MINOR: Fix typos in project (#892)
ffc68c3 is described below

commit ffc68c3c3557108171a73c8512b2d45328b91d54
Author: guiyanakaung <gu...@gmail.com>
AuthorDate: Fri Sep 3 01:41:52 2021 +0800

    MINOR: Fix typos in project (#892)
    
    This PR aims to fix a typos in project.
    
    Easy to read
    
    Pass the CIs.
    
    (cherry picked from commit 9d907815fa988e8de00c833e20c448d624aa8f7a)
    Signed-off-by: Dongjoon Hyun <do...@apache.org>
    (cherry picked from commit fb894c1a8c85af5cc5014269e20960aac92c0858)
    Signed-off-by: Dongjoon Hyun <do...@apache.org>
---
 java/bench/src/java/org/apache/orc/bench/CompressionKind.java       | 4 ++--
 java/bench/src/java/org/apache/orc/bench/DecimalBench.java          | 2 +-
 java/core/src/java/org/apache/orc/OrcFile.java                      | 4 ++--
 java/core/src/java/org/apache/orc/PhysicalWriter.java               | 4 ++--
 java/core/src/java/org/apache/orc/Reader.java                       | 2 +-
 java/core/src/java/org/apache/orc/RecordReader.java                 | 2 +-
 .../core/src/java/org/apache/orc/impl/ConvertTreeReaderFactory.java | 4 ++--
 java/core/src/java/org/apache/orc/impl/RedBlackTree.java            | 4 ++--
 java/core/src/java/org/apache/orc/impl/SchemaEvolution.java         | 6 +++---
 java/core/src/java/org/apache/orc/impl/mask/RedactMaskFactory.java  | 6 +++---
 java/core/src/java/org/apache/orc/impl/writer/TreeWriter.java       | 2 +-
 java/tools/src/java/org/apache/orc/tools/json/HiveType.java         | 2 +-
 12 files changed, 21 insertions(+), 21 deletions(-)

diff --git a/java/bench/src/java/org/apache/orc/bench/CompressionKind.java b/java/bench/src/java/org/apache/orc/bench/CompressionKind.java
index 9274de3..61b34a0 100644
--- a/java/bench/src/java/org/apache/orc/bench/CompressionKind.java
+++ b/java/bench/src/java/org/apache/orc/bench/CompressionKind.java
@@ -35,8 +35,8 @@ public enum CompressionKind {
   ZLIB(".gz"),
   SNAPPY(".snappy");
 
-  CompressionKind(String extendsion) {
-    this.extension = extendsion;
+  CompressionKind(String extension) {
+    this.extension = extension;
   }
 
   private final String extension;
diff --git a/java/bench/src/java/org/apache/orc/bench/DecimalBench.java b/java/bench/src/java/org/apache/orc/bench/DecimalBench.java
index 71a1c33..419ab52 100644
--- a/java/bench/src/java/org/apache/orc/bench/DecimalBench.java
+++ b/java/bench/src/java/org/apache/orc/bench/DecimalBench.java
@@ -96,7 +96,7 @@ public class DecimalBench {
     /**
      * Load the data from the values array into the ColumnVector.
      * @param vector the output
-     * @param values the intput
+     * @param values the input
      * @param offset the first input value
      * @param length the number of values to copy
      */
diff --git a/java/core/src/java/org/apache/orc/OrcFile.java b/java/core/src/java/org/apache/orc/OrcFile.java
index 5d2ddda..93c96a7 100644
--- a/java/core/src/java/org/apache/orc/OrcFile.java
+++ b/java/core/src/java/org/apache/orc/OrcFile.java
@@ -235,7 +235,7 @@ public class OrcFile {
         return FUTURE;
       }
       if (writer != WriterImplementation.ORC_JAVA && val < 6) {
-        throw new IllegalArgumentException("ORC File with illegval version " +
+        throw new IllegalArgumentException("ORC File with illegal version " +
             val + " for writer " + writer);
       }
       WriterVersion[] versions = values[writer.id];
@@ -277,7 +277,7 @@ public class OrcFile {
     private FileSystem filesystem;
     private long maxLength = Long.MAX_VALUE;
     private OrcTail orcTail;
-    // TODO: We can generalize FileMetada interface. Make OrcTail implement FileMetadata interface
+    // TODO: We can generalize FileMetadata interface. Make OrcTail implement FileMetadata interface
     // and remove this class altogether. Both footer caching and llap caching just needs OrcTail.
     // For now keeping this around to avoid complex surgery
     private FileMetadata fileMetadata;
diff --git a/java/core/src/java/org/apache/orc/PhysicalWriter.java b/java/core/src/java/org/apache/orc/PhysicalWriter.java
index 051688b..c465393 100644
--- a/java/core/src/java/org/apache/orc/PhysicalWriter.java
+++ b/java/core/src/java/org/apache/orc/PhysicalWriter.java
@@ -115,7 +115,7 @@ public interface PhysicalWriter {
   void close() throws IOException;
 
   /**
-   * Flushes the writer so that readers can see the preceeding postscripts.
+   * Flushes the writer so that readers can see the preceding postscripts.
    */
   void flush() throws IOException;
 
@@ -134,7 +134,7 @@ public interface PhysicalWriter {
   CompressionCodec getCompressionCodec();
 
   /**
-   * Get the number of bytes for a file in a givem column.
+   * Get the number of bytes for a file in a given column.
    * @param column column from which to get file size
    * @return number of bytes for the given column
    */
diff --git a/java/core/src/java/org/apache/orc/Reader.java b/java/core/src/java/org/apache/orc/Reader.java
index 82376a6..4b14aae 100644
--- a/java/core/src/java/org/apache/orc/Reader.java
+++ b/java/core/src/java/org/apache/orc/Reader.java
@@ -293,7 +293,7 @@ public interface Reader extends Closeable {
 
 
     /**
-     * Set boolean flag to determine if the comparision of field names in schema
+     * Set boolean flag to determine if the comparison of field names in schema
      * evolution is case sensitive
      * @param value the flag for schema evolution is case sensitive or not.
      * @return
diff --git a/java/core/src/java/org/apache/orc/RecordReader.java b/java/core/src/java/org/apache/orc/RecordReader.java
index 2bd94c9..64870c8 100644
--- a/java/core/src/java/org/apache/orc/RecordReader.java
+++ b/java/core/src/java/org/apache/orc/RecordReader.java
@@ -29,7 +29,7 @@ public interface RecordReader extends Closeable {
   /**
    * Read the next row batch. The size of the batch to read cannot be
    * controlled by the callers. Caller need to look at
-   * VectorizedRowBatch.size of the retunred object to know the batch
+   * VectorizedRowBatch.size of the returned object to know the batch
    * size read.
    * @param batch a row batch object to read into
    * @return were more rows available to read?
diff --git a/java/core/src/java/org/apache/orc/impl/ConvertTreeReaderFactory.java b/java/core/src/java/org/apache/orc/impl/ConvertTreeReaderFactory.java
index 6a54da7..f5ecc5e 100644
--- a/java/core/src/java/org/apache/orc/impl/ConvertTreeReaderFactory.java
+++ b/java/core/src/java/org/apache/orc/impl/ConvertTreeReaderFactory.java
@@ -292,7 +292,7 @@ public class ConvertTreeReaderFactory extends TreeReaderFactory {
      */
     // Override this to use convertVector.
     public void setConvertVectorElement(int elementNum) throws IOException {
-      throw new RuntimeException("Expected this method to be overriden");
+      throw new RuntimeException("Expected this method to be overridden");
     }
 
     // Common code used by the conversion.
@@ -2385,7 +2385,7 @@ public class ConvertTreeReaderFactory extends TreeReaderFactory {
    *   TimestampFromAnyIntegerTreeReader (written)
    *   TimestampFromFloatTreeReader (written)
    *   TimestampFromDoubleTreeReader (written)
-   *   TimestampFromDecimalTreeeReader (written)
+   *   TimestampFromDecimalTreeReader (written)
    *   TimestampFromStringGroupTreeReader (written)
    *   TimestampFromDateTreeReader
    *
diff --git a/java/core/src/java/org/apache/orc/impl/RedBlackTree.java b/java/core/src/java/org/apache/orc/impl/RedBlackTree.java
index db405f3..884b42e 100644
--- a/java/core/src/java/org/apache/orc/impl/RedBlackTree.java
+++ b/java/core/src/java/org/apache/orc/impl/RedBlackTree.java
@@ -137,8 +137,8 @@ abstract class RedBlackTree {
    * the parents, this routine passing down the context.
    *
    * The fix is broken down into 6 cases (1.{1,2,3} and 2.{1,2,3} that are
-   * left-right mirror images of each other). See Algorighms by Cormen,
-   * Leiserson, and Rivest for the explaination of the subcases.
+   * left-right mirror images of each other). See Algorithms by Cormen,
+   * Leiserson, and Rivest for the explanation of the subcases.
    *
    * @param node The node that we are fixing right now.
    * @param fromLeft Did we come down from the left?
diff --git a/java/core/src/java/org/apache/orc/impl/SchemaEvolution.java b/java/core/src/java/org/apache/orc/impl/SchemaEvolution.java
index b2c146f..cdc18a0 100644
--- a/java/core/src/java/org/apache/orc/impl/SchemaEvolution.java
+++ b/java/core/src/java/org/apache/orc/impl/SchemaEvolution.java
@@ -313,7 +313,7 @@ public class SchemaEvolution {
     boolean[] result = new boolean[readerSchema.getMaximumId() + 1];
     boolean safePpd = validatePPDConversion(fileSchema, readerSchema);
     result[readerSchema.getId()] = safePpd;
-    return populatePpdSafeConversionForChildern(result,
+    return populatePpdSafeConversionForChildren(result,
         readerSchema.getChildren());
   }
 
@@ -325,7 +325,7 @@ public class SchemaEvolution {
    *
    * @return boolean array to represent list of column safe or not.
    */
-  private boolean[] populatePpdSafeConversionForChildern(
+  private boolean[] populatePpdSafeConversionForChildren(
                         boolean[] ppdSafeConversion,
                         List<TypeDescription> children) {
     boolean safePpd;
@@ -334,7 +334,7 @@ public class SchemaEvolution {
         TypeDescription fileType = getFileType(child.getId());
         safePpd = validatePPDConversion(fileType, child);
         ppdSafeConversion[child.getId()] = safePpd;
-        populatePpdSafeConversionForChildern(ppdSafeConversion,
+        populatePpdSafeConversionForChildren(ppdSafeConversion,
             child.getChildren());
       }
     }
diff --git a/java/core/src/java/org/apache/orc/impl/mask/RedactMaskFactory.java b/java/core/src/java/org/apache/orc/impl/mask/RedactMaskFactory.java
index 7e3e0a1..ff78558 100644
--- a/java/core/src/java/org/apache/orc/impl/mask/RedactMaskFactory.java
+++ b/java/core/src/java/org/apache/orc/impl/mask/RedactMaskFactory.java
@@ -93,7 +93,7 @@ public class RedactMaskFactory extends MaskFactory {
   // The replacement codepoint for each character category. We use codepoints
   // here so that we don't have to worry about handling long UTF characters
   // as special cases.
-  private final int UPPPER_REPLACEMENT;
+  private final int UPPER_REPLACEMENT;
   private final int LOWER_REPLACEMENT;
   private final int OTHER_LETTER_REPLACEMENT;
   private final int MARK_REPLACEMENT;
@@ -123,7 +123,7 @@ public class RedactMaskFactory extends MaskFactory {
   public RedactMaskFactory(String... params) {
     ByteBuffer param = params.length < 1 ? ByteBuffer.allocate(0) :
         ByteBuffer.wrap(params[0].getBytes(StandardCharsets.UTF_8));
-    UPPPER_REPLACEMENT = getNextCodepoint(param, DEFAULT_LETTER_UPPER);
+    UPPER_REPLACEMENT = getNextCodepoint(param, DEFAULT_LETTER_UPPER);
     LOWER_REPLACEMENT = getNextCodepoint(param, DEFAULT_LETTER_LOWER);
     DIGIT_CP_REPLACEMENT = getNextCodepoint(param, DEFAULT_NUMBER_DIGIT_CP);
     DIGIT_REPLACEMENT = getReplacementDigit(DIGIT_CP_REPLACEMENT);
@@ -733,7 +733,7 @@ public class RedactMaskFactory extends MaskFactory {
   int getReplacement(int codepoint) {
     switch (Character.getType(codepoint)) {
       case Character.UPPERCASE_LETTER:
-        return UPPPER_REPLACEMENT;
+        return UPPER_REPLACEMENT;
       case Character.LOWERCASE_LETTER:
         return LOWER_REPLACEMENT;
       case Character.TITLECASE_LETTER:
diff --git a/java/core/src/java/org/apache/orc/impl/writer/TreeWriter.java b/java/core/src/java/org/apache/orc/impl/writer/TreeWriter.java
index bfa403e..7a347b2 100644
--- a/java/core/src/java/org/apache/orc/impl/writer/TreeWriter.java
+++ b/java/core/src/java/org/apache/orc/impl/writer/TreeWriter.java
@@ -46,7 +46,7 @@ public interface TreeWriter {
   long getRawDataSize();
 
   /**
-   * Write a VectorizedRowBath to the file. This is called by the WriterImplV2
+   * Write a VectorizedRowBatch to the file. This is called by the WriterImplV2
    * at the top level.
    * @param batch the list of all of the columns
    * @param offset the first row from the batch to write
diff --git a/java/tools/src/java/org/apache/orc/tools/json/HiveType.java b/java/tools/src/java/org/apache/orc/tools/json/HiveType.java
index 6222aca..ba7452e 100644
--- a/java/tools/src/java/org/apache/orc/tools/json/HiveType.java
+++ b/java/tools/src/java/org/apache/orc/tools/json/HiveType.java
@@ -75,7 +75,7 @@ abstract class HiveType {
   public abstract boolean subsumes(HiveType other);
 
   /**
-   * Merge the other type into this one. It assumes that subsubes(other) is
+   * Merge the other type into this one. It assumes that subsumes(other) is
    * true.
    * @param other
    */