You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@fluo.apache.org by cj...@apache.org on 2018/08/29 14:01:50 UTC

[fluo] branch master updated: Spelling corrections in comments/javadocs (#1047)

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

cjmctague pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/fluo.git


The following commit(s) were added to refs/heads/master by this push:
     new ae34b1d  Spelling corrections in comments/javadocs (#1047)
ae34b1d is described below

commit ae34b1df025b94e61f27f3a34dc271cd992465fe
Author: Christopher McTague <cj...@apache.org>
AuthorDate: Wed Aug 29 10:01:47 2018 -0400

    Spelling corrections in comments/javadocs (#1047)
---
 contrib/create-release-candidate.sh                               | 2 +-
 .../apache/fluo/accumulo/iterators/TimestampSkippingIterator.java | 4 ++--
 .../fluo/accumulo/iterators/GarbageCollectionIteratorTest.java    | 4 ++--
 .../org/apache/fluo/accumulo/iterators/SnapshotIteratorTest.java  | 4 ++--
 .../java/org/apache/fluo/api/client/AbstractSnapshotBase.java     | 2 +-
 .../src/main/java/org/apache/fluo/api/client/LoaderExecutor.java  | 2 +-
 .../java/org/apache/fluo/api/client/scanner/ScannerBuilder.java   | 4 ++--
 .../main/java/org/apache/fluo/api/config/FluoConfiguration.java   | 2 +-
 .../java/org/apache/fluo/api/config/ObserverSpecification.java    | 8 ++++----
 modules/api/src/main/java/org/apache/fluo/api/data/Bytes.java     | 4 ++--
 modules/api/src/test/resources/fluo.properties                    | 2 +-
 .../java/org/apache/fluo/core/client/LoaderExecutorAsyncImpl.java | 2 +-
 .../java/org/apache/fluo/core/impl/FluoConfigurationImpl.java     | 2 +-
 .../core/src/main/java/org/apache/fluo/core/util/ScanUtil.java    | 4 ++--
 modules/distribution/src/main/config/fluo-app.properties          | 2 +-
 modules/distribution/src/main/config/fluo-env.sh                  | 2 +-
 .../test/java/org/apache/fluo/integration/impl/FaultyConfig.java  | 2 +-
 .../test/java/org/apache/fluo/integration/impl/ReadLockIT.java    | 2 +-
 18 files changed, 27 insertions(+), 27 deletions(-)

diff --git a/contrib/create-release-candidate.sh b/contrib/create-release-candidate.sh
index 2f260df..465ad6e 100755
--- a/contrib/create-release-candidate.sh
+++ b/contrib/create-release-candidate.sh
@@ -73,7 +73,7 @@ gitCommit()  { gitCommits -n1 "$@"; }
 gitSubject() { pretty %s "$@"; }
 
 createEmail() {
-  # $1 version (optional); $2 rc seqence num (optional); $3 staging repo num (optional)
+  # $1 version (optional); $2 rc sequence num (optional); $3 staging repo num (optional)
   local ver; [[ -n "$1" ]] && ver=$1 || ver=$(prompter 'version to be released (eg. x.y.z)' '[0-9]+[.][0-9]+[.][0-9]+')
   local rc; [[ -n "$2" ]] && rc=$2 || rc=$(prompter 'release candidate sequence number (eg. 1, 2, etc.)' '[0-9]+')
   local stagingrepo; [[ -n "$3" ]] && stagingrepo=$3 || stagingrepo=$(prompter 'staging repository number from https://repository.apache.org/#stagingRepositories' '[0-9]+')
diff --git a/modules/accumulo/src/main/java/org/apache/fluo/accumulo/iterators/TimestampSkippingIterator.java b/modules/accumulo/src/main/java/org/apache/fluo/accumulo/iterators/TimestampSkippingIterator.java
index ec2a83f..75ba96f 100644
--- a/modules/accumulo/src/main/java/org/apache/fluo/accumulo/iterators/TimestampSkippingIterator.java
+++ b/modules/accumulo/src/main/java/org/apache/fluo/accumulo/iterators/TimestampSkippingIterator.java
@@ -191,7 +191,7 @@ public class TimestampSkippingIterator implements SortedKeyValueIterator<Key, Va
   @VisibleForTesting
   public final boolean shouldSeek() {
     /*
-     * This method is a saftey check to ensure the deleting iterator was removed. If this iterator
+     * This method is a safety check to ensure the deleting iterator was removed. If this iterator
      * was not removed for some reason, then the performance of seeking will be O(N^2). In the case
      * where its not removed, it would be better to just scan forward.
      */
@@ -202,7 +202,7 @@ public class TimestampSkippingIterator implements SortedKeyValueIterator<Key, Va
     if (hasSeeked) {
       // Making assumptions based on how Accumulo currently works. Currently Accumulo does not set
       // up iterators until the 1st seek. Therefore can only remove the deleting iter after the 1st
-      // seek. Also, Accumulo may switch data sources and re-setup the deleting iterator, thats why
+      // seek. Also, Accumulo may switch data sources and re-setup the deleting iterator, that's why
       // this iterator keeps trying to remove it.
       removedDeletingIterator |= removeDeletingIterator(source);
       if (!removedDeletingIterator) {
diff --git a/modules/accumulo/src/test/java/org/apache/fluo/accumulo/iterators/GarbageCollectionIteratorTest.java b/modules/accumulo/src/test/java/org/apache/fluo/accumulo/iterators/GarbageCollectionIteratorTest.java
index 591fdce..18d1291 100644
--- a/modules/accumulo/src/test/java/org/apache/fluo/accumulo/iterators/GarbageCollectionIteratorTest.java
+++ b/modules/accumulo/src/test/java/org/apache/fluo/accumulo/iterators/GarbageCollectionIteratorTest.java
@@ -305,7 +305,7 @@ public class GarbageCollectionIteratorTest {
 
     Assert.assertEquals(expected, output);
 
-    // test write that supercedes a del lock
+    // test write that supersedes a del lock
     input = new TestData();
     input.add("0 f q WRITE 22", "21");
     input.add("0 f q DEL_LOCK 19", "0 ROLLBACK");
@@ -460,7 +460,7 @@ public class GarbageCollectionIteratorTest {
     expected.add("0 h q DATA 33", "9");
     Assert.assertEquals(expected, output);
 
-    // test write that supercededs a delete... delete should not cause write to be GCed
+    // test write that supersedes a delete... delete should not cause write to be GCed
     TestData input = new TestData(inputBase);
     input.add("0 f q WRITE 60", "55");
     input.add("0 f q DATA 55", "abc");
diff --git a/modules/accumulo/src/test/java/org/apache/fluo/accumulo/iterators/SnapshotIteratorTest.java b/modules/accumulo/src/test/java/org/apache/fluo/accumulo/iterators/SnapshotIteratorTest.java
index 4e0c27d..417fd81 100644
--- a/modules/accumulo/src/test/java/org/apache/fluo/accumulo/iterators/SnapshotIteratorTest.java
+++ b/modules/accumulo/src/test/java/org/apache/fluo/accumulo/iterators/SnapshotIteratorTest.java
@@ -123,7 +123,7 @@ public class SnapshotIteratorTest {
     checkInput(input, expected, 23);
 
 
-    // test case where there is newer lock thats not invalidated by DEL_LOCK
+    // test case where there is newer lock that's not invalidated by DEL_LOCK
     input = new TestData();
     input.add("0 f q DEL_LOCK 18", "0 ABORT");
     input.add("0 f q WRITE 16", "11");
@@ -303,7 +303,7 @@ public class SnapshotIteratorTest {
     for (int i = numToWrite * 3 - 1; i > 3; i -= 3) {
       TestData output = new TestData(newSI(input, i), range);
       TestData expected = new TestData();
-      // snapshot time of commited transaction
+      // snapshot time of committed transaction
       int st = i - 2;
       int val1 = ("" + st).hashCode();
       int val2 = ("" + val1).hashCode();
diff --git a/modules/api/src/main/java/org/apache/fluo/api/client/AbstractSnapshotBase.java b/modules/api/src/main/java/org/apache/fluo/api/client/AbstractSnapshotBase.java
index 8c0fa4c..53cd458 100644
--- a/modules/api/src/main/java/org/apache/fluo/api/client/AbstractSnapshotBase.java
+++ b/modules/api/src/main/java/org/apache/fluo/api/client/AbstractSnapshotBase.java
@@ -39,7 +39,7 @@ public abstract class AbstractSnapshotBase implements SnapshotBase {
 
   /*
    * This map of String to Bytes is really only useful when user code is executing a transactions.
-   * Once a transaction is queued for commit, do not want this map to eat up memory. Thats why a
+   * Once a transaction is queued for commit, do not want this map to eat up memory. That's why a
    * weak map is used.
    * 
    * There is intentionally no reverse map from Bytes to String. Relying on two things for this.
diff --git a/modules/api/src/main/java/org/apache/fluo/api/client/LoaderExecutor.java b/modules/api/src/main/java/org/apache/fluo/api/client/LoaderExecutor.java
index a593d46..6868d92 100644
--- a/modules/api/src/main/java/org/apache/fluo/api/client/LoaderExecutor.java
+++ b/modules/api/src/main/java/org/apache/fluo/api/client/LoaderExecutor.java
@@ -30,7 +30,7 @@ public interface LoaderExecutor extends AutoCloseable {
   void execute(Loader loader);
 
   /**
-   * Same as {@link #execute(Loader)}, but allows specifing an identity. The identity is used in
+   * Same as {@link #execute(Loader)}, but allows specifying an identity. The identity is used in
    * metrics and trace logging. When an identity is not supplied, the class name is used. In the
    * case of lambdas the class name may not be the same in different processes.
    * 
diff --git a/modules/api/src/main/java/org/apache/fluo/api/client/scanner/ScannerBuilder.java b/modules/api/src/main/java/org/apache/fluo/api/client/scanner/ScannerBuilder.java
index 201385a..ec7103b 100644
--- a/modules/api/src/main/java/org/apache/fluo/api/client/scanner/ScannerBuilder.java
+++ b/modules/api/src/main/java/org/apache/fluo/api/client/scanner/ScannerBuilder.java
@@ -103,7 +103,7 @@ public interface ScannerBuilder {
    *
    * @see org.apache.fluo.api.data.Span#prefix(Bytes, Column)
    * @param row restrict the scanner to data in an exact row.
-   * @param colPrefix restrict scanner to data that begins with specifiec
+   * @param colPrefix restrict scanner to data that begins with a specific
    *        {@link org.apache.fluo.api.data.Column} prefix.
    * @return self
    * @since 1.2.0
@@ -116,7 +116,7 @@ public interface ScannerBuilder {
    *
    * @see org.apache.fluo.api.data.Span#prefix(CharSequence, Column)
    * @param row restrict the scanner to data in an exact row.
-   * @param colPrefix restrict scanner to data that begins with specifiec
+   * @param colPrefix restrict scanner to data that begins with a specific
    *        {@link org.apache.fluo.api.data.Column} prefix.
    * @return self
    * @since 1.2.0
diff --git a/modules/api/src/main/java/org/apache/fluo/api/config/FluoConfiguration.java b/modules/api/src/main/java/org/apache/fluo/api/config/FluoConfiguration.java
index cf416c0..f50b56f 100644
--- a/modules/api/src/main/java/org/apache/fluo/api/config/FluoConfiguration.java
+++ b/modules/api/src/main/java/org/apache/fluo/api/config/FluoConfiguration.java
@@ -797,7 +797,7 @@ public class FluoConfiguration extends SimpleConfiguration {
   }
 
   /**
-   * Adds an {@link ObserverSpecification} to the configuration using a unique integer prefix thats
+   * Adds an {@link ObserverSpecification} to the configuration using a unique integer prefix that's
    * not currently in use.
    *
    * @deprecated since 1.1.0. Replaced by {@link #setObserverProvider(String)} and
diff --git a/modules/api/src/main/java/org/apache/fluo/api/config/ObserverSpecification.java b/modules/api/src/main/java/org/apache/fluo/api/config/ObserverSpecification.java
index 9ebb47b..cbda037 100644
--- a/modules/api/src/main/java/org/apache/fluo/api/config/ObserverSpecification.java
+++ b/modules/api/src/main/java/org/apache/fluo/api/config/ObserverSpecification.java
@@ -45,8 +45,8 @@ public class ObserverSpecification {
 
   /**
    * @param className The name of a class that implements {@link Observer}
-   * @param observerConfig Per observer configuration thats specific to this observer. For
-   *        configuration thats the same across multiple observers, consider using
+   * @param observerConfig Per observer configuration that's specific to this observer. For
+   *        configuration that's the same across multiple observers, consider using
    *        {@link FluoConfiguration#getAppConfiguration()}
    */
   public ObserverSpecification(String className, SimpleConfiguration observerConfig) {
@@ -56,8 +56,8 @@ public class ObserverSpecification {
 
   /**
    * @param className The name of a class that implements {@link Observer}
-   * @param observerConfig Per observer configuration thats specific to this observer. For
-   *        configuration thats the same across multiple observers, consider using
+   * @param observerConfig Per observer configuration that's specific to this observer. For
+   *        configuration that's the same across multiple observers, consider using
    *        {@link FluoConfiguration#getAppConfiguration()}
    */
   public ObserverSpecification(String className, Map<String, String> observerConfig) {
diff --git a/modules/api/src/main/java/org/apache/fluo/api/data/Bytes.java b/modules/api/src/main/java/org/apache/fluo/api/data/Bytes.java
index dca8b08..8ae590c 100644
--- a/modules/api/src/main/java/org/apache/fluo/api/data/Bytes.java
+++ b/modules/api/src/main/java/org/apache/fluo/api/data/Bytes.java
@@ -161,14 +161,14 @@ public final class Bytes implements Comparable<Bytes>, Serializable {
   }
 
   /**
-   * @return A read only byte buffer thats backed by the internal byte array.
+   * @return A read only byte buffer that's backed by the internal byte array.
    */
   public ByteBuffer toByteBuffer() {
     return ByteBuffer.wrap(data, offset, length).asReadOnlyBuffer();
   }
 
   /**
-   * @return An input stream thats backed by the internal byte array
+   * @return An input stream that's backed by the internal byte array
    */
   public InputStream toInputStream() {
     return new ByteArrayInputStream(data, offset, length);
diff --git a/modules/api/src/test/resources/fluo.properties b/modules/api/src/test/resources/fluo.properties
index 4b86285..4f408ab 100644
--- a/modules/api/src/test/resources/fluo.properties
+++ b/modules/api/src/test/resources/fluo.properties
@@ -52,7 +52,7 @@ fluo.admin.accumulo.table=table9
 # HDFS root path. Should match 'fs.defaultFS' property in Hadoop's core-site.xml
 fluo.admin.hdfs.root=hdfs://localhost:10000
 # Fluo uses iterators within Accumulo tablet servers, therefore Accumulo per
-# table classpath need to be configured with a comma seperated list of uris
+# table classpath need to be configured with a comma separated list of uris
 # where Accumulo can find Fluo jars.  These jars should be reachable from
 # every tablet server.  For the default jars below, `fluo init` will place them
 # in HDFS.  If you add more jars to the classpath below, you will need to
diff --git a/modules/core/src/main/java/org/apache/fluo/core/client/LoaderExecutorAsyncImpl.java b/modules/core/src/main/java/org/apache/fluo/core/client/LoaderExecutorAsyncImpl.java
index 5f644e8..c7117da 100644
--- a/modules/core/src/main/java/org/apache/fluo/core/client/LoaderExecutorAsyncImpl.java
+++ b/modules/core/src/main/java/org/apache/fluo/core/client/LoaderExecutorAsyncImpl.java
@@ -68,7 +68,7 @@ public class LoaderExecutorAsyncImpl implements LoaderExecutor {
         commiting.decrement();
       } else {
         // its only expected that this should be called once.. if its called multiple times in
-        // indicates an error in asyn code
+        // indicates an error in async code
         LoggerFactory.getLogger(LoaderCommitObserver.class).error("Close called twice ",
             new Exception());
       }
diff --git a/modules/core/src/main/java/org/apache/fluo/core/impl/FluoConfigurationImpl.java b/modules/core/src/main/java/org/apache/fluo/core/impl/FluoConfigurationImpl.java
index 3c2f5df..dba18ae 100644
--- a/modules/core/src/main/java/org/apache/fluo/core/impl/FluoConfigurationImpl.java
+++ b/modules/core/src/main/java/org/apache/fluo/core/impl/FluoConfigurationImpl.java
@@ -194,7 +194,7 @@ public class FluoConfigurationImpl {
    * {@value #TRANSACTOR_MAX_CACHE_SIZE} if set, the default
    * {@value #TRANSACTOR_CACHE_TIMEOUT_DEFAULT} otherwise
    *
-   * @param conf The FluoConfiguartion
+   * @param conf The FluoConfiguration
    * @return The maximum number of entries permitted in this cache
    */
 
diff --git a/modules/core/src/main/java/org/apache/fluo/core/util/ScanUtil.java b/modules/core/src/main/java/org/apache/fluo/core/util/ScanUtil.java
index a6c8e68..aa12c16 100644
--- a/modules/core/src/main/java/org/apache/fluo/core/util/ScanUtil.java
+++ b/modules/core/src/main/java/org/apache/fluo/core/util/ScanUtil.java
@@ -240,9 +240,9 @@ public class ScanUtil {
     HELP,
     // hex encode node ascii
     HEX,
-    // scan accumuo table directly
+    // scan accumulo table directly
     ACCUMULO,
-    // endode output as json
+    // encode output as json
     JSON,
     // scan notification
     NTFY
diff --git a/modules/distribution/src/main/config/fluo-app.properties b/modules/distribution/src/main/config/fluo-app.properties
index bdddd5e..88ffa74 100644
--- a/modules/distribution/src/main/config/fluo-app.properties
+++ b/modules/distribution/src/main/config/fluo-app.properties
@@ -30,7 +30,7 @@
 ## If this property is set, fluo.observer.jars.url should not be set.
 #fluo.observer.init.dir=/path/to/observer/jars/
 
-## Observer jars are retreived from this URL. If set, fluo.observer.init.dir should not be set.
+## Observer jars are retrieved from this URL. If set, fluo.observer.init.dir should not be set.
 #fluo.observer.jars.url=hdfs://localhost:8020/path/to/observer/jars/
 
 ## Properties with a prefix of fluo.app.* can easily be retrieved by a Fluo
diff --git a/modules/distribution/src/main/config/fluo-env.sh b/modules/distribution/src/main/config/fluo-env.sh
index 78acbb1..2d72d44 100755
--- a/modules/distribution/src/main/config/fluo-env.sh
+++ b/modules/distribution/src/main/config/fluo-env.sh
@@ -69,7 +69,7 @@ addToClasspath()
 }
 
 
-# This function attemps to obtain Accumulo, Hadoop, and Zookeeper jars from the
+# This function attempts to obtain Accumulo, Hadoop, and Zookeeper jars from the
 # location where those dependencies are installed on the system.
 setupClasspathFromSystem()
 {
diff --git a/modules/integration/src/test/java/org/apache/fluo/integration/impl/FaultyConfig.java b/modules/integration/src/test/java/org/apache/fluo/integration/impl/FaultyConfig.java
index 60f43ca..625323e 100644
--- a/modules/integration/src/test/java/org/apache/fluo/integration/impl/FaultyConfig.java
+++ b/modules/integration/src/test/java/org/apache/fluo/integration/impl/FaultyConfig.java
@@ -33,7 +33,7 @@ public class FaultyConfig extends Environment {
    * not have been written.
    *
    * <p>
-   * The following code was copied from Accumulo in order to avoid depedning on accumulo test
+   * The following code was copied from Accumulo in order to avoid depending on accumulo test
    * module.
    */
   private static class FaultyConditionalWriter implements ConditionalWriter {
diff --git a/modules/integration/src/test/java/org/apache/fluo/integration/impl/ReadLockIT.java b/modules/integration/src/test/java/org/apache/fluo/integration/impl/ReadLockIT.java
index b88d66e..00d01af 100644
--- a/modules/integration/src/test/java/org/apache/fluo/integration/impl/ReadLockIT.java
+++ b/modules/integration/src/test/java/org/apache/fluo/integration/impl/ReadLockIT.java
@@ -273,7 +273,7 @@ public class ReadLockIT extends ITBaseImpl {
         try {
           addEdge(tx, enodes[0], enodes[1]);
         } catch (NullPointerException e) {
-          // TOOD remove after finding bug
+          // TODO remove after finding bug
           System.out.println(
               " en0 " + enodes[0] + " en1 " + enodes[1] + " start ts " + tx.getStartTimestamp());
           dumpRow("r:" + enodes[0], System.out::println);