You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by pi...@apache.org on 2018/04/25 16:13:22 UTC

[geode] branch develop updated: GEODE-5118: Fix common typos in string literals and comments. (#1833)

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

pivotalsarge pushed a commit to branch develop
in repository https://gitbox.apache.org/repos/asf/geode.git


The following commit(s) were added to refs/heads/develop by this push:
     new de8e243  GEODE-5118: Fix common typos in string literals and comments. (#1833)
de8e243 is described below

commit de8e24319783e4207f0986eabc4d9f564b165af7
Author: Michael "Sarge" Dodge <md...@pivotal.io>
AuthorDate: Wed Apr 25 09:13:14 2018 -0700

    GEODE-5118: Fix common typos in string literals and comments. (#1833)
---
 .../internal/web/controllers/RestAPITestBase.java  |   2 +-
 .../apache/geode/admin/jmx/internal/MBeanUtil.java |   2 +-
 .../cache/client/internal/ExecuteFunctionOp.java   |   4 +-
 .../apache/geode/cache/query/SelectResults.java    |   2 +-
 .../org/apache/geode/cache/query/internal/Bag.java |  12 +-
 .../query/internal/CompiledIndexOperation.java     |   2 +-
 .../geode/cache/query/internal/CompiledSelect.java |  72 +++----
 .../cache/query/internal/ExecutionContext.java     |   2 +-
 .../geode/cache/query/internal/MapIndexable.java   |   2 +-
 .../geode/cache/query/internal/QCompiler.java      |   2 +-
 .../geode/cache/query/internal/ResultsBag.java     |  16 +-
 .../query/internal/ResultsCollectionWrapper.java   |   2 +-
 .../cache/query/internal/SortedStructBag.java      |   4 +-
 .../geode/cache/query/internal/StructBag.java      |   4 +-
 .../query/internal/aggregate/CountPRQueryNode.java |   2 +-
 .../query/internal/index/AbstractMapIndex.java     |   2 +-
 .../query/internal/index/CompactRangeIndex.java    |   2 +-
 .../index/FunctionalIndexCreationHelper.java       |   4 +-
 .../cache/query/internal/index/HashIndex.java      |   2 +-
 .../cache/query/internal/index/IndexData.java      |   2 +-
 .../query/internal/index/MemoryIndexStore.java     |   2 +-
 .../geode/distributed/ConfigurationProperties.java |  12 +-
 .../distributed/internal/DistributionConfig.java   |   2 +-
 .../internal/deadlock/DependencyGraph.java         |   8 +-
 .../geode/internal/DataSerializableFixedID.java    |   2 +-
 .../geode/internal/InternalInstantiator.java       |   4 +-
 .../geode/internal/admin/CacheCollector.java       |   2 +-
 .../internal/cache/InitialImageOperation.java      |  12 +-
 .../geode/internal/cache/PartitionedRegion.java    |  16 +-
 .../cache/PartitionedRegionQueryEvaluator.java     |  10 +-
 .../apache/geode/internal/cache/RegionEntry.java   |   6 +-
 .../apache/geode/internal/cache/TXManagerImpl.java |   2 +-
 .../internal/cache/backup/BackupFileCopier.java    |   8 +-
 .../DistributedRegionFunctionResultSender.java     |  14 +-
 .../execute/FunctionStreamingResultCollector.java  |  10 +-
 .../cache/execute/LocalResultCollectorImpl.java    |  14 +-
 .../cache/execute/MemberFunctionExecutor.java      |   4 +-
 .../cache/execute/MemberFunctionResultSender.java  |  22 +-
 .../PartitionedRegionFunctionResultSender.java     |  22 +-
 .../PartitionedRegionFunctionResultWaiter.java     |   6 +-
 .../cache/execute/StreamingFunctionOperation.java  |   6 +-
 .../geode/internal/cache/ha/HARegionQueue.java     |  22 +-
 .../cache/partitioned/BucketBackupMessage.java     |   2 +-
 .../internal/cache/partitioned/FlushMessage.java   |   2 +-
 .../cache/partitioned/IndexCreationMsg.java        |   2 +-
 .../PRFunctionStreamingResultCollector.java        |   4 +-
 .../internal/cache/partitioned/RegionAdvisor.java  |   2 +-
 .../cache/partitioned/RemoveIndexesMessage.java    |   2 +-
 .../cache/tier/sockets/CacheClientNotifier.java    |   6 +-
 .../cache/tier/sockets/ClientHealthMonitor.java    |   2 +-
 .../cache/tier/sockets/command/GetAllForRI.java    |   2 +-
 .../tier/sockets/command/UnregisterInterest.java   |   2 +-
 .../wan/AbstractGatewaySenderEventProcessor.java   |   2 +-
 .../internal/datasource/AbstractPoolCache.java     |   6 +-
 .../geode/internal/i18n/LocalizedStrings.java      |   8 +-
 .../geode/internal/jta/TransactionManagerImpl.java |   4 +-
 .../geode/management/internal/cli/GfshParser.java  |   2 +-
 .../internal/cli/util/ExportLogsCacheWriter.java   |   2 +-
 .../geode/redis/internal/RedisConstants.java       |   2 +-
 .../java/com/main/MyDistributedSystemListener.java |   2 +-
 .../java/com/main/WANBootStrapping_Site2_Add.java  |   2 +-
 .../dunit/QueryUsingFunctionContextDUnitTest.java  |   6 +-
 .../query/internal/NWayMergeResultsJUnitTest.java  |   4 +-
 .../ResultsBagLimitBehaviourJUnitTest.java         |  38 ++--
 .../ResultsCollectionWrapperLimitJUnitTest.java    |   2 +-
 .../index/AsynchIndexMaintenanceJUnitTest.java     |   2 +-
 ...ncurrentIndexInitOnOverflowRegionDUnitTest.java |   2 +-
 .../query/partitioned/PRQueryDUnitHelper.java      |   2 +-
 .../apache/geode/cache30/CacheMapTxnDUnitTest.java |   2 +-
 ...entServerInvalidAndDestroyedEntryDUnitTest.java |  12 +-
 .../internal/cache/DeltaPropagationDUnitTest.java  |   2 +-
 .../cache/DeltaPropagationStatsDUnitTest.java      |   2 +-
 .../cache/DiskRegCachexmlGeneratorJUnitTest.java   |   2 +-
 .../internal/cache/DiskRegRecoveryJUnitTest.java   |   2 +-
 .../geode/internal/cache/FaultingInJUnitTest.java  |   2 +-
 .../geode/internal/cache/OplogJUnitTest.java       |   2 +-
 ...itionedRegionSingleNodeOperationsJUnitTest.java |   2 +-
 .../backup/BackupFileCopierIntegrationTest.java    |   2 +-
 .../cache/ha/BlockingHARegionJUnitTest.java        |   2 +-
 .../cache/ha/EventIdOptimizationDUnitTest.java     |   4 +-
 .../cache/ha/HAEventIdPropagationDUnitTest.java    |   4 +-
 .../geode/internal/cache/ha/HARegionDUnitTest.java |   6 +-
 .../internal/cache/ha/HARegionQueueDUnitTest.java  |   4 +-
 .../internal/cache/ha/HASlowReceiverDUnitTest.java |   2 +-
 .../cache/ha/OperationsPropagationDUnitTest.java   |   2 +-
 .../geode/internal/cache/ha/PutAllDUnitTest.java   |   4 +-
 .../cache/ha/TestBlockingHARegionQueue.java        |   2 +-
 .../PersistentPartitionedRegionDUnitTest.java      |  10 +-
 .../cache/tier/sockets/Bug36269DUnitTest.java      |   2 +-
 .../cache/tier/sockets/Bug36805DUnitTest.java      |   2 +-
 .../sockets/InterestListEndpointDUnitTest.java     |   2 +-
 .../sockets/RedundancyLevelPart3DUnitTest.java     |   4 +-
 .../cache/PRDeltaPropagationDUnitTest.java         |   2 +-
 .../cache/tier/sockets/DurableClientTestCase.java  |   2 +-
 .../dunit/standalone/VersionManagerJUnitTest.java  |   4 +-
 geode-pulse/src/main/webapp/clusterDetail.html     |   6 +-
 geode-pulse/src/main/webapp/css/popup.css          |   2 +-
 geode-pulse/src/main/webapp/css/style.css          |  12 +-
 geode-pulse/src/main/webapp/dataBrowser.html       |   6 +-
 geode-pulse/src/main/webapp/memberDetails.html     |   6 +-
 geode-pulse/src/main/webapp/queryStatistics.html   |   6 +-
 geode-pulse/src/main/webapp/regionDetail.html      |   6 +-
 .../src/main/webapp/scripts/lib/jquery-1.7.2.js    |   2 +-
 .../main/webapp/scripts/lib/jquery.jqGrid.src.js   | 226 ++++++++++-----------
 .../main/webapp/scripts/lib/jquery.sparkline.js    |   2 +-
 .../cache/wan/GatewayReceiverImplJUnitTest.java    |   4 +-
 .../web/controllers/PdxBasedCrudController.java    |   2 +-
 107 files changed, 414 insertions(+), 414 deletions(-)

diff --git a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPITestBase.java b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPITestBase.java
index 1558ad9..1251455 100644
--- a/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPITestBase.java
+++ b/geode-assembly/src/test/java/org/apache/geode/rest/internal/web/controllers/RestAPITestBase.java
@@ -89,7 +89,7 @@ class RestAPITestBase extends JUnit4DistributedTestCase {
   private void postSetUpRestAPITestBase() throws Exception {}
 
   /**
-   * close the clients and teh servers
+   * close the clients and the servers
    */
   @Override
   public final void preTearDown() throws Exception {
diff --git a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MBeanUtil.java b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MBeanUtil.java
index e991c6e..30b0d90 100755
--- a/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MBeanUtil.java
+++ b/geode-core/src/main/java/org/apache/geode/admin/jmx/internal/MBeanUtil.java
@@ -371,7 +371,7 @@ public class MBeanUtil {
         timerNotificationId = refreshTimer.addNotification(type.getType(), // type
             type.getMessage(), // message = "refresh"
             userData, // userData
-            new Date(System.currentTimeMillis() + refreshInterval * 1000), // first occurence
+            new Date(System.currentTimeMillis() + refreshInterval * 1000), // first occurrence
             refreshInterval * 1000); // period to repeat
 
         // put an entry into the map for the listener...
diff --git a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteFunctionOp.java b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteFunctionOp.java
index 415752e..2cd5b76 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteFunctionOp.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/client/internal/ExecuteFunctionOp.java
@@ -260,7 +260,7 @@ public class ExecuteFunctionOp {
       } catch (InternalFunctionInvocationTargetException e) {
         if (isDebugEnabled) {
           logger.debug(
-              "ExecuteFunctionOp#reexecute : Recieved InternalFunctionInvocationTargetException. The failed nodes are {}",
+              "ExecuteFunctionOp#reexecute : Received InternalFunctionInvocationTargetException. The failed nodes are {}",
               e.getFailedNodeSet());
         }
         reexecute = true;
@@ -309,7 +309,7 @@ public class ExecuteFunctionOp {
       } catch (InternalFunctionInvocationTargetException e) {
         if (isDebugEnabled) {
           logger.debug(
-              "ExecuteFunctionOp#reexecute : Recieved InternalFunctionInvocationTargetException. The failed nodes are {}",
+              "ExecuteFunctionOp#reexecute : Received InternalFunctionInvocationTargetException. The failed nodes are {}",
               e.getFailedNodeSet());
         }
         reexecute = true;
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/SelectResults.java b/geode-core/src/main/java/org/apache/geode/cache/query/SelectResults.java
index 71368f8..7c59708 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/SelectResults.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/SelectResults.java
@@ -80,7 +80,7 @@ public interface SelectResults<E> extends Collection<E> {
    * <code>element</code> is not present in this collection, then 0 is returned.
    *
    * @param element the element
-   * @return the number of occurrances of element
+   * @return the number of occurrences of element
    * @since GemFire 5.1
    */
   int occurrences(E element);
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/Bag.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/Bag.java
index ac39288..9ef2999 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/Bag.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/Bag.java
@@ -232,18 +232,18 @@ public abstract class Bag<E> extends AbstractCollection<E> implements CqResults<
   // gets an Object [] indicating field values as parameter
   // from the CompiledSelect
   public int addAndGetOccurence(Object element) {
-    int occurence;
+    int occurrence;
     if (element == null) {
       numNulls++;
-      occurence = numNulls;
+      occurrence = numNulls;
     } else {
-      occurence = this.mapGet(element); // 0 if not
-                                        // found
-      this.mapPut(element, ++occurence);
+      occurrence = this.mapGet(element); // 0 if not
+                                         // found
+      this.mapPut(element, ++occurrence);
     }
     this.size++;
     assert this.size >= 0 : this.size;
-    return occurence;
+    return occurrence;
   }
 
   @Override
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledIndexOperation.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledIndexOperation.java
index 97c8b25..0a066d0 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledIndexOperation.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledIndexOperation.java
@@ -165,7 +165,7 @@ public class CompiledIndexOperation extends AbstractCompiledValue implements Map
   }
 
 
-  public CompiledValue getRecieverSansIndexArgs() {
+  public CompiledValue getReceiverSansIndexArgs() {
     return this.receiver;
   }
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledSelect.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledSelect.java
index 195476c..b1538cc 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledSelect.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/CompiledSelect.java
@@ -884,8 +884,8 @@ public class CompiledSelect extends AbstractCompiledValue {
           for (int i = 0; i < values.length; i++) {
             ((RuntimeIterator) iterators.get(i)).setCurrent(values[i]);
           }
-          int occurence = applyProjectionAndAddToResultSet(context, pResultSet, ignoreOrderBy);
-          if (occurence == 1 || (occurence > 1 && !this.distinct)) {
+          int occurrence = applyProjectionAndAddToResultSet(context, pResultSet, ignoreOrderBy);
+          if (occurrence == 1 || (occurrence > 1 && !this.distinct)) {
             // (Unique i.e first time occurrence) or subsequent occurrence
             // for non distinct query
             ++numElementsAdded;
@@ -1129,22 +1129,22 @@ public class CompiledSelect extends AbstractCompiledValue {
   // could be a distinct subquery)
   // in future, it would be good to simplify this to always work with a bag
   // (converting all sets to bags) until the end when we enforce distinct
-  // The number returned indicates the occurence of the data in the SelectResults
+  // The number returned indicates the occurrence of the data in the SelectResults
   // Thus if the SelectResults is of type ResultsSet or StructSet
   // then 1 will indicate that data was added to the results & that was the
-  // first occurence. For this 0 will indicate that the data was not added
+  // first occurrence. For this 0 will indicate that the data was not added
   // because it was a duplicate
   // If the SelectResults is an instance ResultsBag or StructsBag , the number will
-  // indicate the occurence. Thus 1 will indicate it being added for first time
+  // indicate the occurrence. Thus 1 will indicate it being added for first time
   // Currently orderBy is present only for StructSet & ResultSet which are
-  // unique object holders. So the occurence for them can be either 0 or 1 only
+  // unique object holders. So the occurrence for them can be either 0 or 1 only
 
   private int applyProjectionAndAddToResultSet(ExecutionContext context, SelectResults resultSet,
       boolean ignoreOrderBy) throws FunctionDomainException, TypeMismatchException,
       NameResolutionException, QueryInvocationTargetException {
     List currrentRuntimeIters = context.getCurrentIterators();
 
-    int occurence = 0;
+    int occurrence = 0;
     ObjectType elementType = resultSet.getCollectionType().getElementType();
     boolean isStruct = elementType != null && elementType.isStructType();
 
@@ -1193,7 +1193,7 @@ public class CompiledSelect extends AbstractCompiledValue {
         // until
         // the end of evaluate call to this CompiledSelect object.
         this.countStartQueryResult++;
-        occurence = 1;
+        occurrence = 1;
       } else {
         // if order by is present
         if (applyOrderBy) {
@@ -1203,10 +1203,10 @@ public class CompiledSelect extends AbstractCompiledValue {
               if (values.length == 1 && values[0] instanceof StructImpl) {
                 structImpl = (StructImpl) values[0];
                 comparator.addEvaluatedSortCriteria(structImpl.getFieldValues(), context);
-                occurence = resultSet.add(structImpl) ? 1 : 0;
+                occurrence = resultSet.add(structImpl) ? 1 : 0;
               } else {
                 comparator.addEvaluatedSortCriteria(values, context);
-                occurence = ((StructFields) resultSet).addFieldValues(values) ? 1 : 0;
+                occurrence = ((StructFields) resultSet).addFieldValues(values) ? 1 : 0;
               }
               // TODO:Instead of a normal Map containing which holds
               // StructImpl object
@@ -1215,22 +1215,22 @@ public class CompiledSelect extends AbstractCompiledValue {
               // creating objects of type Object[]
             } else {
               comparator.addEvaluatedSortCriteria(values[0], context);
-              occurence = resultSet.add(values[0]) ? 1 : 0;
+              occurrence = resultSet.add(values[0]) ? 1 : 0;
             }
           } else {
             if (isStruct) {
               if (values.length == 1 && values[0] instanceof StructImpl) {
                 structImpl = (StructImpl) values[0];
                 comparator.addEvaluatedSortCriteria(structImpl.getFieldValues(), context);
-                occurence = ((Bag) resultSet).addAndGetOccurence(structImpl.getFieldValues());
+                occurrence = ((Bag) resultSet).addAndGetOccurence(structImpl.getFieldValues());
               } else {
                 comparator.addEvaluatedSortCriteria(values, context);
-                occurence = ((Bag) resultSet).addAndGetOccurence(values);
+                occurrence = ((Bag) resultSet).addAndGetOccurence(values);
 
               }
             } else {
               comparator.addEvaluatedSortCriteria(values[0], context);
-              occurence = ((Bag) resultSet).addAndGetOccurence(values[0]);
+              occurrence = ((Bag) resultSet).addAndGetOccurence(values[0]);
             }
           }
         } else {
@@ -1243,28 +1243,28 @@ public class CompiledSelect extends AbstractCompiledValue {
                 structImpl = new StructImpl((StructTypeImpl) elementType, values);
               }
               if (this.distinct) {
-                occurence = resultSet.add(structImpl) ? 1 : 0;
+                occurrence = resultSet.add(structImpl) ? 1 : 0;
               } else {
-                occurence = ((Bag) resultSet).addAndGetOccurence(structImpl);
+                occurrence = ((Bag) resultSet).addAndGetOccurence(structImpl);
               }
             } else {
               if (this.distinct) {
-                occurence = resultSet.add(values[0]) ? 1 : 0;
+                occurrence = resultSet.add(values[0]) ? 1 : 0;
               } else {
-                occurence = ((Bag) resultSet).addAndGetOccurence(values[0]);
+                occurrence = ((Bag) resultSet).addAndGetOccurence(values[0]);
               }
 
             }
           } else {
             if (this.distinct) {
               if (isStruct) {
-                occurence = ((StructFields) resultSet).addFieldValues(values) ? 1 : 0;
+                occurrence = ((StructFields) resultSet).addFieldValues(values) ? 1 : 0;
               } else {
-                occurence = resultSet.add(values[0]) ? 1 : 0;
+                occurrence = resultSet.add(values[0]) ? 1 : 0;
               }
             } else {
               if (isStruct) {
-                occurence = ((Bag) resultSet).addAndGetOccurence(values);
+                occurrence = ((Bag) resultSet).addAndGetOccurence(values);
               } else {
                 boolean add = true;
                 if (context.isCqQueryContext()) {
@@ -1284,7 +1284,7 @@ public class CompiledSelect extends AbstractCompiledValue {
                   }
                 }
                 if (add) {
-                  occurence = ((Bag) resultSet).addAndGetOccurence(values[0]);
+                  occurrence = ((Bag) resultSet).addAndGetOccurence(values[0]);
                 }
               }
             }
@@ -1318,22 +1318,22 @@ public class CompiledSelect extends AbstractCompiledValue {
         if (distinct) {
           if (isStruct) {
             comparator.addEvaluatedSortCriteria(values, context);
-            // Occurence field is used to identify the corrcet number of
+            // Occurrence field is used to identify the corrcet number of
             // iterations
             // required to implement the limit based on the presence or absence
             // of distinct clause
-            occurence = ((StructFields) resultSet).addFieldValues(values) ? 1 : 0;
+            occurrence = ((StructFields) resultSet).addFieldValues(values) ? 1 : 0;
           } else {
             comparator.addEvaluatedSortCriteria(values[0], context);
-            occurence = resultSet.add(values[0]) ? 1 : 0;
+            occurrence = resultSet.add(values[0]) ? 1 : 0;
           }
         } else {
           if (isStruct) {
             comparator.addEvaluatedSortCriteria(values, context);
-            occurence = ((Bag) resultSet).addAndGetOccurence(values);
+            occurrence = ((Bag) resultSet).addAndGetOccurence(values);
           } else {
             comparator.addEvaluatedSortCriteria(values[0], context);
-            occurence = ((Bag) resultSet).addAndGetOccurence(values[0]);
+            occurrence = ((Bag) resultSet).addAndGetOccurence(values[0]);
           }
         }
       } else {
@@ -1341,36 +1341,36 @@ public class CompiledSelect extends AbstractCompiledValue {
           if (isStruct) {
             StructImpl structImpl = new StructImpl((StructTypeImpl) elementType, values);
             if (this.distinct) {
-              occurence = resultSet.add(structImpl) ? 1 : 0;
+              occurrence = resultSet.add(structImpl) ? 1 : 0;
             } else {
-              occurence = ((Bag) resultSet).addAndGetOccurence(structImpl);
+              occurrence = ((Bag) resultSet).addAndGetOccurence(structImpl);
             }
 
           } else {
             if (this.distinct) {
-              occurence = resultSet.add(values[0]) ? 1 : 0;
+              occurrence = resultSet.add(values[0]) ? 1 : 0;
             } else {
-              occurence = ((Bag) resultSet).addAndGetOccurence(values[0]);
+              occurrence = ((Bag) resultSet).addAndGetOccurence(values[0]);
             }
           }
         } else {
           if (this.distinct) {
             if (isStruct) {
-              occurence = ((StructFields) resultSet).addFieldValues(values) ? 1 : 0;
+              occurrence = ((StructFields) resultSet).addFieldValues(values) ? 1 : 0;
             } else {
-              occurence = resultSet.add(values[0]) ? 1 : 0;
+              occurrence = resultSet.add(values[0]) ? 1 : 0;
             }
           } else {
             if (isStruct) {
-              occurence = ((Bag) resultSet).addAndGetOccurence(values);
+              occurrence = ((Bag) resultSet).addAndGetOccurence(values);
             } else {
-              occurence = ((Bag) resultSet).addAndGetOccurence(values[0]);
+              occurrence = ((Bag) resultSet).addAndGetOccurence(values[0]);
             }
           }
         }
       }
     }
-    return occurence;
+    return occurrence;
   }
 
   private String generateProjectionName(CompiledValue projExpr, ExecutionContext context) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/ExecutionContext.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/ExecutionContext.java
index 717d78a..a821fb4 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/ExecutionContext.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/ExecutionContext.java
@@ -260,7 +260,7 @@ public class ExecutionContext {
    * Independent Iterator which is passed as a parameter to the function. For correct usage it is
    * necessary that the RuntimeIterator passed is independent. If there are no dependent Iterators
    * then the list will just contain one element which will be the RuntimeIterator passed as
-   * argument . Also the self independent Runtime Iterator present in the scope ( that is teh
+   * argument . Also the self independent Runtime Iterator present in the scope ( that is the
    * RuntimeIterator same as the independent iterator passed as argument) is added at start of the
    * list. If an iterator is dependent on more than one independent iterator, it is not added to the
    * List
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/MapIndexable.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/MapIndexable.java
index 2685963..0e6a63f 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/MapIndexable.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/MapIndexable.java
@@ -19,7 +19,7 @@ import java.util.List;
 public interface MapIndexable {
   CompiledValue getMapLookupKey();
 
-  CompiledValue getRecieverSansIndexArgs();
+  CompiledValue getReceiverSansIndexArgs();
 
   List<CompiledValue> getIndexingKeys();
 }
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/QCompiler.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/QCompiler.java
index 8546b2d..05e7d49 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/QCompiler.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/QCompiler.java
@@ -710,7 +710,7 @@ public class QCompiler implements OQLLexerTokenTypes {
       this.indexList = indexList;
     }
 
-    public CompiledValue getRecieverSansIndexArgs() {
+    public CompiledValue getReceiverSansIndexArgs() {
       return rcvr;
     }
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsBag.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsBag.java
index 3443ea8..2baa5ae 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsBag.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsBag.java
@@ -146,9 +146,9 @@ public class ResultsBag extends Bag implements DataSerializableFixedID {
 
     while (numLeft > 0) {
       Object key = DataSerializer.readObject(in);
-      int occurence = in.readInt();
-      this.map.put(key, occurence);
-      numLeft -= occurence;
+      int occurrence = in.readInt();
+      this.map.put(key, occurrence);
+      numLeft -= occurrence;
     }
   }
 
@@ -169,12 +169,12 @@ public class ResultsBag extends Bag implements DataSerializableFixedID {
       Entry entry = itr.next();
       Object key = entry.getKey();
       DataSerializer.writeObject(key, out);
-      int occurence = entry.getValue();
-      if (numLeft < occurence) {
-        occurence = numLeft;
+      int occurrence = entry.getValue();
+      if (numLeft < occurrence) {
+        occurrence = numLeft;
       }
-      out.writeInt(occurence);
-      numLeft -= occurence;
+      out.writeInt(occurrence);
+      numLeft -= occurrence;
     }
   }
 
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsCollectionWrapper.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsCollectionWrapper.java
index da470a5..9ced3ae 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsCollectionWrapper.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/ResultsCollectionWrapper.java
@@ -479,7 +479,7 @@ public class ResultsCollectionWrapper implements SelectResults, DataSerializable
 
   // Asif : If the underlying collection is a ordered
   // one then it will allow duplicates. In such case , our
-  // limit iterator will correctly give the number of occurences
+  // limit iterator will correctly give the number of occurrences
   // but if the underlying collection is not ordered , it will
   // not allow duplicates, but then since we have already truncated
   // the unordered set, it will work correctly.
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/SortedStructBag.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/SortedStructBag.java
index 0096839..fd920e6 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/SortedStructBag.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/SortedStructBag.java
@@ -150,7 +150,7 @@ public class SortedStructBag extends SortedResultsBag<Object[]> implements Struc
           count++;
           encounteredObject = true;
         } else if (encounteredObject) {
-          // Asif: No possibility of its occurence again
+          // Asif: No possibility of its occurrence again
           break;
         }
       }
@@ -273,7 +273,7 @@ public class SortedStructBag extends SortedResultsBag<Object[]> implements Struc
 
   /**
    * Return an iterator over the elements in this collection. Duplicates will show up the number of
-   * times it has occurrances.
+   * times it has occurrences.
    */
   @Override
   public Iterator iterator() {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/StructBag.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/StructBag.java
index 4e6ce24..da6b67b 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/StructBag.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/StructBag.java
@@ -249,7 +249,7 @@ public class StructBag extends ResultsBag implements StructFields {
           count++;
           encounteredObject = true;
         } else if (encounteredObject) {
-          // Asif: No possibility of its occurence again
+          // Asif: No possibility of its occurrence again
           break;
         }
       }
@@ -381,7 +381,7 @@ public class StructBag extends ResultsBag implements StructFields {
 
   /**
    * Return an iterator over the elements in this collection. Duplicates will show up the number of
-   * times it has occurrances.
+   * times it has occurrences.
    */
   @Override
   public Iterator iterator() {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/CountPRQueryNode.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/CountPRQueryNode.java
index a3fbead..73aa4f6 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/CountPRQueryNode.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/aggregate/CountPRQueryNode.java
@@ -25,7 +25,7 @@ public class CountPRQueryNode implements Aggregator {
   private int count = 0;
 
   /**
-   * Recieves the input of the individual counts from the bucket nodes.
+   * Receives the input of the individual counts from the bucket nodes.
    */
   @Override
   public void accumulate(Object value) {
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/AbstractMapIndex.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/AbstractMapIndex.java
index 40e1681..cbb49c9 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/AbstractMapIndex.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/AbstractMapIndex.java
@@ -375,7 +375,7 @@ public abstract class AbstractMapIndex extends AbstractIndex {
       // stripped of the index arg & see if it matches.
       if (condnExpr instanceof MapIndexable) {
         MapIndexable mi = (MapIndexable) condnExpr;
-        CompiledValue recvr = mi.getRecieverSansIndexArgs();
+        CompiledValue recvr = mi.getReceiverSansIndexArgs();
         StringBuilder sb = new StringBuilder();
         recvr.generateCanonicalizedExpression(sb, context);
         sb.append('[').append(']');
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/CompactRangeIndex.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/CompactRangeIndex.java
index 2c8c935..9a4e3a9 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/CompactRangeIndex.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/CompactRangeIndex.java
@@ -1436,7 +1436,7 @@ public class CompactRangeIndex extends AbstractIndex {
      * can be used to obtain the underlying RegionEntry object. If the boolean is true & additional
      * projection attribute is not null, then the Region.Entry object can be obtained by evaluating
      * the additional projection attribute. If the boolean isFirstItrOnEntry is tru e& additional
-     * projection attribute is null, then teh 0th iterator itself will evaluate to Region.Entry
+     * projection attribute is null, then the 0th iterator itself will evaluate to Region.Entry
      * Object.
      *
      * The 2nd element of Object Array contains the Struct object ( tuple) created. If the boolean
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/FunctionalIndexCreationHelper.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/FunctionalIndexCreationHelper.java
index 3f2133c..306399a 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/FunctionalIndexCreationHelper.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/FunctionalIndexCreationHelper.java
@@ -466,7 +466,7 @@ class FunctionalIndexCreationHelper extends IndexCreationHelper {
           this.isMapTypeIndex = true;
           this.isAllKeys = true;
           // Strip the index operator
-          expr = mi.getRecieverSansIndexArgs();
+          expr = mi.getReceiverSansIndexArgs();
           expr.generateCanonicalizedExpression(sb, this.context);
           sb.append('[').append('*').append(']');
 
@@ -477,7 +477,7 @@ class FunctionalIndexCreationHelper extends IndexCreationHelper {
           this.isMapTypeIndex = true;
           this.multiIndexKeysPattern = new String[indexingKeys.size()];
           this.mapKeys = new Object[indexingKeys.size()];
-          expr = mi.getRecieverSansIndexArgs();
+          expr = mi.getReceiverSansIndexArgs();
           expr.generateCanonicalizedExpression(sb, this.context);
           sb.append('[');
           String prefixStr = sb.toString();
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/HashIndex.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/HashIndex.java
index 0f43a6d..090dfc7 100755
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/HashIndex.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/HashIndex.java
@@ -1144,7 +1144,7 @@ public class HashIndex extends AbstractIndex {
      * can be used to obtain the underlying RegionEntry object. If the boolean is true & additional
      * projection attribute is not null, then the Region.Entry object can be obtained by evaluating
      * the additional projection attribute. If the boolean isFirstItrOnEntry is tru e& additional
-     * projection attribute is null, then teh 0th iterator itself will evaluate to Region.Entry
+     * projection attribute is null, then the 0th iterator itself will evaluate to Region.Entry
      * Object.
      *
      * The 2nd element of Object Array contains the Struct object ( tuple) created. If the boolean
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexData.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexData.java
index f436a3c..751ed79 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexData.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/IndexData.java
@@ -38,7 +38,7 @@ public class IndexData {
   /**
    * An int array of size equal to the number of Iterators present in the Group representing the
    * Iterators for that region. It identifies the index result field position which maps to the
-   * RuntimeIterator for teh Group. The mapping of index result field is 1 based ( not zero). For
+   * RuntimeIterator for the Group. The mapping of index result field is 1 based ( not zero). For
    * example the second Iterator of the group ( 0 indxe based , hence 1 ) will map to the field
    * position in the Index Result given by the value maping[1]. If an iterator has no mapping , the
    * value will be 0. *
diff --git a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/MemoryIndexStore.java b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/MemoryIndexStore.java
index a093517..ee27b23 100644
--- a/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/MemoryIndexStore.java
+++ b/geode-core/src/main/java/org/apache/geode/cache/query/internal/index/MemoryIndexStore.java
@@ -75,7 +75,7 @@ public class MemoryIndexStore implements IndexStore {
 
   // Used as a place holder for an indexkey collection for when a thread is about to change
   // the collection from index elem to concurrent hash set. Solution for #47475 where
-  // we could be missing removes due to different threads grabbing occurences of the same
+  // we could be missing removes due to different threads grabbing occurrences of the same
   // index elem (or collection), one would transition and addAll to a new collection,
   // while the other would execute a remove on the index elem.
   // both would complete but the remove would have been lost because we had already added it to the
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/ConfigurationProperties.java b/geode-core/src/main/java/org/apache/geode/distributed/ConfigurationProperties.java
index 8cbe7c5..f8f9e29 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/ConfigurationProperties.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/ConfigurationProperties.java
@@ -503,7 +503,7 @@ public interface ConfigurationProperties {
    * The static String definition of the <i>"gateway-ssl-ciphers"</i> property <a
    * name="gateway-ssl-ciphers"/a>
    * </p>
-   * <U>Description</U>: A space seperated list of the SSL cipher suites to enable. Those listed
+   * <U>Description</U>: A space separated list of the SSL cipher suites to enable. Those listed
    * must be supported by the available providers.
    * </p>
    * <U>Default</U>: <code>any</code>
@@ -578,7 +578,7 @@ public interface ConfigurationProperties {
    * The static String definition of the <i>"gateway-ssl-protocols"</i> property <a
    * name="gateway-ssl-protocols"/a>
    * </p>
-   * <U>Description</U>: A space seperated list of the SSL protocols to enable. Those listed must be
+   * <U>Description</U>: A space separated list of the SSL protocols to enable. Those listed must be
    * supported by the available providers.
    * </p>
    * <U>Default</U>: <code>any</code>
@@ -974,7 +974,7 @@ public interface ConfigurationProperties {
    * The static String definition of the <i>"jmx-manager-ssl-ciphers"</i> property <a
    * name="jmx-manager-ssl-ciphers"/a>
    * </p>
-   * <U>Description</U>: A space seperated list of the SSL cipher suites to enable. Those listed
+   * <U>Description</U>: A space separated list of the SSL cipher suites to enable. Those listed
    * must be supported by the available providers.
    * </p>
    * <U>Default</U>: "any"
@@ -1047,7 +1047,7 @@ public interface ConfigurationProperties {
    * The static String definition of the <i>"jmx-manager-ssl-protocols"</i> property <a
    * name="jmx-manager-ssl-protocols"/a>
    * </p>
-   * <U>Description</U>: A space seperated list of the SSL protocols to enable. Those listed must be
+   * <U>Description</U>: A space separated list of the SSL protocols to enable. Those listed must be
    * supported by the available providers.
    * </p>
    * <U>Default</U>: "any"
@@ -1555,7 +1555,7 @@ public interface ConfigurationProperties {
    * The static String definition of the <i>"server-ssl-ciphers"</i> property <a
    * name="server-ssl-ciphers"/a>
    * </p>
-   * <U>Description</U>: A space seperated list of the SSL cipher suites to enable. Those listed
+   * <U>Description</U>: A space separated list of the SSL cipher suites to enable. Those listed
    * must be supported by the available providers.
    * </p>
    * <U>Default</U>: <code>any</code>
@@ -1630,7 +1630,7 @@ public interface ConfigurationProperties {
    * The static String definition of the <i>"server-ssl-protocols"</i> property <a
    * name="server-ssl-protocols"/a>
    * </p>
-   * <U>Description</U>: A space seperated list of the SSL protocols to enable. Those listed must be
+   * <U>Description</U>: A space separated list of the SSL protocols to enable. Those listed must be
    * supported by the available providers.
    * </p>
    * <U>Default</U>: <code>any</code>
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionConfig.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionConfig.java
index dbbe3df..3840128 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionConfig.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/DistributionConfig.java
@@ -295,7 +295,7 @@ public interface DistributionConfig extends Config, LogConfig {
    * the system to locator other system nodes and to publish itself so it can be located by others.
    *
    * @param value must be of the form <code>hostName[portNum]</code>. Multiple elements are allowed
-   *        and must be seperated by a comma.
+   *        and must be separated by a comma.
    *
    * @throws IllegalArgumentException if the specified value is not acceptable.
    * @throws org.apache.geode.UnmodifiableException if this attribute can not be modified.
diff --git a/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/DependencyGraph.java b/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/DependencyGraph.java
index 27c8cab..d5404e9 100644
--- a/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/DependencyGraph.java
+++ b/geode-core/src/main/java/org/apache/geode/distributed/internal/deadlock/DependencyGraph.java
@@ -174,20 +174,20 @@ public class DependencyGraph implements Serializable {
 
     // find all terminal nodes having no incoming
     // dependers.
-    Set<Object> allDependants = new HashSet<>();
+    Set<Object> allDependents = new HashSet<>();
     for (Dependency dep : edges) {
       if ((dep.dependsOn instanceof LocalThread)) {
         if (dep.depender instanceof MessageKey) {
-          allDependants.add(dep.dependsOn);
+          allDependents.add(dep.dependsOn);
         }
       } else {
-        allDependants.add(dep.dependsOn);
+        allDependents.add(dep.dependsOn);
       }
     }
 
     List<DependencyGraph> result = new LinkedList<>();
     for (Object depender : dependsOnObj) {
-      if (!allDependants.contains(depender)) {
+      if (!allDependents.contains(depender)) {
         result.add(getSubGraph(depender));
       }
     }
diff --git a/geode-core/src/main/java/org/apache/geode/internal/DataSerializableFixedID.java b/geode-core/src/main/java/org/apache/geode/internal/DataSerializableFixedID.java
index fff0f1d..b5b6b5e 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/DataSerializableFixedID.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/DataSerializableFixedID.java
@@ -31,7 +31,7 @@ import org.apache.geode.Instantiator;
  *
  * <p>
  * Note that this class is for internal use only. Customer classes that want to do something
- * similiar should implement a subclass of {@link DataSerializer} or {@link Instantiator}.
+ * similar should implement a subclass of {@link DataSerializer} or {@link Instantiator}.
  *
  * <p>
  * To add a new DataSerializableFixedID do this following:
diff --git a/geode-core/src/main/java/org/apache/geode/internal/InternalInstantiator.java b/geode-core/src/main/java/org/apache/geode/internal/InternalInstantiator.java
index 86f5283..fea2c4c 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/InternalInstantiator.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/InternalInstantiator.java
@@ -177,8 +177,8 @@ public class InternalInstantiator {
       // send it to cache servers if it is a client
       sendRegistrationMessageToServers(instantiator);
     }
-    // send it to all cache clients irelevent of distribute
-    // bridge servers send it all the clients irelevent of
+    // send it to all cache clients irrelevant of distribute
+    // bridge servers send it all the clients irrelevant of
     // originator VM
     sendRegistrationMessageToClients(instantiator);
 
diff --git a/geode-core/src/main/java/org/apache/geode/internal/admin/CacheCollector.java b/geode-core/src/main/java/org/apache/geode/internal/admin/CacheCollector.java
index d402777..e70bc52 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/admin/CacheCollector.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/admin/CacheCollector.java
@@ -51,7 +51,7 @@ public class CacheCollector {
 
   /**
    * A sequence number for the snapshots requested by this VM. We use this sequence number to ignore
-   * snapshot segments that are not relevent to the current snapshot
+   * snapshot segments that are not relevant to the current snapshot
    */
   private static int snapshotCount;
 
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/InitialImageOperation.java b/geode-core/src/main/java/org/apache/geode/internal/cache/InitialImageOperation.java
index e4e5278..9007399 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/InitialImageOperation.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/InitialImageOperation.java
@@ -1139,9 +1139,9 @@ public class InitialImageOperation {
     private volatile boolean abort = false;
 
     /**
-     * to know whether chunk recieved or not, since last checkpoint
+     * to know whether chunk received or not, since last checkpoint
      */
-    private volatile boolean recievedChunk = false;
+    private volatile boolean receivedChunk = false;
 
     /**
      * Tracks the status of this operation.
@@ -1262,9 +1262,9 @@ public class InitialImageOperation {
 
     @Override
     protected boolean processTimeout() {
-      // if chunk recieved then no need to process timeout
-      boolean ret = this.recievedChunk;
-      this.recievedChunk = false;
+      // if chunk received then no need to process timeout
+      boolean ret = this.receivedChunk;
+      this.receivedChunk = false;
       return !ret;
     }
 
@@ -1308,7 +1308,7 @@ public class InitialImageOperation {
                 if (isAborted) {
                   this.abort = true; // volatile store
                 } else {
-                  this.recievedChunk = true;
+                  this.receivedChunk = true;
                 }
               }
               isLast = trackMessage(m); // interpret series/msgNum
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegion.java b/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegion.java
index a7d0800..2a6f2cb 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegion.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegion.java
@@ -3577,10 +3577,10 @@ public class PartitionedRegion extends LocalRegion
         logger.debug("FunctionService: Executing on remote nodes with member to keys map.{}",
             memberToKeysMap);
       }
-      PartitionedRegionFunctionResultWaiter resultReciever =
+      PartitionedRegionFunctionResultWaiter resultReceiver =
           new PartitionedRegionFunctionResultWaiter(getSystem(), this.getPRId(),
               localResultCollector, function, resultSender);
-      return resultReciever.getPartitionedDataFrom(recipMap, this, execution);
+      return resultReceiver.getPartitionedDataFrom(recipMap, this, execution);
     }
     return localResultCollector;
   }
@@ -3826,11 +3826,11 @@ public class PartitionedRegion extends LocalRegion
               localBucketSet, resultSender, execution.isReExecute());
       execution.executeFunctionOnLocalNode(function, prContext, resultSender, dm, isTX());
     }
-    PartitionedRegionFunctionResultWaiter resultReciever =
+    PartitionedRegionFunctionResultWaiter resultReceiver =
         new PartitionedRegionFunctionResultWaiter(getSystem(), this.getPRId(), localRC, function,
             resultSender);
 
-    return resultReciever.getPartitionedDataFrom(recipMap, this, execution);
+    return resultReceiver.getPartitionedDataFrom(recipMap, this, execution);
   }
 
   /**
@@ -3921,11 +3921,11 @@ public class PartitionedRegion extends LocalRegion
               localBucketSet, resultSender, execution.isReExecute());
       execution.executeFunctionOnLocalPRNode(function, prContext, resultSender, dm, isTX());
     }
-    PartitionedRegionFunctionResultWaiter resultReciever =
+    PartitionedRegionFunctionResultWaiter resultReceiver =
         new PartitionedRegionFunctionResultWaiter(getSystem(), this.getPRId(), localResultCollector,
             function, resultSender);
 
-    return resultReciever.getPartitionedDataFrom(recipMap, this, execution);
+    return resultReceiver.getPartitionedDataFrom(recipMap, this, execution);
   }
 
   /**
@@ -4811,7 +4811,7 @@ public class PartitionedRegion extends LocalRegion
         new PartitionedRegionFunctionResultSender(null, this, 0, rc, sender, false, true,
             execution.isForwardExceptions(), function, bucketSet);
 
-    PartitionedRegionFunctionResultWaiter resultReciever =
+    PartitionedRegionFunctionResultWaiter resultReceiver =
         new PartitionedRegionFunctionResultWaiter(getSystem(), this.getPRId(), rc, function,
             resultSender);
 
@@ -4823,7 +4823,7 @@ public class PartitionedRegion extends LocalRegion
 
     recipMap.put(targetNode, context);
 
-    return resultReciever.getPartitionedDataFrom(recipMap, this, execution);
+    return resultReceiver.getPartitionedDataFrom(recipMap, this, execution);
   }
 
   /**
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionQueryEvaluator.java b/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionQueryEvaluator.java
index b541d94..8a8c61c 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionQueryEvaluator.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/PartitionedRegionQueryEvaluator.java
@@ -260,7 +260,7 @@ public class PartitionedRegionQueryEvaluator extends StreamingPartitionOperation
   }
 
   // TODO Asif: optimize it by creating a Sorted SelectResults Object at the time of fromData , so
-  // that processData already recieves ordered data.
+  // that processData already receives ordered data.
   private List sortIncomingData(List objects, List<CompiledSortCriterion> orderByAttribs) {
     ObjectType resultType = cumulativeResults.getCollectionType().getElementType();
     ExecutionContext local = new ExecutionContext(null, this.pr.cache);
@@ -713,16 +713,16 @@ public class PartitionedRegionQueryEvaluator extends StreamingPartitionOperation
 
             for (Object obj : res) {
               checkIfQueryShouldBeCancelled();
-              int occurence = 0;
+              int occurrence = 0;
               obj = PDXUtils.convertPDX(obj, isStruct, getDomainObjectForPdx, getDeserializedObject,
                   localResults, objectChangedMarker, true);
               boolean elementGotAdded =
                   isStruct ? ((StructSet) this.cumulativeResults).addFieldValues((Object[]) obj)
                       : this.cumulativeResults.add(obj);
-              occurence = elementGotAdded ? 1 : 0;
-              // Asif: (Unique i.e first time occurence) or subsequent occurence
+              occurrence = elementGotAdded ? 1 : 0;
+              // Asif: (Unique i.e first time occurrence) or subsequent occurrence
               // for non distinct query
-              if (occurence == 1) {
+              if (occurrence == 1) {
                 ++numElementsInResult;
                 // Asif:Check again to see if this addition caused limit to be
                 // reached so that current loop will not iterate one more
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionEntry.java b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionEntry.java
index 27baabd..c16ad23 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/RegionEntry.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/RegionEntry.java
@@ -298,9 +298,9 @@ public interface RegionEntry {
    * getInitialImage.
    *
    * <p>
-   * put if LOCAL_INVALID and nonexistant<br>
-   * put if INVALID and nonexistant, recovered, or LOCAL_INVALID<br>
-   * put if valid and nonexistant, recovered, or LOCAL_INVALID
+   * put if LOCAL_INVALID and nonexistent<br>
+   * put if INVALID and nonexistent, recovered, or LOCAL_INVALID<br>
+   * put if valid and nonexistent, recovered, or LOCAL_INVALID
    *
    * <p>
    * REGION_INVALIDATED: (special case)<br>
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/TXManagerImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/TXManagerImpl.java
index 9144566..ccc68f2 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/TXManagerImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/TXManagerImpl.java
@@ -577,7 +577,7 @@ public class TXManagerImpl implements CacheTransactionManager, MembershipListene
   }
 
   /**
-   * Reports the existance of a Transaction for this thread
+   * Reports the existence of a Transaction for this thread
    *
    */
   public boolean exists() {
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/backup/BackupFileCopier.java b/geode-core/src/main/java/org/apache/geode/internal/cache/backup/BackupFileCopier.java
index e013e7e..e054cc3 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/backup/BackupFileCopier.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/backup/BackupFileCopier.java
@@ -64,13 +64,13 @@ public class BackupFileCopier {
   }
 
   void copyConfigFiles() throws IOException {
-    ensureExistance(configDirectory);
+    ensureExistence(configDirectory);
     addConfigFileToBackup(cache.getCacheXmlURL());
     addConfigFileToBackup(DistributedSystem.getPropertiesFileURL());
     // TODO: should the gfsecurity.properties file be backed up?
   }
 
-  private void ensureExistance(Path directory) throws IOException {
+  private void ensureExistence(Path directory) throws IOException {
     if (!Files.exists(directory)) {
       Files.createDirectories(directory);
     }
@@ -97,7 +97,7 @@ public class BackupFileCopier {
 
   Set<File> copyUserFiles() throws IOException {
     Set<File> userFilesBackedUp = new HashSet<>();
-    ensureExistance(userDirectory);
+    ensureExistence(userDirectory);
     List<File> backupFiles = cache.getBackupFiles();
     for (File original : backupFiles) {
       if (original.exists()) {
@@ -119,7 +119,7 @@ public class BackupFileCopier {
     Set<File> userJars = new HashSet<>();
     JarDeployer deployer = null;
 
-    ensureExistance(userDirectory);
+    ensureExistence(userDirectory);
     try {
       // Suspend any user deployed jar file updates during this backup.
       deployer = getJarDeployer();
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/DistributedRegionFunctionResultSender.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/DistributedRegionFunctionResultSender.java
index 8827220..bb8e6e7 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/DistributedRegionFunctionResultSender.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/DistributedRegionFunctionResultSender.java
@@ -45,7 +45,7 @@ public class DistributedRegionFunctionResultSender implements InternalResultSend
 
   private boolean enableOrderedResultStreming;
 
-  private boolean localLastResultRecieved = false;
+  private boolean localLastResultReceived = false;
 
   /**
    * Have to combine next two construcotr in one and make a new class which will send Results back.
@@ -77,10 +77,10 @@ public class DistributedRegionFunctionResultSender implements InternalResultSend
           LocalizedStrings.ExecuteFunction_CANNOT_0_RESULTS_HASRESULT_FALSE
               .toLocalizedString("send"));
     }
-    if (this.localLastResultRecieved) {
+    if (this.localLastResultReceived) {
       return;
     }
-    this.localLastResultRecieved = true;
+    this.localLastResultReceived = true;
     if (this.sender != null) { // Client-Server
       sender.lastResult(oneResult);
       if (this.rc != null) {
@@ -114,7 +114,7 @@ public class DistributedRegionFunctionResultSender implements InternalResultSend
           LocalizedStrings.ExecuteFunction_CANNOT_0_RESULTS_HASRESULT_FALSE
               .toLocalizedString("send"));
     }
-    this.localLastResultRecieved = true;
+    this.localLastResultReceived = true;
     if (this.sender != null) { // Client-Server
       sender.lastResult(oneResult, memberID);
       if (this.rc != null) {
@@ -211,7 +211,7 @@ public class DistributedRegionFunctionResultSender implements InternalResultSend
   public void sendException(Throwable exception) {
     InternalFunctionException iFunxtionException = new InternalFunctionException(exception);
     this.lastResult(iFunxtionException);
-    this.localLastResultRecieved = true;
+    this.localLastResultReceived = true;
   }
 
   public void setException(Throwable exception) {
@@ -227,7 +227,7 @@ public class DistributedRegionFunctionResultSender implements InternalResultSend
           exception);
     }
     this.rc.endResults();
-    this.localLastResultRecieved = true;
+    this.localLastResultReceived = true;
   }
 
   public void enableOrderedResultStreming(boolean enable) {
@@ -239,6 +239,6 @@ public class DistributedRegionFunctionResultSender implements InternalResultSend
   }
 
   public boolean isLastResultReceived() {
-    return this.localLastResultRecieved;
+    return this.localLastResultReceived;
   }
 }
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionStreamingResultCollector.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionStreamingResultCollector.java
index 05a05a0..24935ac 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionStreamingResultCollector.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/FunctionStreamingResultCollector.java
@@ -76,7 +76,7 @@ public class FunctionStreamingResultCollector extends ReplyProcessor21 implement
 
   protected AbstractExecution execution;
 
-  protected volatile boolean endResultRecieved = false;
+  protected volatile boolean endResultReceived = false;
 
   protected volatile List<FunctionInvocationTargetException> fites;
 
@@ -97,7 +97,7 @@ public class FunctionStreamingResultCollector extends ReplyProcessor21 implement
   }
 
   public void addResult(DistributedMember memId, Object resultOfSingleExecution) {
-    if (this.userRC != null && !this.endResultRecieved) {
+    if (this.userRC != null && !this.endResultReceived) {
       try {
         this.userRC.addResult(memId, resultOfSingleExecution);
       } catch (RuntimeException badre) {
@@ -111,13 +111,13 @@ public class FunctionStreamingResultCollector extends ReplyProcessor21 implement
   public void endResults() {
     if (this.userRC != null) {
       this.userRC.endResults();
-      this.endResultRecieved = true;
+      this.endResultReceived = true;
     }
   }
 
   public void clearResults() {
     if (userRC != null) {
-      this.endResultRecieved = false;
+      this.endResultReceived = false;
       this.userRC.clearResults();
     }
     this.fites.clear();
@@ -394,7 +394,7 @@ public class FunctionStreamingResultCollector extends ReplyProcessor21 implement
                   id);
               if (execution.isClientServerMode()) {
                 if (this.userRC != null) {
-                  this.endResultRecieved = false;
+                  this.endResultReceived = false;
                   this.userRC.endResults();
                   this.userRC.clearResults();
                 }
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/LocalResultCollectorImpl.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/LocalResultCollectorImpl.java
index e0fe28f..6461205 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/LocalResultCollectorImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/LocalResultCollectorImpl.java
@@ -32,7 +32,7 @@ public class LocalResultCollectorImpl implements LocalResultCollector {
 
   private CountDownLatch latch = new CountDownLatch(1);
 
-  protected volatile boolean endResultRecieved = false;
+  protected volatile boolean endResultReceived = false;
 
   private volatile boolean resultCollected = false;
 
@@ -54,7 +54,7 @@ public class LocalResultCollectorImpl implements LocalResultCollector {
     if (resultsCleared) {
       return;
     }
-    if (!this.endResultRecieved) {
+    if (!this.endResultReceived) {
       if (resultOfSingleExecution instanceof Throwable) {
         Throwable t = (Throwable) resultOfSingleExecution;
         if (this.execution.isIgnoreDepartedMembers()) {
@@ -88,14 +88,14 @@ public class LocalResultCollectorImpl implements LocalResultCollector {
   }
 
   public void endResults() {
-    this.endResultRecieved = true;
+    this.endResultReceived = true;
     this.userRC.endResults();
     this.latch.countDown();
   }
 
   public synchronized void clearResults() {
     this.latch = new CountDownLatch(1);
-    this.endResultRecieved = false;
+    this.endResultReceived = false;
     this.functionException = null;
     this.userRC.clearResults();
     resultsCleared = true;
@@ -139,19 +139,19 @@ public class LocalResultCollectorImpl implements LocalResultCollector {
   public Object getResult(long timeout, TimeUnit unit)
       throws FunctionException, InterruptedException {
 
-    boolean resultRecieved = false;
+    boolean resultReceived = false;
     if (this.resultCollected) {
       throw new FunctionException(
           LocalizedStrings.ExecuteFunction_RESULTS_ALREADY_COLLECTED.toLocalizedString());
     }
     this.resultCollected = true;
     try {
-      resultRecieved = this.latch.await(timeout, unit);
+      resultReceived = this.latch.await(timeout, unit);
     } catch (InterruptedException e) {
       this.latch.countDown();
       Thread.currentThread().interrupt();
     }
-    if (!resultRecieved) {
+    if (!resultReceived) {
       throw new FunctionException(
           LocalizedStrings.ExecuteFunction_RESULTS_NOT_COLLECTED_IN_TIME_PROVIDED
               .toLocalizedString());
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MemberFunctionExecutor.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MemberFunctionExecutor.java
index 752d56a..f6f1098 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MemberFunctionExecutor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MemberFunctionExecutor.java
@@ -149,10 +149,10 @@ public class MemberFunctionExecutor extends AbstractExecution {
         memberArgs.put(recip, getArgumentsForMember(recip.getId()));
       }
       Assert.assertTrue(memberArgs.size() == dest.size());
-      MemberFunctionResultWaiter resultReciever = new MemberFunctionResultWaiter(this.ds, localRC,
+      MemberFunctionResultWaiter resultReceiver = new MemberFunctionResultWaiter(this.ds, localRC,
           function, memberArgs, dest, resultSender);
 
-      ResultCollector reply = resultReciever.getFunctionResultFrom(dest, function, this);
+      ResultCollector reply = resultReceiver.getFunctionResultFrom(dest, function, this);
       return reply;
     }
     return localRC;
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MemberFunctionResultSender.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MemberFunctionResultSender.java
index 6ba62e1..54b7caa 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MemberFunctionResultSender.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/MemberFunctionResultSender.java
@@ -41,7 +41,7 @@ public class MemberFunctionResultSender implements InternalResultSender {
 
   private final Function function;
 
-  private boolean localLastResultRecieved = false;
+  private boolean localLastResultReceived = false;
 
   private boolean onlyLocal = false;
 
@@ -85,13 +85,13 @@ public class MemberFunctionResultSender implements InternalResultSender {
               .toLocalizedString("send"));
     }
     if (this.serverSender != null) { // client-server
-      if (this.localLastResultRecieved) {
+      if (this.localLastResultReceived) {
         return;
       }
       if (onlyLocal) {
         this.serverSender.lastResult(oneResult);
         this.rc.endResults();
-        this.localLastResultRecieved = true;
+        this.localLastResultReceived = true;
       } else {
         lastResult(oneResult, rc, false, true, this.dm.getId());
       }
@@ -107,13 +107,13 @@ public class MemberFunctionResultSender implements InternalResultSender {
           throw new FunctionException(e);
         }
       } else {
-        if (this.localLastResultRecieved) {
+        if (this.localLastResultReceived) {
           return;
         }
         if (onlyLocal) {
           this.rc.addResult(this.dm.getDistributionManagerId(), oneResult);
           this.rc.endResults();
-          this.localLastResultRecieved = true;
+          this.localLastResultReceived = true;
         } else {
           // call a synchronized method as local node is also waiting to send lastResult
           lastResult(oneResult, rc, false, true, this.dm.getDistributionManagerId());
@@ -131,18 +131,18 @@ public class MemberFunctionResultSender implements InternalResultSender {
       this.completelyDoneFromRemote = true;
     }
     if (lastLocalResult) {
-      this.localLastResultRecieved = true;
+      this.localLastResultReceived = true;
 
     }
     if (this.serverSender != null) { // Client-Server
-      if (this.completelyDoneFromRemote && this.localLastResultRecieved) {
+      if (this.completelyDoneFromRemote && this.localLastResultReceived) {
         this.serverSender.lastResult(oneResult, memberID);
         collector.endResults();
       } else {
         this.serverSender.sendResult(oneResult, memberID);
       }
     } else { // P2P
-      if (this.completelyDoneFromRemote && this.localLastResultRecieved) {
+      if (this.completelyDoneFromRemote && this.localLastResultReceived) {
         collector.addResult(memberID, oneResult);
         collector.endResults();
       } else {
@@ -217,7 +217,7 @@ public class MemberFunctionResultSender implements InternalResultSender {
   public void sendException(Throwable exception) {
     InternalFunctionException iFunxtionException = new InternalFunctionException(exception);
     this.lastResult(iFunxtionException);
-    this.localLastResultRecieved = true;
+    this.localLastResultReceived = true;
   }
 
   public void setException(Throwable exception) {
@@ -228,7 +228,7 @@ public class MemberFunctionResultSender implements InternalResultSender {
             LocalizedStrings.MemberResultSender_UNEXPECTED_EXCEPTION_DURING_FUNCTION_EXECUTION_ON_LOCAL_NODE),
         exception);
     this.rc.endResults();
-    this.localLastResultRecieved = true;
+    this.localLastResultReceived = true;
   }
 
   public void enableOrderedResultStreming(boolean enable) {
@@ -240,6 +240,6 @@ public class MemberFunctionResultSender implements InternalResultSender {
   }
 
   public boolean isLastResultReceived() {
-    return this.localLastResultRecieved;
+    return this.localLastResultReceived;
   }
 }
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/PartitionedRegionFunctionResultSender.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/PartitionedRegionFunctionResultSender.java
index 441043b..4f4dcc5 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/PartitionedRegionFunctionResultSender.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/PartitionedRegionFunctionResultSender.java
@@ -35,7 +35,7 @@ import org.apache.geode.internal.logging.log4j.LocalizedMessage;
  * ResultSender needs ResultCollector in which to add results one by one. In case of localExecution
  * it just adds result to the resultCollector whereas for remote cases it takes help of
  * PRFunctionExecutionStreamer to send results to the calling node. The results will be received in
- * the ResultReciever. ResultSender will be instantiated in executeOnDatastore and set in
+ * the ResultReceiver. ResultSender will be instantiated in executeOnDatastore and set in
  * FunctionContext.
  *
  */
@@ -58,7 +58,7 @@ public class PartitionedRegionFunctionResultSender implements InternalResultSend
 
   private ServerToClientFunctionResultSender serverSender;
 
-  private boolean localLastResultRecieved = false;
+  private boolean localLastResultReceived = false;
 
   private boolean onlyLocal = false;
 
@@ -137,7 +137,7 @@ public class PartitionedRegionFunctionResultSender implements InternalResultSend
     // so that client receives all the results before
 
     if (this.serverSender != null) { // Client-Server
-      if (this.localLastResultRecieved) {
+      if (this.localLastResultReceived) {
         return;
       }
       if (onlyLocal) {
@@ -149,7 +149,7 @@ public class PartitionedRegionFunctionResultSender implements InternalResultSend
           lastClientSend(dm.getDistributionManagerId(), oneResult);
         }
         this.rc.endResults();
-        this.localLastResultRecieved = true;
+        this.localLastResultReceived = true;
 
       } else {
         // call a synchronized method as local node is also waiting to send lastResult
@@ -175,7 +175,7 @@ public class PartitionedRegionFunctionResultSender implements InternalResultSend
           throw new FunctionException(e);
         }
       } else {
-        if (this.localLastResultRecieved) {
+        if (this.localLastResultReceived) {
           return;
         }
         if (onlyLocal) {
@@ -188,7 +188,7 @@ public class PartitionedRegionFunctionResultSender implements InternalResultSend
           }
           // exception thrown will do end result
           this.rc.endResults();
-          this.localLastResultRecieved = true;
+          this.localLastResultReceived = true;
         } else {
           // call a synchronized method as local node is also waiting to send lastResult
           lastResult(oneResult, rc, false, true, dm.getDistributionManagerId());
@@ -209,7 +209,7 @@ public class PartitionedRegionFunctionResultSender implements InternalResultSend
       boolean lastRemoteResult, boolean lastLocalResult, DistributedMember memberID) {
 
 
-    boolean completedLocal = lastLocalResult || this.localLastResultRecieved;
+    boolean completedLocal = lastLocalResult || this.localLastResultReceived;
     if (lastRemoteResult) {
       this.completelyDoneFromRemote = true;
     }
@@ -273,7 +273,7 @@ public class PartitionedRegionFunctionResultSender implements InternalResultSend
       }
     }
     if (lastLocalResult) {
-      this.localLastResultRecieved = true;
+      this.localLastResultReceived = true;
     }
   }
 
@@ -365,7 +365,7 @@ public class PartitionedRegionFunctionResultSender implements InternalResultSend
   public void sendException(Throwable exception) {
     InternalFunctionException iFunxtionException = new InternalFunctionException(exception);
     this.lastResult(iFunxtionException);
-    this.localLastResultRecieved = true;
+    this.localLastResultReceived = true;
   }
 
   public void setException(Throwable exception) {
@@ -379,7 +379,7 @@ public class PartitionedRegionFunctionResultSender implements InternalResultSend
           exception);
     }
     this.rc.endResults();
-    this.localLastResultRecieved = true;
+    this.localLastResultReceived = true;
   }
 
   public void enableOrderedResultStreming(boolean enable) {
@@ -391,7 +391,7 @@ public class PartitionedRegionFunctionResultSender implements InternalResultSend
   }
 
   public boolean isLastResultReceived() {
-    return localLastResultRecieved;
+    return localLastResultReceived;
   }
 
 }
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/PartitionedRegionFunctionResultWaiter.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/PartitionedRegionFunctionResultWaiter.java
index 156c2f0..90a87e0 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/PartitionedRegionFunctionResultWaiter.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/PartitionedRegionFunctionResultWaiter.java
@@ -31,7 +31,7 @@ import org.apache.geode.internal.cache.partitioned.PartitionMessage;
 import org.apache.geode.internal.cache.partitioned.PartitionedRegionFunctionStreamingMessage;
 
 /**
- * ResultReciever (which could be resultCollector?)will be instantiated and will be used to send
+ * ResultReceiver (which could be resultCollector?)will be instantiated and will be used to send
  * messages and receive results from other nodes. It takes a set of nodes to which functionExecution
  * message has to be sent. Creates one message for each and sends it to each of them. Then it gets
  * result in processData where it adds them to the resultCollector.
@@ -108,9 +108,9 @@ public class PartitionedRegionFunctionResultWaiter extends StreamingFunctionOper
   public void processData(Object result, boolean lastMsg, DistributedMember memberID) {
     boolean completelyDone = false;
     if (lastMsg) {
-      this.totalLastMsgRecieved++;
+      this.totalLastMsgReceived++;
     }
-    if (this.totalLastMsgRecieved == this.recipients.size()) {
+    if (this.totalLastMsgReceived == this.recipients.size()) {
       completelyDone = true;
     }
     ((PartitionedRegionFunctionResultSender) resultSender).lastResult(result, completelyDone,
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/StreamingFunctionOperation.java b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/StreamingFunctionOperation.java
index a821dda..b419f52 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/execute/StreamingFunctionOperation.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/execute/StreamingFunctionOperation.java
@@ -42,7 +42,7 @@ public abstract class StreamingFunctionOperation {
 
   protected ResultCollector reply;
 
-  protected int totalLastMsgRecieved = 0;
+  protected int totalLastMsgReceived = 0;
 
   /** Creates a new instance of StreamingOperation */
   public StreamingFunctionOperation(InternalDistributedSystem sys, ResultCollector rc,
@@ -68,9 +68,9 @@ public abstract class StreamingFunctionOperation {
   public void processData(Object result, boolean lastMsg, DistributedMember memberID) {
     boolean completelyDone = false;
     if (lastMsg) {
-      this.totalLastMsgRecieved++;
+      this.totalLastMsgReceived++;
     }
-    if (this.totalLastMsgRecieved == this.recipients.size()) {
+    if (this.totalLastMsgReceived == this.recipients.size()) {
       completelyDone = true;
     }
 
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HARegionQueue.java b/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HARegionQueue.java
index e69a8af..9e0b38c 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HARegionQueue.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/ha/HARegionQueue.java
@@ -284,7 +284,7 @@ public class HARegionQueue implements RegionQueue {
    *
    * @since GemFire 6.0
    */
-  public boolean isClientSlowReciever = false;
+  public boolean isClientSlowReceiver = false;
 
   /**
    * initialization flag - when true the queue has fully initialized
@@ -296,7 +296,7 @@ public class HARegionQueue implements RegionQueue {
    *
    * @since GemFire 6.0
    */
-  static boolean testMarkerMessageRecieved = false;
+  static boolean testMarkerMessageReceived = false;
   static boolean isUsedByTest = false;
 
   /**
@@ -1599,9 +1599,9 @@ public class HARegionQueue implements RegionQueue {
         Object old = ((ConcurrentMap) tempDispatchedMessagesMap).putIfAbsent(this.regionName,
             this.threadIdToSeqId);
         if (isUsedByTest) {
-          testMarkerMessageRecieved = true;
+          testMarkerMessageReceived = true;
           if (logger.isDebugEnabled()) {
-            logger.debug("testIsAckRecieved: {}", testMarkerMessageRecieved);
+            logger.debug("testIsAckReceived: {}", testMarkerMessageReceived);
           }
         }
         Assert.assertTrue(old == null);
@@ -2248,7 +2248,7 @@ public class HARegionQueue implements RegionQueue {
             synchronized (this.permitMon) {
               if (reconcilePutPermits() <= 0) {
                 if (region.getSystem().getConfig().getRemoveUnresponsiveClient()) {
-                  isClientSlowReciever = true;
+                  isClientSlowReceiver = true;
                 } else {
                   try {
                     long logFrequency = CacheClientNotifier.DEFAULT_LOG_FREQUENCY;
@@ -2656,7 +2656,7 @@ public class HARegionQueue implements RegionQueue {
 
   /**
    * A static class which is created only for for testing prposes as some existing tests extend the
-   * HARegionQueue. Since teh constructors of HAregionQueue are private , this class can act as a
+   * HARegionQueue. Since the constructors of HAregionQueue are private , this class can act as a
    * bridge between the user defined HARegionQueue class & the actual class. This class object will
    * be buggy as it will tend to publish the Object o QRM thread & the expiry thread before the
    * complete creation of the HARegionQueue instance
@@ -3787,19 +3787,19 @@ public class HARegionQueue implements RegionQueue {
 
   public void initializeTransients() {}
 
-  public static boolean isTestMarkerMessageRecieved() {
-    return testMarkerMessageRecieved;
+  public static boolean isTestMarkerMessageReceived() {
+    return testMarkerMessageReceived;
   }
 
   public static void setUsedByTest(boolean isUsedByTest) {
     HARegionQueue.isUsedByTest = isUsedByTest;
     if (!isUsedByTest) {
-      HARegionQueue.testMarkerMessageRecieved = isUsedByTest;
+      HARegionQueue.testMarkerMessageReceived = isUsedByTest;
     }
   }
 
-  public boolean isClientSlowReciever() {
-    return isClientSlowReciever;
+  public boolean isClientSlowReceiver() {
+    return isClientSlowReceiver;
   }
 
   @Override
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/BucketBackupMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/BucketBackupMessage.java
index 0c16647..f330a66 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/BucketBackupMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/BucketBackupMessage.java
@@ -70,7 +70,7 @@ public class BucketBackupMessage extends PartitionMessage {
 
   /**
    * This message may be sent to nodes before the PartitionedRegion is completely initialized due to
-   * the RegionAdvisor(s) knowing about the existance of a partitioned region at a very early part
+   * the RegionAdvisor(s) knowing about the existence of a partitioned region at a very early part
    * of the initialization
    */
   @Override
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/FlushMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/FlushMessage.java
index 38a4e20..c8f175b 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/FlushMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/FlushMessage.java
@@ -68,7 +68,7 @@ public class FlushMessage extends SerialDistributionMessage implements MessageWi
   }
 
   /*
-   * Used both for the reciept of a FlushMessage and the reply to a Flushmessage
+   * Used both for the receipt of a FlushMessage and the reply to a Flushmessage
    */
   @Override
   protected void process(ClusterDistributionManager dm) {
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/IndexCreationMsg.java b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/IndexCreationMsg.java
index fd711f3..493bfad 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/IndexCreationMsg.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/IndexCreationMsg.java
@@ -85,7 +85,7 @@ public class IndexCreationMsg extends PartitionMessage {
 
   /**
    * This message may be sent to nodes before the PartitionedRegion is completely initialized due to
-   * the RegionAdvisor(s) knowing about the existance of a partitioned region at a very early part
+   * the RegionAdvisor(s) knowing about the existence of a partitioned region at a very early part
    * of the initialization
    */
   @Override
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/PRFunctionStreamingResultCollector.java b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/PRFunctionStreamingResultCollector.java
index 27035b1..ec08ee8 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/PRFunctionStreamingResultCollector.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/PRFunctionStreamingResultCollector.java
@@ -71,7 +71,7 @@ public class PRFunctionStreamingResultCollector extends FunctionStreamingResultC
 
   @Override
   public void addResult(DistributedMember memId, Object resultOfSingleExecution) {
-    if (!this.endResultRecieved) {
+    if (!this.endResultReceived) {
       if (!(this.userRC instanceof LocalResultCollectorImpl)
           && resultOfSingleExecution instanceof InternalFunctionException) {
         resultOfSingleExecution = ((InternalFunctionException) resultOfSingleExecution).getCause();
@@ -223,7 +223,7 @@ public class PRFunctionStreamingResultCollector extends FunctionStreamingResultC
       try {
         long timeBefore = System.currentTimeMillis();
         if (!this.waitForCacheOrFunctionException(timeoutInMillis)) {
-          throw new FunctionException("All results not recieved in time provided.");
+          throw new FunctionException("All results not received in time provided.");
         }
         long timeAfter = System.currentTimeMillis();
         timeoutInMillis = timeoutInMillis - (timeAfter - timeBefore);
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/RegionAdvisor.java b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/RegionAdvisor.java
index b1b2c72..e2fd72c 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/RegionAdvisor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/RegionAdvisor.java
@@ -545,7 +545,7 @@ public class RegionAdvisor extends CacheDistributionAdvisor {
     /**
      * Track the number of buckets this data store may have, implies isDataStore == true This value
      * is NOT sent directly but updated when {@link org.apache.geode.internal.cache.BucketAdvisor}s
-     * recieve updates
+     * receive updates
      */
     public transient short numBuckets = 0;
 
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/RemoveIndexesMessage.java b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/RemoveIndexesMessage.java
index e87639b..42b54e9 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/RemoveIndexesMessage.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/partitioned/RemoveIndexesMessage.java
@@ -105,7 +105,7 @@ public class RemoveIndexesMessage extends PartitionMessage {
 
   /**
    * This message may be sent to nodes before the PartitionedRegion is completely initialized due to
-   * the RegionAdvisor(s) knowing about the existance of a partitioned region at a very early part
+   * the RegionAdvisor(s) knowing about the existence of a partitioned region at a very early part
    * of the initialization
    */
   @Override
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/tier/sockets/CacheClientNotifier.java b/geode-core/src/main/java/org/apache/geode/internal/cache/tier/sockets/CacheClientNotifier.java
index b4b15aa..43fa076 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/tier/sockets/CacheClientNotifier.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/tier/sockets/CacheClientNotifier.java
@@ -987,7 +987,7 @@ public class CacheClientNotifier {
           }
           deadProxies.add(proxy);
         }
-        this.blackListSlowReciever(proxy);
+        this.blackListSlowReceiver(proxy);
       }
     }
     checkAndRemoveFromClientMsgsRegion(conflatable);
@@ -1038,9 +1038,9 @@ public class CacheClientNotifier {
     return result;
   }
 
-  private void blackListSlowReciever(CacheClientProxy clientProxy) {
+  private void blackListSlowReceiver(CacheClientProxy clientProxy) {
     final CacheClientProxy proxy = clientProxy;
-    if ((proxy.getHARegionQueue() != null && proxy.getHARegionQueue().isClientSlowReciever())
+    if ((proxy.getHARegionQueue() != null && proxy.getHARegionQueue().isClientSlowReceiver())
         && !blackListedClients.contains(proxy.getProxyID())) {
       // log alert with client info.
       logger.warn(
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/tier/sockets/ClientHealthMonitor.java b/geode-core/src/main/java/org/apache/geode/internal/cache/tier/sockets/ClientHealthMonitor.java
index 454497f..72f4f6f 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/tier/sockets/ClientHealthMonitor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/tier/sockets/ClientHealthMonitor.java
@@ -122,7 +122,7 @@ public class ClientHealthMonitor {
 
   /**
    * Gives, version-wise, the number of clients connected to the cache servers in this cache, which
-   * are capable of processing recieved deltas.
+   * are capable of processing received deltas.
    *
    * NOTE: It does not necessarily give the actual number of clients per version connected to the
    * cache servers in this cache.
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/tier/sockets/command/GetAllForRI.java b/geode-core/src/main/java/org/apache/geode/internal/cache/tier/sockets/command/GetAllForRI.java
index 4ff7137..9d07723 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/tier/sockets/command/GetAllForRI.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/tier/sockets/command/GetAllForRI.java
@@ -23,7 +23,7 @@ import org.apache.geode.internal.cache.tier.sockets.SerializedObjectPartList;
  * form, so that they can be separated into individual values without being deserialized. The
  * standard GetAll requires us to deserialize the value of every object.
  *
- * [bruce] this class is superceded by GetAll70, which merges GetAll651 and GetAllForRI
+ * [bruce] this class is superseded by GetAll70, which merges GetAll651 and GetAllForRI
  *
  *
  */
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/tier/sockets/command/UnregisterInterest.java b/geode-core/src/main/java/org/apache/geode/internal/cache/tier/sockets/command/UnregisterInterest.java
index 791963f..2d73a6d 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/tier/sockets/command/UnregisterInterest.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/tier/sockets/command/UnregisterInterest.java
@@ -141,7 +141,7 @@ public class UnregisterInterest extends BaseCommand {
      * interest request"); writeErrorResponse(msg, MessageType.UNREGISTER_INTEREST_DATA_ERROR);
      * responded = true; } else {
      */
-    // Unregister interest irrelevent of whether the region is present it or
+    // Unregister interest irrelevant of whether the region is present it or
     // not
     serverConnection.getAcceptor().getCacheClientNotifier().unregisterClientInterest(regionName,
         key, interestType, isClosing, serverConnection.getProxyID(), keepalive);
diff --git a/geode-core/src/main/java/org/apache/geode/internal/cache/wan/AbstractGatewaySenderEventProcessor.java b/geode-core/src/main/java/org/apache/geode/internal/cache/wan/AbstractGatewaySenderEventProcessor.java
index cdf6125..47367ff 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/cache/wan/AbstractGatewaySenderEventProcessor.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/cache/wan/AbstractGatewaySenderEventProcessor.java
@@ -874,7 +874,7 @@ public abstract class AbstractGatewaySenderEventProcessor extends Thread {
       }
       if (pdxEvent.isDispatched) {
         // Dispacther does not mean that event has reched remote site. We may
-        // need to send it agian if there is porblem while recieveing ack
+        // need to send it agian if there is porblem while receiveing ack
         // containing this event.Dont add to pdxEventsToBeDispatched
         continue;
       }
diff --git a/geode-core/src/main/java/org/apache/geode/internal/datasource/AbstractPoolCache.java b/geode-core/src/main/java/org/apache/geode/internal/datasource/AbstractPoolCache.java
index dc03cf6..c2f9b90 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/datasource/AbstractPoolCache.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/datasource/AbstractPoolCache.java
@@ -145,7 +145,7 @@ public abstract class AbstractPoolCache implements ConnectionPoolCache, Serializ
       // returning their own connections
       synchronized (connectionObject) {
         if (this.activeCache.containsKey(connectionObject)) {
-          // Asif: Remove teh connection from activeCache
+          // Asif: Remove the connection from activeCache
           // Don't add it to availabel pool now. Add it when we have
           // taken a lock on availableCache & then we will modify the
           // count.
@@ -385,8 +385,8 @@ public abstract class AbstractPoolCache implements ConnectionPoolCache, Serializ
               // that destroy can be called on it.
               // We will first collect all the connections
               // which have timed out & then expire them.
-              // In that gap even if teh client genuinely closes
-              // teh connection , it will not be returned to the
+              // In that gap even if the client genuinely closes
+              // the connection , it will not be returned to the
               // pool as the active map no longer contains it
               this.activeCache.remove(conn);
               this.expiredConns.add(conn);
diff --git a/geode-core/src/main/java/org/apache/geode/internal/i18n/LocalizedStrings.java b/geode-core/src/main/java/org/apache/geode/internal/i18n/LocalizedStrings.java
index a81d5a5..ff56a07 100755
--- a/geode-core/src/main/java/org/apache/geode/internal/i18n/LocalizedStrings.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/i18n/LocalizedStrings.java
@@ -4768,8 +4768,8 @@ public class LocalizedStrings {
       new StringId(3867, "no global transaction exists");
   public static final StringId GemFireCacheImpl_STARTING_GEMFIRE_MEMCACHED_SERVER_ON_PORT_0_FOR_1_PROTOCOL =
       new StringId(3868, "Starting GemFireMemcachedServer on port {0} for {1} protocol");
-  public static final StringId TransactionManagerImpl_TRANSACTIONMANAGERIMPL_SETTRANSACTIONTIMEOUT_TRANSACTION_HAS_EITHER_EXPIRED_OR_ROLLEDBACK_OR_COMITTED =
-      new StringId(3869, "Transaction has either expired or rolledback or comitted");
+  public static final StringId TransactionManagerImpl_TRANSACTIONMANAGERIMPL_SETTRANSACTIONTIMEOUT_TRANSACTION_HAS_EITHER_EXPIRED_OR_ROLLEDBACK_OR_COMMITTED =
+      new StringId(3869, "Transaction has either expired or rolledback or committed");
   public static final StringId TransactionManagerImpl_TRANSACTIONMANAGERIMPL_RESUME_CANNOT_RESUME_A_NULL_TRANSACTION =
       new StringId(3870, "cannot resume a null transaction");
   public static final StringId AbstractDistributionConfig_SECURITY_CLIENT_DHALGO_NAME_0 =
@@ -5402,7 +5402,7 @@ public class LocalizedStrings {
       4228,
       "The maximum size in megabytes of all inactive log files combined. If this limit is exceeded, inactive log files will be deleted, oldest first, until the total size is within the limit. If set to zero, disk space usage is unlimited.");
   public static final StringId AbstractDistributionConfig_LOCATORS_NAME_0 = new StringId(4229,
-      "A possibly empty list of locators used to find other system nodes. Each element of the list must be a host name followed by bracketed, \"[]\", port number. Host names may be followed by a colon and a bind address used by the locator on that host.  Multiple elements must be comma seperated. Defaults to \"{0}\".");
+      "A possibly empty list of locators used to find other system nodes. Each element of the list must be a host name followed by bracketed, \"[]\", port number. Host names may be followed by a colon and a bind address used by the locator on that host.  Multiple elements must be comma separated. Defaults to \"{0}\".");
   public static final StringId AbstractDistributionConfig_TCP_PORT_NAME_0_1_2 = new StringId(4230,
       "The port used for tcp/ip communcations in the distributed system. If zero then a random available port is selected by the operating system.   Defaults to \"{0}\".  Legal values are in the range [{1}..{2}].");
   public static final StringId AbstractDistributionConfig_MCAST_PORT_NAME_0_1_2 = new StringId(4231,
@@ -6954,7 +6954,7 @@ public class LocalizedStrings {
 
   public static final StringId AbstractDistributionConfig_REMOTE_DISTRIBUTED_SYSTEMS_NAME_0 =
       new StringId(5185,
-          "A possibly empty list of locators used to find other distributed systems. Each element of the list must be a host name followed by bracketed, \"[]\", port number. Host names may be followed by a colon and a bind address used by the locator on that host.  Multiple elements must be comma seperated. Defaults to \"{0}\".");
+          "A possibly empty list of locators used to find other distributed systems. Each element of the list must be a host name followed by bracketed, \"[]\", port number. Host names may be followed by a colon and a bind address used by the locator on that host.  Multiple elements must be comma separated. Defaults to \"{0}\".");
   public static final StringId SerialGatewaySenderImpl_0__BECOMING_PRIMARY_GATEWAYSENDER =
       new StringId(5186, "{0} : Becoming primary gateway sender");
   public static final StringId AbstractGatewaySender_REMOTE_LOCATOR_FOR_REMOTE_SITE_0_IS_NOT_AVAILABLE_IN_LOCAL_LOCATOR_1 =
diff --git a/geode-core/src/main/java/org/apache/geode/internal/jta/TransactionManagerImpl.java b/geode-core/src/main/java/org/apache/geode/internal/jta/TransactionManagerImpl.java
index f088a5b..54cc826 100644
--- a/geode-core/src/main/java/org/apache/geode/internal/jta/TransactionManagerImpl.java
+++ b/geode-core/src/main/java/org/apache/geode/internal/jta/TransactionManagerImpl.java
@@ -614,7 +614,7 @@ public class TransactionManagerImpl implements TransactionManager, Serializable
         }
       } else {
         String exception =
-            LocalizedStrings.TransactionManagerImpl_TRANSACTIONMANAGERIMPL_SETTRANSACTIONTIMEOUT_TRANSACTION_HAS_EITHER_EXPIRED_OR_ROLLEDBACK_OR_COMITTED
+            LocalizedStrings.TransactionManagerImpl_TRANSACTIONMANAGERIMPL_SETTRANSACTIONTIMEOUT_TRANSACTION_HAS_EITHER_EXPIRED_OR_ROLLEDBACK_OR_COMMITTED
                 .toLocalizedString();
         LogWriterI18n writer = TransactionUtils.getLogWriterI18n();
         if (VERBOSE)
@@ -803,7 +803,7 @@ public class TransactionManagerImpl implements TransactionManager, Serializable
               if (lag >= 0) {
                 // Asif: Expire the GTX .Do not worry if some GTX comes
                 // before it in Map , ie
-                // even if tehre is a GTX earlier than this one to expire ,
+                // even if there is a GTX earlier than this one to expire ,
                 // it is OK
                 // to first take care of this one
                 // TODO: Do the clean up from all Maps
diff --git a/geode-core/src/main/java/org/apache/geode/management/internal/cli/GfshParser.java b/geode-core/src/main/java/org/apache/geode/management/internal/cli/GfshParser.java
index 3bc29d0..a72ee73 100755
--- a/geode-core/src/main/java/org/apache/geode/management/internal/cli/GfshParser.java
+++ b/geode-core/src/main/java/org/apache/geode/management/internal/cli/GfshParser.java
@@ -115,7 +115,7 @@ public class GfshParser extends SimpleParser {
 
     List<String> furtherSplitWithEquals = new ArrayList<>();
     for (String token : splitWithWhiteSpaces) {
-      // if this token has equal sign, split around the first occurrance of it
+      // if this token has equal sign, split around the first occurrence of it
       int indexOfFirstEqual = token.indexOf('=');
       if (indexOfFirstEqual < 0) {
         furtherSplitWithEquals.add(token);
diff --git a/geode-core/src/main/java/org/apache/geode/management/internal/cli/util/ExportLogsCacheWriter.java b/geode-core/src/main/java/org/apache/geode/management/internal/cli/util/ExportLogsCacheWriter.java
index e752ced..a54e49d 100644
--- a/geode-core/src/main/java/org/apache/geode/management/internal/cli/util/ExportLogsCacheWriter.java
+++ b/geode-core/src/main/java/org/apache/geode/management/internal/cli/util/ExportLogsCacheWriter.java
@@ -45,7 +45,7 @@ public class ExportLogsCacheWriter extends CacheWriterAdapter implements Seriali
       Object newValue = event.getNewValue();
       if (!(newValue instanceof byte[])) {
         throw new IllegalArgumentException(
-            "Value must be a byte[].  Recieved " + newValue.getClass().getCanonicalName());
+            "Value must be a byte[].  Received " + newValue.getClass().getCanonicalName());
       }
       currentOutputStream.write((byte[]) newValue);
       isEmpty = false;
diff --git a/geode-core/src/main/java/org/apache/geode/redis/internal/RedisConstants.java b/geode-core/src/main/java/org/apache/geode/redis/internal/RedisConstants.java
index 3c39c01..ad42dbb 100644
--- a/geode-core/src/main/java/org/apache/geode/redis/internal/RedisConstants.java
+++ b/geode-core/src/main/java/org/apache/geode/redis/internal/RedisConstants.java
@@ -30,7 +30,7 @@ public class RedisConstants {
    * Error responses
    */
   static final String PARSING_EXCEPTION_MESSAGE =
-      "The command recieved by GeodeRedisServer was improperly formatted";
+      "The command received by GeodeRedisServer was improperly formatted";
   static final String SERVER_ERROR_MESSAGE = "The server had an internal error please try again";
   static final String SERVER_ERROR_UNKNOWN_RESPONSE = "Unkown response";
   static final String SERVER_ERROR_SHUTDOWN = "The server is shutting down";
diff --git a/geode-core/src/test/java/com/main/MyDistributedSystemListener.java b/geode-core/src/test/java/com/main/MyDistributedSystemListener.java
index efaf5e4..fad2d25 100644
--- a/geode-core/src/test/java/com/main/MyDistributedSystemListener.java
+++ b/geode-core/src/test/java/com/main/MyDistributedSystemListener.java
@@ -26,7 +26,7 @@ import org.apache.geode.internal.cache.wan.DistributedSystemListener;
 
 /**
  * This is an implementation of DistributedSystemListener. When a addedDistributedSystem is called a
- * Region is created on both sites and GatewaySender and GatewayReciever is started on site 1 and
+ * Region is created on both sites and GatewaySender and GatewayReceiver is started on site 1 and
  * site 2 respectively.
  *
  * When a removedDistributedSystem is called, GatewaySender and GatewayReceiver is stopped on site1
diff --git a/geode-core/src/test/java/com/main/WANBootStrapping_Site2_Add.java b/geode-core/src/test/java/com/main/WANBootStrapping_Site2_Add.java
index ea6c897..3392c90 100644
--- a/geode-core/src/test/java/com/main/WANBootStrapping_Site2_Add.java
+++ b/geode-core/src/test/java/com/main/WANBootStrapping_Site2_Add.java
@@ -79,7 +79,7 @@ public class WANBootStrapping_Site2_Add {
       }
     }
 
-    // region size should be 100. This is the data which will recieve from remote site
+    // region size should be 100. This is the data which will receive from remote site
     while (region.size() != 100) {
       continue;
     }
diff --git a/geode-core/src/test/java/org/apache/geode/cache/query/dunit/QueryUsingFunctionContextDUnitTest.java b/geode-core/src/test/java/org/apache/geode/cache/query/dunit/QueryUsingFunctionContextDUnitTest.java
index 840370a..df99ad6 100644
--- a/geode-core/src/test/java/org/apache/geode/cache/query/dunit/QueryUsingFunctionContextDUnitTest.java
+++ b/geode-core/src/test/java/org/apache/geode/cache/query/dunit/QueryUsingFunctionContextDUnitTest.java
@@ -437,7 +437,7 @@ public class QueryUsingFunctionContextDUnitTest extends JUnit4CacheTestCase {
           } catch (FunctionException ex) {
             // ex.printStackTrace();
             if (!(ex.getCause() instanceof QueryInvocationTargetException)) {
-              fail("Should have received an QueryInvocationTargetException but recieved"
+              fail("Should have received an QueryInvocationTargetException but received"
                   + ex.getMessage());
             }
           }
@@ -511,11 +511,11 @@ public class QueryUsingFunctionContextDUnitTest extends JUnit4CacheTestCase {
               if (ex.getCause() instanceof FunctionException) {
                 FunctionException fe = (FunctionException) ex.getCause();
                 if (!fe.getMessage().startsWith("IOException")) {
-                  fail("Should have received an QueryInvocationTargetException but recieved"
+                  fail("Should have received an QueryInvocationTargetException but received"
                       + ex.getMessage());
                 }
               } else {
-                fail("Should have received an QueryInvocationTargetException but recieved"
+                fail("Should have received an QueryInvocationTargetException but received"
                     + ex.getMessage());
               }
             }
diff --git a/geode-core/src/test/java/org/apache/geode/cache/query/internal/NWayMergeResultsJUnitTest.java b/geode-core/src/test/java/org/apache/geode/cache/query/internal/NWayMergeResultsJUnitTest.java
index 76cb362..7db2215 100644
--- a/geode-core/src/test/java/org/apache/geode/cache/query/internal/NWayMergeResultsJUnitTest.java
+++ b/geode-core/src/test/java/org/apache/geode/cache/query/internal/NWayMergeResultsJUnitTest.java
@@ -347,7 +347,7 @@ public class NWayMergeResultsJUnitTest {
   }
 
   @Test
-  public void testOccurenceNonDistinct() throws Exception {
+  public void testOccurrenceNonDistinct() throws Exception {
     final int numSortedLists = 40;
     Collection<List<Integer>> listOfSortedLists = new ArrayList<List<Integer>>();
     for (int i = 0; i < numSortedLists; ++i) {
@@ -395,7 +395,7 @@ public class NWayMergeResultsJUnitTest {
   }
 
   @Test
-  public void testOccurenceDistinct() throws Exception {
+  public void testOccurrenceDistinct() throws Exception {
     final int numSortedLists = 40;
     Collection<List<Integer>> listOfSortedLists = new ArrayList<List<Integer>>();
     for (int i = 0; i < numSortedLists; ++i) {
diff --git a/geode-core/src/test/java/org/apache/geode/cache/query/internal/ResultsBagLimitBehaviourJUnitTest.java b/geode-core/src/test/java/org/apache/geode/cache/query/internal/ResultsBagLimitBehaviourJUnitTest.java
index b195e5d..88d87d6 100644
--- a/geode-core/src/test/java/org/apache/geode/cache/query/internal/ResultsBagLimitBehaviourJUnitTest.java
+++ b/geode-core/src/test/java/org/apache/geode/cache/query/internal/ResultsBagLimitBehaviourJUnitTest.java
@@ -59,7 +59,7 @@ public class ResultsBagLimitBehaviourJUnitTest {
   }
 
   @Test
-  public void testOccurence() {
+  public void testOccurrence() {
     ResultsBag bag = getBagObject(String.class);
     bag.add(wrap(null, bag.getCollectionType().getElementType()));
     bag.add(wrap(null, bag.getCollectionType().getElementType()));
@@ -159,10 +159,10 @@ public class ResultsBagLimitBehaviourJUnitTest {
     }
   }
 
-  // Internal method AddAndGetOccurence used for iter evaluating
+  // Internal method AddAndGetOccurrence used for iter evaluating
   // only up till the limit
   @Test
-  public void testAddAndGetOccurence() {
+  public void testAddAndGetOccurrence() {
     ResultsBag bag = getBagObject(String.class);
     bag = getBagObject(String.class);
     ObjectType elementType = bag.getCollectionType().getElementType();
@@ -247,9 +247,9 @@ public class ResultsBagLimitBehaviourJUnitTest {
     for (int i = 1; i < 5; ++i) {
       Integer intg = new Integer(i);
       if (temp.contains(wrap(intg, bag.getCollectionType().getElementType()))) {
-        int occurence = bag.occurrences(wrap(intg, bag.getCollectionType().getElementType()));
+        int occurrence = bag.occurrences(wrap(intg, bag.getCollectionType().getElementType()));
         assertTrue(bag.remove(wrap(intg, bag.getCollectionType().getElementType())));
-        assertEquals(--occurence,
+        assertEquals(--occurrence,
             bag.occurrences(wrap(intg, bag.getCollectionType().getElementType())));
         --currSize;
         assertEquals(currSize, bag.size());
@@ -258,9 +258,9 @@ public class ResultsBagLimitBehaviourJUnitTest {
       }
     }
     if (temp.contains(wrap(null, bag.getCollectionType().getElementType()))) {
-      int occurence = bag.occurrences(wrap(null, bag.getCollectionType().getElementType()));
+      int occurrence = bag.occurrences(wrap(null, bag.getCollectionType().getElementType()));
       assertTrue(bag.remove(wrap(null, bag.getCollectionType().getElementType())));
-      assertEquals(--occurence,
+      assertEquals(--occurrence,
           bag.occurrences(wrap(null, bag.getCollectionType().getElementType())));
       --currSize;
       assertEquals(currSize, bag.size());
@@ -503,18 +503,18 @@ public class ResultsBagLimitBehaviourJUnitTest {
     // Remove all the elements from the list which match the
     // first element pf the list and also
     // Get the number of occurnce of first element of List, in the bag
-    int occurence = bag.occurrences(asList.get(0));
+    int occurrence = bag.occurrences(asList.get(0));
     // Now remove the this element from the list totally
     Object toRemove = asList.get(0);
-    for (int i = 0; i < occurence; ++i) {
+    for (int i = 0; i < occurrence; ++i) {
       asList.remove(toRemove);
     }
     // So we have added one element in thje list which does not exist in the bag
-    // and removeed one element from list which exists in teh bag.
+    // and removeed one element from list which exists in the bag.
     bag.removeAll(asList);
-    assertEquals(occurence, bag.size());
+    assertEquals(occurrence, bag.size());
     Iterator itr = bag.iterator();
-    for (int i = 0; i < occurence; ++i) {
+    for (int i = 0; i < occurrence; ++i) {
       itr.next();
     }
     assertFalse(itr.hasNext());
@@ -542,18 +542,18 @@ public class ResultsBagLimitBehaviourJUnitTest {
     // Remove all the elements from the list which match the
     // first element pf the list and also
     // Get the number of occurnce of first element of List, in the bag
-    int occurence = bag.occurrences(asList.get(0));
+    int occurrence = bag.occurrences(asList.get(0));
     // Now remove the this element from the list totally
     Object toRemove = asList.get(0);
-    for (int i = 0; i < occurence; ++i) {
+    for (int i = 0; i < occurrence; ++i) {
       asList.remove(toRemove);
     }
     // So we have added one element in thje list which does not exist in the bag
-    // and removeed one element from list which exists in teh bag.
+    // and removeed one element from list which exists in the bag.
     bag.retainAll(asList);
-    assertEquals((4 - occurence), bag.size());
+    assertEquals((4 - occurrence), bag.size());
     Iterator itr = bag.iterator();
-    for (int i = 0; i < (4 - occurence); ++i) {
+    for (int i = 0; i < (4 - occurrence); ++i) {
       itr.next();
     }
     assertFalse(itr.hasNext());
@@ -580,10 +580,10 @@ public class ResultsBagLimitBehaviourJUnitTest {
     // assertIndexDetailsEquals(5,asList.size());
     // Remove all the elements from the list which match the
     // first element pf the list
-    int occurence = bag.occurrences(asList.get(0));
+    int occurrence = bag.occurrences(asList.get(0));
     // Now remove the this element from the list totally
     Object toRemove = asList.get(0);
-    for (int i = 0; i < occurence; ++i) {
+    for (int i = 0; i < occurrence; ++i) {
       asList.remove(toRemove);
     }
     assertTrue(bag.containsAll(asList));
diff --git a/geode-core/src/test/java/org/apache/geode/cache/query/internal/ResultsCollectionWrapperLimitJUnitTest.java b/geode-core/src/test/java/org/apache/geode/cache/query/internal/ResultsCollectionWrapperLimitJUnitTest.java
index 1e098c3..eddec1b 100644
--- a/geode-core/src/test/java/org/apache/geode/cache/query/internal/ResultsCollectionWrapperLimitJUnitTest.java
+++ b/geode-core/src/test/java/org/apache/geode/cache/query/internal/ResultsCollectionWrapperLimitJUnitTest.java
@@ -304,7 +304,7 @@ public class ResultsCollectionWrapperLimitJUnitTest {
   }
 
   @Test
-  public void testOccurences() {
+  public void testOccurrences() {
     Collection ordered = new TreeSet();
     for (int i = 1; i < 11; ++i) {
       ordered.add(new Integer(i));
diff --git a/geode-core/src/test/java/org/apache/geode/cache/query/internal/index/AsynchIndexMaintenanceJUnitTest.java b/geode-core/src/test/java/org/apache/geode/cache/query/internal/index/AsynchIndexMaintenanceJUnitTest.java
index 94e6a8a..ee86e57 100644
--- a/geode-core/src/test/java/org/apache/geode/cache/query/internal/index/AsynchIndexMaintenanceJUnitTest.java
+++ b/geode-core/src/test/java/org/apache/geode/cache/query/internal/index/AsynchIndexMaintenanceJUnitTest.java
@@ -79,7 +79,7 @@ public class AsynchIndexMaintenanceJUnitTest {
   }
 
   @Test
-  public void testIndexMaintenanceBasedOnThreshhold() throws Exception {
+  public void testIndexMaintenanceBasedOnThreshold() throws Exception {
     System.getProperties()
         .put(DistributionConfig.GEMFIRE_PREFIX + "AsynchIndexMaintenanceThreshold", "50");
     System.getProperties().put(DistributionConfig.GEMFIRE_PREFIX + "AsynchIndexMaintenanceInterval",
diff --git a/geode-core/src/test/java/org/apache/geode/cache/query/internal/index/ConcurrentIndexInitOnOverflowRegionDUnitTest.java b/geode-core/src/test/java/org/apache/geode/cache/query/internal/index/ConcurrentIndexInitOnOverflowRegionDUnitTest.java
index e55308e..e0fab8c 100644
--- a/geode-core/src/test/java/org/apache/geode/cache/query/internal/index/ConcurrentIndexInitOnOverflowRegionDUnitTest.java
+++ b/geode-core/src/test/java/org/apache/geode/cache/query/internal/index/ConcurrentIndexInitOnOverflowRegionDUnitTest.java
@@ -375,7 +375,7 @@ public class ConcurrentIndexInitOnOverflowRegionDUnitTest extends JUnit4CacheTes
         switch (spot) {
           case 6: // processAction in IndexManager
             hooked = true;
-            // wait untill some thread unhooks.
+            // wait until some thread unhooks.
             while (hooked) {
               Wait.pause(20);
             }
diff --git a/geode-core/src/test/java/org/apache/geode/cache/query/partitioned/PRQueryDUnitHelper.java b/geode-core/src/test/java/org/apache/geode/cache/query/partitioned/PRQueryDUnitHelper.java
index d70b9c3..2cd5dc1 100755
--- a/geode-core/src/test/java/org/apache/geode/cache/query/partitioned/PRQueryDUnitHelper.java
+++ b/geode-core/src/test/java/org/apache/geode/cache/query/partitioned/PRQueryDUnitHelper.java
@@ -1686,7 +1686,7 @@ public class PRQueryDUnitHelper implements Serializable {
            * " + "buckets indexed should be equal",
            * ((PartitionedRegion)region).getTotalNumberOfBuckets(),
            * (((PartionedIndex)parIndex).getNumberOfIndexedBucket()+((PartionedIndex)parIndex).
-           * getNumRemtoeBucketsIndexed())); should put all the assetion in a seperate function.
+           * getNumRemtoeBucketsIndexed())); should put all the assetion in a separate function.
            */
         } catch (Exception ex) {
           Assert.fail("Creating Index in this vm failed : ", ex);
diff --git a/geode-core/src/test/java/org/apache/geode/cache30/CacheMapTxnDUnitTest.java b/geode-core/src/test/java/org/apache/geode/cache30/CacheMapTxnDUnitTest.java
index a0fccf9..1ac1e32 100644
--- a/geode-core/src/test/java/org/apache/geode/cache30/CacheMapTxnDUnitTest.java
+++ b/geode-core/src/test/java/org/apache/geode/cache30/CacheMapTxnDUnitTest.java
@@ -156,7 +156,7 @@ public class CacheMapTxnDUnitTest extends JUnit4DistributedTestCase { // TODO: r
                                                                                            // same
                                                                                            // vm but
                                                                                            // in
-                                                                                           // seperate
+                                                                                           // separate
                                                                                            // thread
     AsyncInvocation o3 = vm1.invokeAsync(() -> CacheMapTxnDUnitTest.miscMethodsNotOwner());// invoke
                                                                                            // in
diff --git a/geode-core/src/test/java/org/apache/geode/internal/cache/ClientServerInvalidAndDestroyedEntryDUnitTest.java b/geode-core/src/test/java/org/apache/geode/internal/cache/ClientServerInvalidAndDestroyedEntryDUnitTest.java
index c19412b..31d88d0 100755
--- a/geode-core/src/test/java/org/apache/geode/internal/cache/ClientServerInvalidAndDestroyedEntryDUnitTest.java
+++ b/geode-core/src/test/java/org/apache/geode/internal/cache/ClientServerInvalidAndDestroyedEntryDUnitTest.java
@@ -184,7 +184,7 @@ public class ClientServerInvalidAndDestroyedEntryDUnitTest extends JUnit4CacheTe
     // in the client. All of these keys hash to bucket 0 in a two-bucket PR
     // except Object11 and IDoNotExist1
     final String notAffectedKey = "Object1";
-    final String nonexistantKey = (usePR && useTX) ? "IDoNotExist2" : "IDoNotExist1";
+    final String nonexistentKey = (usePR && useTX) ? "IDoNotExist2" : "IDoNotExist1";
     final String key1 = "Object10";
     final String key2 = (usePR && useTX) ? "Object12" : "Object11";
 
@@ -224,8 +224,8 @@ public class ClientServerInvalidAndDestroyedEntryDUnitTest extends JUnit4CacheTe
     assertTrue(myRegion.containsKey(key2));
 
     // now try a key that doesn't exist anywhere
-    assertNull(myRegion.get(nonexistantKey));
-    assertFalse(myRegion.containsKey(nonexistantKey));
+    assertNull(myRegion.get(nonexistentKey));
+    assertFalse(myRegion.containsKey(nonexistentKey));
 
     if (useTX) {
       c.getCacheTransactionManager().commit();
@@ -305,7 +305,7 @@ public class ClientServerInvalidAndDestroyedEntryDUnitTest extends JUnit4CacheTe
     // in the client. All of these keys hash to bucket 0 in a two-bucket PR
     // except Object11 and IDoNotExist1
     final String notAffectedKey = "Object1";
-    final String nonexistantKey = (usePR && useTX) ? "IDoNotExist2" : "IDoNotExist1";
+    final String nonexistentKey = (usePR && useTX) ? "IDoNotExist2" : "IDoNotExist1";
     final String key1 = "Object10";
     final String key2 = (usePR && useTX) ? "Object12" : "Object11";
 
@@ -355,8 +355,8 @@ public class ClientServerInvalidAndDestroyedEntryDUnitTest extends JUnit4CacheTe
 
 
     // now try a key that doesn't exist anywhere
-    assertNull(myRegion.get(nonexistantKey));
-    assertFalse(myRegion.containsKey(nonexistantKey));
+    assertNull(myRegion.get(nonexistentKey));
+    assertFalse(myRegion.containsKey(nonexistentKey));
 
     if (useTX) {
       c.getCacheTransactionManager().commit();
diff --git a/geode-core/src/test/java/org/apache/geode/internal/cache/DeltaPropagationDUnitTest.java b/geode-core/src/test/java/org/apache/geode/internal/cache/DeltaPropagationDUnitTest.java
index f81b1f0..ff7c78d 100755
--- a/geode-core/src/test/java/org/apache/geode/internal/cache/DeltaPropagationDUnitTest.java
+++ b/geode-core/src/test/java/org/apache/geode/internal/cache/DeltaPropagationDUnitTest.java
@@ -604,7 +604,7 @@ public class DeltaPropagationDUnitTest extends JUnit4DistributedTestCase {
 
     /**
      * 1. Create a cache server with slow dispatcher 2. Start a durable client with a custom cache
-     * listener which shuts itself down as soon as it recieves a marker message. 3. Do some puts on
+     * listener which shuts itself down as soon as it receives a marker message. 3. Do some puts on
      * the server region 4. Let the dispatcher start dispatching 5. Verify that durable client is
      * disconnected as soon as it processes the marker. Server will retain its queue which has some
      * events (containing deltas) in it. 6. Restart the durable client without the self-destructing
diff --git a/geode-core/src/test/java/org/apache/geode/internal/cache/DeltaPropagationStatsDUnitTest.java b/geode-core/src/test/java/org/apache/geode/internal/cache/DeltaPropagationStatsDUnitTest.java
index 12817df..9a0454b 100755
--- a/geode-core/src/test/java/org/apache/geode/internal/cache/DeltaPropagationStatsDUnitTest.java
+++ b/geode-core/src/test/java/org/apache/geode/internal/cache/DeltaPropagationStatsDUnitTest.java
@@ -416,7 +416,7 @@ public class DeltaPropagationStatsDUnitTest extends JUnit4DistributedTestCase {
         } catch (InvalidDeltaException ide) {
           assertTrue("InvalidDeltaException not expected.",
               delta.getIntVar() == DeltaTestImpl.ERRONEOUS_INT_FOR_TO_DELTA);
-          cache.getLoggerI18n().fine("Recieved InvalidDeltaException as expected.");
+          cache.getLoggerI18n().fine("Received InvalidDeltaException as expected.");
         }
       }
     }
diff --git a/geode-core/src/test/java/org/apache/geode/internal/cache/DiskRegCachexmlGeneratorJUnitTest.java b/geode-core/src/test/java/org/apache/geode/internal/cache/DiskRegCachexmlGeneratorJUnitTest.java
index 6b92547..fd5ead0 100644
--- a/geode-core/src/test/java/org/apache/geode/internal/cache/DiskRegCachexmlGeneratorJUnitTest.java
+++ b/geode-core/src/test/java/org/apache/geode/internal/cache/DiskRegCachexmlGeneratorJUnitTest.java
@@ -34,7 +34,7 @@ import org.apache.geode.test.junit.categories.IntegrationTest;
 
 /**
  * This test is for testing Disk attributes set programmatically The generated cacheXml is used to
- * create a cache and teh region properties retested.
+ * create a cache and the region properties retested.
  */
 @Category(IntegrationTest.class)
 public class DiskRegCachexmlGeneratorJUnitTest extends DiskRegionTestingBase {
diff --git a/geode-core/src/test/java/org/apache/geode/internal/cache/DiskRegRecoveryJUnitTest.java b/geode-core/src/test/java/org/apache/geode/internal/cache/DiskRegRecoveryJUnitTest.java
index fe7f5f5..d7c6462 100644
--- a/geode-core/src/test/java/org/apache/geode/internal/cache/DiskRegRecoveryJUnitTest.java
+++ b/geode-core/src/test/java/org/apache/geode/internal/cache/DiskRegRecoveryJUnitTest.java
@@ -756,7 +756,7 @@ public class DiskRegRecoveryJUnitTest extends DiskRegionTestingBase {
   }
 
   /**
-   * This tests the case where potential of writing a dummy byte was tehre. The case would be
+   * This tests the case where potential of writing a dummy byte was there. The case would be
    * compactor terminating early. The create is present in both Htree as well as Oplog. When
    * recovery is done, the create is added to the Oplog createdEntrySet. Now while compactor
    * iterates over the entries in the region, it skips the created entry because its Htree Offset is
diff --git a/geode-core/src/test/java/org/apache/geode/internal/cache/FaultingInJUnitTest.java b/geode-core/src/test/java/org/apache/geode/internal/cache/FaultingInJUnitTest.java
index 25afb1b..2d64b71 100755
--- a/geode-core/src/test/java/org/apache/geode/internal/cache/FaultingInJUnitTest.java
+++ b/geode-core/src/test/java/org/apache/geode/internal/cache/FaultingInJUnitTest.java
@@ -48,7 +48,7 @@ public class FaultingInJUnitTest extends DiskRegionTestingBase {
   }
 
   /**
-   * fault in a value from teh current oplog
+   * fault in a value from the current oplog
    */
   private void faultInFromCurrentOplog() {
     put100Int();
diff --git a/geode-core/src/test/java/org/apache/geode/internal/cache/OplogJUnitTest.java b/geode-core/src/test/java/org/apache/geode/internal/cache/OplogJUnitTest.java
index e5491b0..63a73e0 100755
--- a/geode-core/src/test/java/org/apache/geode/internal/cache/OplogJUnitTest.java
+++ b/geode-core/src/test/java/org/apache/geode/internal/cache/OplogJUnitTest.java
@@ -405,7 +405,7 @@ public class OplogJUnitTest extends DiskRegionTestingBase {
 
     region = DiskRegionHelperFactory.getSyncPersistOnlyRegion(cache, diskProps, Scope.LOCAL);
     DiskRegion dr = ((LocalRegion) region).getDiskRegion();
-    // Populate data just below the switch over threshhold
+    // Populate data just below the switch over threshold
     byte[] val = new byte[5];
     for (int i = 0; i < val.length; ++i) {
       val[i] = (byte) i;
diff --git a/geode-core/src/test/java/org/apache/geode/internal/cache/PartitionedRegionSingleNodeOperationsJUnitTest.java b/geode-core/src/test/java/org/apache/geode/internal/cache/PartitionedRegionSingleNodeOperationsJUnitTest.java
index d14748b..23db6e1 100644
--- a/geode-core/src/test/java/org/apache/geode/internal/cache/PartitionedRegionSingleNodeOperationsJUnitTest.java
+++ b/geode-core/src/test/java/org/apache/geode/internal/cache/PartitionedRegionSingleNodeOperationsJUnitTest.java
@@ -54,7 +54,7 @@ import org.apache.geode.test.junit.categories.IntegrationTest;
 /**
  * Test for Partitioned Region operations on a single node. Following tests are included:
  * <P>
- * (1) testPut() - Tests teh put() functionality for the partitioned region.
+ * (1) testPut() - Tests the put() functionality for the partitioned region.
  * </P>
  *
  *
diff --git a/geode-core/src/test/java/org/apache/geode/internal/cache/backup/BackupFileCopierIntegrationTest.java b/geode-core/src/test/java/org/apache/geode/internal/cache/backup/BackupFileCopierIntegrationTest.java
index 35fb6ac..8a97aa6 100644
--- a/geode-core/src/test/java/org/apache/geode/internal/cache/backup/BackupFileCopierIntegrationTest.java
+++ b/geode-core/src/test/java/org/apache/geode/internal/cache/backup/BackupFileCopierIntegrationTest.java
@@ -89,7 +89,7 @@ public class BackupFileCopierIntegrationTest {
   @Test
   public void configFilesNotCreatedIfDoNotExist() throws IOException {
     System.setProperty(DistributedSystem.PROPERTIES_FILE_PROPERTY,
-        tempFolder.getRoot().getAbsolutePath() + "/nonexistant");
+        tempFolder.getRoot().getAbsolutePath() + "/nonexistent");
     fileCopier.copyConfigFiles();
     Path cacheXmlDestination = tempFilesLocation.resolve(CONFIG_DIRECTORY).resolve(CACHE_XML);
     assertThat(cacheXmlDestination).doesNotExist();
diff --git a/geode-core/src/test/java/org/apache/geode/internal/cache/ha/BlockingHARegionJUnitTest.java b/geode-core/src/test/java/org/apache/geode/internal/cache/ha/BlockingHARegionJUnitTest.java
index 134cd78..233b3a1 100755
--- a/geode-core/src/test/java/org/apache/geode/internal/cache/ha/BlockingHARegionJUnitTest.java
+++ b/geode-core/src/test/java/org/apache/geode/internal/cache/ha/BlockingHARegionJUnitTest.java
@@ -39,7 +39,7 @@ public class BlockingHARegionJUnitTest {
 
   private static InternalCache cache = null;
 
-  /** boolean to record an exception occurence in another thread **/
+  /** boolean to record an exception occurrence in another thread **/
   private static volatile boolean exceptionOccurred = false;
   /** StringBuffer to store the exception **/
   private static StringBuffer exceptionString = new StringBuffer();
diff --git a/geode-core/src/test/java/org/apache/geode/internal/cache/ha/EventIdOptimizationDUnitTest.java b/geode-core/src/test/java/org/apache/geode/internal/cache/ha/EventIdOptimizationDUnitTest.java
index b408844..12c3c2d 100755
--- a/geode-core/src/test/java/org/apache/geode/internal/cache/ha/EventIdOptimizationDUnitTest.java
+++ b/geode-core/src/test/java/org/apache/geode/internal/cache/ha/EventIdOptimizationDUnitTest.java
@@ -66,7 +66,7 @@ import org.apache.geode.test.junit.categories.DistributedTest;
  * sequenceId need not be sent as long if their value is small. This test has two servers and two
  * clients , each connected to one server. The events with event-ids having specific values for
  * thread-id and sequence-id are generated by client-1 and sent to server-1 and then to server-2 via
- * p2p and then finally to client-2. It is verified that client-2 recieves the same values for
+ * p2p and then finally to client-2. It is verified that client-2 receives the same values for
  * thread-id and sequence-id.
  */
 @Category({DistributedTest.class, ClientSubscriptionTest.class})
@@ -414,7 +414,7 @@ public class EventIdOptimizationDUnitTest extends JUnit4DistributedTestCase {
     LogWriterUtils.getLogWriter().info("Starting validation on client2");
     if (validationFailed) {
       fail(
-          "\n The following eventIds recieved by client2 were not present in the eventId array sent by client1 \n"
+          "\n The following eventIds received by client2 were not present in the eventId array sent by client1 \n"
               + failureMsg);
     }
     LogWriterUtils.getLogWriter()
diff --git a/geode-core/src/test/java/org/apache/geode/internal/cache/ha/HAEventIdPropagationDUnitTest.java b/geode-core/src/test/java/org/apache/geode/internal/cache/ha/HAEventIdPropagationDUnitTest.java
index 189ee43..daed2d0 100755
--- a/geode-core/src/test/java/org/apache/geode/internal/cache/ha/HAEventIdPropagationDUnitTest.java
+++ b/geode-core/src/test/java/org/apache/geode/internal/cache/ha/HAEventIdPropagationDUnitTest.java
@@ -617,7 +617,7 @@ public class HAEventIdPropagationDUnitTest extends JUnit4DistributedTestCase {
   }
 
   /**
-   * Listener which sends a notification after create to waiting threads and also extracts teh event
+   * Listener which sends a notification after create to waiting threads and also extracts the event
    * id storing it in a static variable
    */
   static class HAEventIdPropagationListenerForClient extends CacheListenerAdapter {
@@ -702,7 +702,7 @@ public class HAEventIdPropagationDUnitTest extends JUnit4DistributedTestCase {
   }
 
   /**
-   * Listener which sends a notification after create to waiting threads and also extracts teh event
+   * Listener which sends a notification after create to waiting threads and also extracts the event
    * id storing it in a static variable
    */
   static class HAEventIdPropagationListenerForServer extends CacheListenerAdapter {
diff --git a/geode-core/src/test/java/org/apache/geode/internal/cache/ha/HARegionDUnitTest.java b/geode-core/src/test/java/org/apache/geode/internal/cache/ha/HARegionDUnitTest.java
index 0004539..93ec1ce 100755
--- a/geode-core/src/test/java/org/apache/geode/internal/cache/ha/HARegionDUnitTest.java
+++ b/geode-core/src/test/java/org/apache/geode/internal/cache/ha/HARegionDUnitTest.java
@@ -139,7 +139,7 @@ public class HARegionDUnitTest extends JUnit4DistributedTestCase {
   }
 
   /**
-   * 1) Create mirrored HARegion region1 in VM1 2) do a put in VM1 3) get teh value in VM1 to assert
+   * 1) Create mirrored HARegion region1 in VM1 2) do a put in VM1 3) get the value in VM1 to assert
    * put has happened successfully 4) Create mirrored HARegion region1 in VM2 5) do a get in VM2 to
    * verify that value was got through GII 6) do a put in VM2 7) assert put in VM2 was successful
    *
@@ -157,7 +157,7 @@ public class HARegionDUnitTest extends JUnit4DistributedTestCase {
   }
 
   /**
-   * 1) Create mirrored HARegion region1 in VM1 2) do a put in VM1 3) get teh value in VM1 to assert
+   * 1) Create mirrored HARegion region1 in VM1 2) do a put in VM1 3) get the value in VM1 to assert
    * put has happened successfully 4) Create mirrored HARegion region1 in VM2 5) do a get in VM2 to
    * verify that value was got through GII 6) do a put in VM2 7) assert put in VM2 was successful
    *
@@ -188,7 +188,7 @@ public class HARegionDUnitTest extends JUnit4DistributedTestCase {
   }
 
   /**
-   * 1) Create mirrored HARegion region1 in VM1 2) do a put in VM1 3) get teh value in VM1 to assert
+   * 1) Create mirrored HARegion region1 in VM1 2) do a put in VM1 3) get the value in VM1 to assert
    * put has happened successfully 4) Create mirrored HARegion region1 in VM2 5) do a get in VM2 to
    * verify that value was got through GII 6) do a put in VM2 7) assert put in VM2 was successful
    *
diff --git a/geode-core/src/test/java/org/apache/geode/internal/cache/ha/HARegionQueueDUnitTest.java b/geode-core/src/test/java/org/apache/geode/internal/cache/ha/HARegionQueueDUnitTest.java
index 78db217..db05a60 100755
--- a/geode-core/src/test/java/org/apache/geode/internal/cache/ha/HARegionQueueDUnitTest.java
+++ b/geode-core/src/test/java/org/apache/geode/internal/cache/ha/HARegionQueueDUnitTest.java
@@ -161,7 +161,7 @@ public class HARegionQueueDUnitTest extends JUnit4DistributedTestCase {
   }
 
   /**
-   * 1) Create mirrored HARegion region1 in VM1 2) do a put in VM1 3) get teh value in VM1 to assert
+   * 1) Create mirrored HARegion region1 in VM1 2) do a put in VM1 3) get the value in VM1 to assert
    * put has happened successfully 4) Create mirrored HARegion region1 in VM2 5) do a get in VM2 to
    * verify that value was got through GII 6) do a put in VM2 7) assert put in VM2 was successful
    */
@@ -177,7 +177,7 @@ public class HARegionQueueDUnitTest extends JUnit4DistributedTestCase {
   }
 
   /**
-   * 1) Create mirrored HARegion region1 in VM1 2) do a put in VM1 3) get teh value in VM1 to assert
+   * 1) Create mirrored HARegion region1 in VM1 2) do a put in VM1 3) get the value in VM1 to assert
    * put has happened successfully 4) Create mirrored HARegion region1 in VM2 5) do a get in VM2 to
    * verify that value was got through GII 6) do a put in VM2 7) assert put in VM2 was successful
    */
diff --git a/geode-core/src/test/java/org/apache/geode/internal/cache/ha/HASlowReceiverDUnitTest.java b/geode-core/src/test/java/org/apache/geode/internal/cache/ha/HASlowReceiverDUnitTest.java
index bfd5c4f..d3d573a 100755
--- a/geode-core/src/test/java/org/apache/geode/internal/cache/ha/HASlowReceiverDUnitTest.java
+++ b/geode-core/src/test/java/org/apache/geode/internal/cache/ha/HASlowReceiverDUnitTest.java
@@ -162,7 +162,7 @@ public class HASlowReceiverDUnitTest extends JUnit4DistributedTestCase {
         .addServer("localhost", port2).addServer("localhost", port3).setSubscriptionEnabled(true)
         .setSubscriptionRedundancy(rLevel.intValue()).setThreadLocalConnections(true)
         .setMinConnections(6).setReadTimeout(20000).setPingInterval(1000).setRetryAttempts(5)
-        .create("HASlowRecieverDUnitTestPool");
+        .create("HASlowReceiverDUnitTestPool");
 
     factory.setScope(Scope.LOCAL);
     factory.setPoolName(p.getName());
diff --git a/geode-core/src/test/java/org/apache/geode/internal/cache/ha/OperationsPropagationDUnitTest.java b/geode-core/src/test/java/org/apache/geode/internal/cache/ha/OperationsPropagationDUnitTest.java
index 30d97f9..26d919a 100755
--- a/geode-core/src/test/java/org/apache/geode/internal/cache/ha/OperationsPropagationDUnitTest.java
+++ b/geode-core/src/test/java/org/apache/geode/internal/cache/ha/OperationsPropagationDUnitTest.java
@@ -100,7 +100,7 @@ public class OperationsPropagationDUnitTest extends JUnit4DistributedTestCase {
   }
 
   /**
-   * closes the cache and disconnects the vm from teh distributed system
+   * closes the cache and disconnects the vm from the distributed system
    */
   public static void closeCache() {
     if (cache != null && !cache.isClosed()) {
diff --git a/geode-core/src/test/java/org/apache/geode/internal/cache/ha/PutAllDUnitTest.java b/geode-core/src/test/java/org/apache/geode/internal/cache/ha/PutAllDUnitTest.java
index 52a5a5a..7992f35 100755
--- a/geode-core/src/test/java/org/apache/geode/internal/cache/ha/PutAllDUnitTest.java
+++ b/geode-core/src/test/java/org/apache/geode/internal/cache/ha/PutAllDUnitTest.java
@@ -462,7 +462,7 @@ public class PutAllDUnitTest extends JUnit4DistributedTestCase {
   }
 
   /**
-   * Listener which sends a notification after create to waiting threads and also extracts teh event
+   * Listener which sends a notification after create to waiting threads and also extracts the event
    * id storing it in a static variable
    *
    */
@@ -507,7 +507,7 @@ public class PutAllDUnitTest extends JUnit4DistributedTestCase {
   }
 
   /**
-   * Listener which sends a notification after create to waiting threads and also extracts teh event
+   * Listener which sends a notification after create to waiting threads and also extracts the event
    * ids storing them in static variables
    *
    */
diff --git a/geode-core/src/test/java/org/apache/geode/internal/cache/ha/TestBlockingHARegionQueue.java b/geode-core/src/test/java/org/apache/geode/internal/cache/ha/TestBlockingHARegionQueue.java
index 2bc8724..be764b7 100755
--- a/geode-core/src/test/java/org/apache/geode/internal/cache/ha/TestBlockingHARegionQueue.java
+++ b/geode-core/src/test/java/org/apache/geode/internal/cache/ha/TestBlockingHARegionQueue.java
@@ -70,7 +70,7 @@ public class TestBlockingHARegionQueue extends HARegionQueue.TestOnlyHARegionQue
   }
 
   /**
-   * blocking peek. This method will not return till it has acquired a legitimate object from teh
+   * blocking peek. This method will not return till it has acquired a legitimate object from the
    * queue.
    *
    */
diff --git a/geode-core/src/test/java/org/apache/geode/internal/cache/partitioned/PersistentPartitionedRegionDUnitTest.java b/geode-core/src/test/java/org/apache/geode/internal/cache/partitioned/PersistentPartitionedRegionDUnitTest.java
index 168a42c..7534616 100644
--- a/geode-core/src/test/java/org/apache/geode/internal/cache/partitioned/PersistentPartitionedRegionDUnitTest.java
+++ b/geode-core/src/test/java/org/apache/geode/internal/cache/partitioned/PersistentPartitionedRegionDUnitTest.java
@@ -467,7 +467,7 @@ public class PersistentPartitionedRegionDUnitTest extends PersistentPartitionedR
         IgnoredException.addIgnoredException(RevokedPersistentDataException.class.getName(), vm1);
     try {
       createPR(vm1, 1);
-      fail("Should have recieved a SplitDistributedSystemException");
+      fail("Should have received a SplitDistributedSystemException");
     } catch (RMIException e) {
       // This should throw a split distributed system exception, because
       // We revoked this member.
@@ -540,7 +540,7 @@ public class PersistentPartitionedRegionDUnitTest extends PersistentPartitionedR
         IgnoredException.addIgnoredException(RevokedPersistentDataException.class.getName(), vm1);
     try {
       createPR(vm1, 1);
-      fail("Should have recieved a SplitDistributedSystemException");
+      fail("Should have received a SplitDistributedSystemException");
     } catch (RMIException e) {
       // This should throw a split distributed system exception, because
       // We revoked this member.
@@ -903,7 +903,7 @@ public class PersistentPartitionedRegionDUnitTest extends PersistentPartitionedR
         IgnoredException.addIgnoredException(RevokedPersistentDataException.class.getName(), vm1);
     try {
       createPR(vm1, 0);
-      fail("Should have recieved a RevokedPersistentDataException");
+      fail("Should have received a RevokedPersistentDataException");
     } catch (RMIException e) {
       // This should throw a split distributed system exception, because
       // We revoked this member.
@@ -953,7 +953,7 @@ public class PersistentPartitionedRegionDUnitTest extends PersistentPartitionedR
         IgnoredException.addIgnoredException(RevokedPersistentDataException.class.getName(), vm1);
     try {
       createPR(vm1, 1);
-      fail("Should have recieved a SplitDistributedSystemException");
+      fail("Should have received a SplitDistributedSystemException");
     } catch (RMIException e) {
       // This should throw a RevokedPersistentDataException exception, because
       // We revoked this member.
@@ -975,7 +975,7 @@ public class PersistentPartitionedRegionDUnitTest extends PersistentPartitionedR
 
     try {
       createPR(vm1, 1);
-      fail("Should have recieved a RevokedPersistentDataException");
+      fail("Should have received a RevokedPersistentDataException");
     } catch (RMIException e) {
       // This should throw a RevokedPersistentDataException exception, because
       // We revoked this member.
diff --git a/geode-core/src/test/java/org/apache/geode/internal/cache/tier/sockets/Bug36269DUnitTest.java b/geode-core/src/test/java/org/apache/geode/internal/cache/tier/sockets/Bug36269DUnitTest.java
index 65c4611..f041a1d 100644
--- a/geode-core/src/test/java/org/apache/geode/internal/cache/tier/sockets/Bug36269DUnitTest.java
+++ b/geode-core/src/test/java/org/apache/geode/internal/cache/tier/sockets/Bug36269DUnitTest.java
@@ -50,7 +50,7 @@ import org.apache.geode.test.junit.categories.DistributedTest;
 /**
  * The Region Destroy Operation from Cache Client does not pass the Client side Context object nor
  * does the p2p messaging has provision of sending Context object in the DestroyRegionMessage. This
- * can cause sender to recieve it own region destruction message.
+ * can cause sender to receive it own region destruction message.
  */
 @Category({DistributedTest.class, ClientServerTest.class})
 public class Bug36269DUnitTest extends JUnit4DistributedTestCase {
diff --git a/geode-core/src/test/java/org/apache/geode/internal/cache/tier/sockets/Bug36805DUnitTest.java b/geode-core/src/test/java/org/apache/geode/internal/cache/tier/sockets/Bug36805DUnitTest.java
index 3a75ed4..3e0f2ac 100755
--- a/geode-core/src/test/java/org/apache/geode/internal/cache/tier/sockets/Bug36805DUnitTest.java
+++ b/geode-core/src/test/java/org/apache/geode/internal/cache/tier/sockets/Bug36805DUnitTest.java
@@ -224,7 +224,7 @@ public class Bug36805DUnitTest extends JUnit4DistributedTestCase {
     // + " but it is: " + proxy.getDeadServers().size()
     // + ". This issue can occur on Solaris as DSM thread get stuck in connectForServer() call, and
     // hence not recovering any newly started server This may be beacuase of tcp_ip_abort_cinterval
-    // kernal level property on solaris which has 3 minutes as a default value",
+    // kernel level property on solaris which has 3 minutes as a default value",
     // (System.currentTimeMillis() - start) < maxWaitTime);
     // try {
     // Thread.yield();
diff --git a/geode-core/src/test/java/org/apache/geode/internal/cache/tier/sockets/InterestListEndpointDUnitTest.java b/geode-core/src/test/java/org/apache/geode/internal/cache/tier/sockets/InterestListEndpointDUnitTest.java
index e98c87e..da325e2 100755
--- a/geode-core/src/test/java/org/apache/geode/internal/cache/tier/sockets/InterestListEndpointDUnitTest.java
+++ b/geode-core/src/test/java/org/apache/geode/internal/cache/tier/sockets/InterestListEndpointDUnitTest.java
@@ -118,7 +118,7 @@ public class InterestListEndpointDUnitTest extends JUnit4DistributedTestCase {
   }
 
   /**
-   * tests wheteher upadets are sent to clients if put on server directly
+   * tests whetheer upadets are sent to clients if put on server directly
    *
    */
   @Test
diff --git a/geode-core/src/test/java/org/apache/geode/internal/cache/tier/sockets/RedundancyLevelPart3DUnitTest.java b/geode-core/src/test/java/org/apache/geode/internal/cache/tier/sockets/RedundancyLevelPart3DUnitTest.java
index 6bf9132..bd8415d 100755
--- a/geode-core/src/test/java/org/apache/geode/internal/cache/tier/sockets/RedundancyLevelPart3DUnitTest.java
+++ b/geode-core/src/test/java/org/apache/geode/internal/cache/tier/sockets/RedundancyLevelPart3DUnitTest.java
@@ -41,7 +41,7 @@ public class RedundancyLevelPart3DUnitTest extends RedundancyLevelTestBase {
   }
 
   /**
-   * This tests failing of a primary server in a situation where teh rest of the server are all
+   * This tests failing of a primary server in a situation where the rest of the server are all
    * redundant. After every failure, the order, the dispatcher, the interest registration and the
    * makePrimary calls are verified. The failure detection in these tests could be either through
    * CCU or cache operation, whichever occurs first
@@ -194,7 +194,7 @@ public class RedundancyLevelPart3DUnitTest extends RedundancyLevelTestBase {
   }
 
   /**
-   * This tests failing of a primary server in a situation where only one of the rest of teh servers
+   * This tests failing of a primary server in a situation where only one of the rest of the servers
    * is redundant. After every failure, the order, the dispatcher, the interest registration and the
    * makePrimary calls are verified. The failure detection in these tests could be either through
    * CCU or cache operation, whichever occurs first
diff --git a/geode-cq/src/test/java/org/apache/geode/internal/cache/PRDeltaPropagationDUnitTest.java b/geode-cq/src/test/java/org/apache/geode/internal/cache/PRDeltaPropagationDUnitTest.java
index 9bbbfa6..ad2cd3b 100755
--- a/geode-cq/src/test/java/org/apache/geode/internal/cache/PRDeltaPropagationDUnitTest.java
+++ b/geode-cq/src/test/java/org/apache/geode/internal/cache/PRDeltaPropagationDUnitTest.java
@@ -1079,7 +1079,7 @@ public class PRDeltaPropagationDUnitTest extends DistributedTestCase {
     return queryDestroyExecuted;
   }
 
-  public boolean checkVMRecievesDeltaObjectThrCQListner() {
+  public boolean checkVMReceivesDeltaObjectThrCQListner() {
     return notADeltaInstanceObj;
   }
 
diff --git a/geode-cq/src/test/java/org/apache/geode/internal/cache/tier/sockets/DurableClientTestCase.java b/geode-cq/src/test/java/org/apache/geode/internal/cache/tier/sockets/DurableClientTestCase.java
index aae6b2d..f897a9c 100755
--- a/geode-cq/src/test/java/org/apache/geode/internal/cache/tier/sockets/DurableClientTestCase.java
+++ b/geode-cq/src/test/java/org/apache/geode/internal/cache/tier/sockets/DurableClientTestCase.java
@@ -1692,7 +1692,7 @@ public class DurableClientTestCase extends JUnit4DistributedTestCase {
    */
   protected static boolean checkForAck(CacheClientProxy proxy) {
     // pause(5000);
-    return HARegionQueue.isTestMarkerMessageRecieved();
+    return HARegionQueue.isTestMarkerMessageReceived();
   }
 
   protected static void setTestFlagToVerifyActForMarker(Boolean flag) {
diff --git a/geode-old-versions/src/test/java/org/apache/geode/test/dunit/standalone/VersionManagerJUnitTest.java b/geode-old-versions/src/test/java/org/apache/geode/test/dunit/standalone/VersionManagerJUnitTest.java
index 9982e5f..ed71071 100755
--- a/geode-old-versions/src/test/java/org/apache/geode/test/dunit/standalone/VersionManagerJUnitTest.java
+++ b/geode-old-versions/src/test/java/org/apache/geode/test/dunit/standalone/VersionManagerJUnitTest.java
@@ -29,14 +29,14 @@ public class VersionManagerJUnitTest {
   @Test
   public void exceptionIsNotThrownInInitialization() throws Exception {
     VersionManager instance =
-        VersionManager.getInstance("--nonexistant-file?--", "--nonexistant-install-file--");
+        VersionManager.getInstance("--nonexistent-file?--", "--nonexistent-install-file--");
     Assert.assertNotEquals("", instance.loadFailure);
   }
 
   @Test
   public void exceptionIsThrownOnUse() throws Exception {
     VersionManager instance =
-        VersionManager.getInstance("--nonexistant-file?--", "--nonexistant-install-file--");
+        VersionManager.getInstance("--nonexistent-file?--", "--nonexistent-install-file--");
     Assert.assertNotEquals("", instance.loadFailure);
     assertThatThrownBy(() -> instance.getVersionsWithoutCurrent()).hasMessage(instance.loadFailure);
     assertThatThrownBy(() -> instance.getVersions()).hasMessage(instance.loadFailure);
diff --git a/geode-pulse/src/main/webapp/clusterDetail.html b/geode-pulse/src/main/webapp/clusterDetail.html
index c74299d..dd64fca 100644
--- a/geode-pulse/src/main/webapp/clusterDetail.html
+++ b/geode-pulse/src/main/webapp/clusterDetail.html
@@ -117,12 +117,12 @@
 		</div>
         </div>
       </div>
-      <div class="left headerTopSeperator"></div>
+      <div class="left headerTopSeparator"></div>
       <div class="left"><a href="#" onclick="return openHelpGuide();" class="left headerTopLinks">Help</a></div>
-      <div class="left headerTopSeperator"></div>
+      <div class="left headerTopSeparator"></div>
       <div class="left headerTopLinks welcomeLabelPRZero">Welcome</div>
       <div class="left headerTopLinks textbold font-size12" id="userName"></div>
-      <div class="left headerTopSeperator"></div>
+      <div class="left headerTopSeparator"></div>
       <div class="left"><a href="clusterLogout" class="left headerTopLinks">Sign Out</a></div>
     </div>
   </div>
diff --git a/geode-pulse/src/main/webapp/css/popup.css b/geode-pulse/src/main/webapp/css/popup.css
index f861cf9..b543f44 100644
--- a/geode-pulse/src/main/webapp/css/popup.css
+++ b/geode-pulse/src/main/webapp/css/popup.css
@@ -42,7 +42,7 @@
 .popup_contentBlock{float:left; width:100%}
 .popup-innerblock{background:#283649;  padding:10px; color:#949ba4; font-size:13px;}
 .popup-innerblock ul li{margin-bottom:5px;}
-.dataSeperator{margin:0px 5px;}
+.dataSeparator{margin:0px 5px;}
 .width-58{width:58%}
 /*Popup Width*/
 .width345 {
diff --git a/geode-pulse/src/main/webapp/css/style.css b/geode-pulse/src/main/webapp/css/style.css
index 32ee3d1..9fb4083 100644
--- a/geode-pulse/src/main/webapp/css/style.css
+++ b/geode-pulse/src/main/webapp/css/style.css
@@ -77,11 +77,11 @@ body {
 	font-size: 12px;
 }
 
-.headerTopSeperator {
+.headerTopSeparator {
 	color: #4d4d4d;
 	height: 25px;
 	width: 1px;
-	background: url(../images/seperator.png) no-repeat center center
+	background: url(../images/separator.png) no-repeat center center
 }
 
 /*about */
@@ -919,7 +919,7 @@ body {
 	color: #424028;
 }
 
-.linkSeperator {
+.linkSeparator {
 	padding: 0px 5px;
 }
 
@@ -1837,7 +1837,7 @@ body {
 	margin-bottom: 5px;
 }
 
-.dataSeperator {
+.dataSeparator {
 	margin: 0px 5px;
 }
 
@@ -1899,7 +1899,7 @@ body {
 	color: #424028;
 }
 
-.linkSeperator {
+.linkSeparator {
 	padding: 0px 5px;
 }
 
@@ -3102,4 +3102,4 @@ input[type="text"].searchBoxRegion {
   height: 100%;
   float: left;
 }
-/* End For Data Browser */
\ No newline at end of file
+/* End For Data Browser */
diff --git a/geode-pulse/src/main/webapp/dataBrowser.html b/geode-pulse/src/main/webapp/dataBrowser.html
index 478bce5..5c70daa 100644
--- a/geode-pulse/src/main/webapp/dataBrowser.html
+++ b/geode-pulse/src/main/webapp/dataBrowser.html
@@ -136,12 +136,12 @@
 	            </div>
 	        </div>
 				</div>
-				<div class="left headerTopSeperator"></div>
+				<div class="left headerTopSeparator"></div>
 	      <div class="left"><a target="_blank" href="#" onclick="return openHelpGuide();" class="left headerTopLinks">Help</a></div>
-	      <div class="left headerTopSeperator"></div>
+	      <div class="left headerTopSeparator"></div>
 	      <div class="left headerTopLinks welcomeLabelPRZero">Welcome</div>
 	      <div class="left headerTopLinks textbold font-size12" id="userName"></div>
-	      <div class="left headerTopSeperator"></div>
+	      <div class="left headerTopSeparator"></div>
 	      <div class="left"><a href="clusterLogout" class="left headerTopLinks">Sign Out</a></div>
 			</div>
 		</div>
diff --git a/geode-pulse/src/main/webapp/memberDetails.html b/geode-pulse/src/main/webapp/memberDetails.html
index fa5998f..2488c94 100644
--- a/geode-pulse/src/main/webapp/memberDetails.html
+++ b/geode-pulse/src/main/webapp/memberDetails.html
@@ -127,12 +127,12 @@
         </div>
       
       </div>
-      <div class="left headerTopSeperator"></div>
+      <div class="left headerTopSeparator"></div>
       <div class="left"><a target="_blank" href="#" onclick="return openHelpGuide();" class="left headerTopLinks">Help</a></div>
-      <div class="left headerTopSeperator"></div>
+      <div class="left headerTopSeparator"></div>
       <div class="left headerTopLinks welcomeLabelPRZero">Welcome</div>
       <div class="left headerTopLinks textbold font-size12" id="userName"></div>
-      <div class="left headerTopSeperator"></div>
+      <div class="left headerTopSeparator"></div>
       <div class="left"><a href="clusterLogout" class="left headerTopLinks">Sign Out</a></div>
     </div>
   </div>
diff --git a/geode-pulse/src/main/webapp/queryStatistics.html b/geode-pulse/src/main/webapp/queryStatistics.html
index cbaf157..5471add 100644
--- a/geode-pulse/src/main/webapp/queryStatistics.html
+++ b/geode-pulse/src/main/webapp/queryStatistics.html
@@ -147,12 +147,12 @@
 						</div>
 					</div>
 				</div>
-				<div class="left headerTopSeperator"></div>
+				<div class="left headerTopSeparator"></div>
 				<div class="left"><a target="_blank" href="#" onclick="return openHelpGuide();" class="left headerTopLinks">Help</a></div>
-				<div class="left headerTopSeperator"></div>
+				<div class="left headerTopSeparator"></div>
 				<div class="left headerTopLinks welcomeLabelPRZero">Welcome</div>
 				<div class="left headerTopLinks textbold font-size12" id="userName"></div>
-				<div class="left headerTopSeperator"></div>
+				<div class="left headerTopSeparator"></div>
 				<div class="left">
 					<a href="clusterLogout" class="left headerTopLinks">Sign
 						Out</a>
diff --git a/geode-pulse/src/main/webapp/regionDetail.html b/geode-pulse/src/main/webapp/regionDetail.html
index e303d60..fa0a558 100644
--- a/geode-pulse/src/main/webapp/regionDetail.html
+++ b/geode-pulse/src/main/webapp/regionDetail.html
@@ -209,12 +209,12 @@
         </div>
         <!-- Version Details Popup -->
       </div>
-      <div class="left headerTopSeperator"></div>
+      <div class="left headerTopSeparator"></div>
       <div class="left"><a target="_blank" href="#" onclick="return openHelpGuide();" class="left headerTopLinks">Help</a></div>
-      <div class="left headerTopSeperator"></div>
+      <div class="left headerTopSeparator"></div>
       <div class="left headerTopLinks welcomeLabelPRZero">Welcome</div>
       <div class="left headerTopLinks textbold font-size12" id="userName"></div>
-      <div class="left headerTopSeperator"></div>
+      <div class="left headerTopSeparator"></div>
       <div class="left"><a href="clusterLogout" class="left headerTopLinks">Sign Out</a></div>
     </div>
   </div> 
diff --git a/geode-pulse/src/main/webapp/scripts/lib/jquery-1.7.2.js b/geode-pulse/src/main/webapp/scripts/lib/jquery-1.7.2.js
index 75ce261..b6624f3 100644
--- a/geode-pulse/src/main/webapp/scripts/lib/jquery-1.7.2.js
+++ b/geode-pulse/src/main/webapp/scripts/lib/jquery-1.7.2.js
@@ -2338,7 +2338,7 @@ jQuery.fn.extend({
 					classNames = value.split( rspace );
 
 				while ( (className = classNames[ i++ ]) ) {
-					// check each className given, space seperated list
+					// check each className given, space separated list
 					state = isBool ? state : !self.hasClass( className );
 					self[ state ? "addClass" : "removeClass" ]( className );
 				}
diff --git a/geode-pulse/src/main/webapp/scripts/lib/jquery.jqGrid.src.js b/geode-pulse/src/main/webapp/scripts/lib/jquery.jqGrid.src.js
index eb425c3..50ada95 100644
--- a/geode-pulse/src/main/webapp/scripts/lib/jquery.jqGrid.src.js
+++ b/geode-pulse/src/main/webapp/scripts/lib/jquery.jqGrid.src.js
@@ -19,7 +19,7 @@ $.extend($.jgrid,{
 	version : "4.4.0",
 	htmlDecode : function(value){
 		if(value && (value=='&nbsp;' || value=='&#160;' || (value.length===1 && value.charCodeAt(0)===160))) { return "";}
-		return !value ? value : String(value).replace(/&gt;/g, ">").replace(/&lt;/g, "<").replace(/&quot;/g, '"').replace(/&amp;/g, "&");		
+		return !value ? value : String(value).replace(/&gt;/g, ">").replace(/&lt;/g, "<").replace(/&quot;/g, '"').replace(/&amp;/g, "&");
 	},
 	htmlEncode : function (value){
 		return !value ? value : String(value).replace(/&/g, "&amp;").replace(/\"/g, "&quot;").replace(/</g, "&lt;").replace(/>/g, "&gt;");
@@ -529,7 +529,7 @@ $.extend($.jgrid,{
 			switch(swst) {
 				case 'int':
 				case 'integer':
-					val = (isNaN(Number(val)) || val==="") ? '0' : val; // To be fixed with more inteligent code
+					val = (isNaN(Number(val)) || val==="") ? '0' : val; // To be fixed with more intelligent code
 					fld = 'parseInt('+fld+',10)';
 					val = 'parseInt('+val+',10)';
 					break;
@@ -537,7 +537,7 @@ $.extend($.jgrid,{
 				case 'number':
 				case 'numeric':
 					val = String(val).replace(_stripNum, '');
-					val = (isNaN(Number(val)) || val==="") ? '0' : val; // To be fixed with more inteligent code
+					val = (isNaN(Number(val)) || val==="") ? '0' : val; // To be fixed with more intelligent code
 					fld = 'parseFloat('+fld+')';
 					val = 'parseFloat('+val+')';
 					break;
@@ -917,7 +917,7 @@ $.fn.jqGrid = function( pin ) {
 					ts.grid.bDiv.scrollLeft = left;
 					$(ts).unbind('.selectionPreserver', restoreSelection);
 				};
-				$(ts).bind('jqGridGridComplete.selectionPreserver', restoreSelection);				
+				$(ts).bind('jqGridGridComplete.selectionPreserver', restoreSelection);
 			}
 		};
 		if(this.tagName.toUpperCase()!='TABLE') {
@@ -1325,7 +1325,7 @@ $.fn.jqGrid = function( pin ) {
 				F = f = reader(frd);
 			}
 			if( ts.p.keyIndex===false ) {
-				idn = $.isFunction(dReader.id) ? dReader.id.call(ts, data) : dReader.id; 
+				idn = $.isFunction(dReader.id) ? dReader.id.call(ts, data) : dReader.id;
 			} else {
 				idn = ts.p.keyIndex;
 			}
@@ -1558,7 +1558,7 @@ $.fn.jqGrid = function( pin ) {
 					if(s>0) {
 						var result = query.select();
 						query = $.jgrid.from( result);
-						if (ts.p.ignoreCase) { query = query.ignoreCase(); } 
+						if (ts.p.ignoreCase) { query = query.ignoreCase(); }
 					}
 					try{
 						ror = group.rules.length && group.groupOp.toString().toUpperCase() === "OR";
@@ -1812,7 +1812,7 @@ $.fn.jqGrid = function( pin ) {
 						beforeSend: function(xhr, settings ){
 							var gotoreq = true;
 							if($.isFunction(ts.p.loadBeforeSend)) {
-								gotoreq = ts.p.loadBeforeSend.call(ts,xhr, settings); 
+								gotoreq = ts.p.loadBeforeSend.call(ts,xhr, settings);
 							}
 							if(gotoreq === undefined) { gotoreq = true; }
 							if(gotoreq === false) {
@@ -2239,7 +2239,7 @@ $.fn.jqGrid = function( pin ) {
 						if (i>0) {
 							if(!$(this).hasClass("ui-subgrid") && !$(this).hasClass("jqgroup") && !$(this).hasClass('ui-state-disabled')){
 								$("#jqg_"+$.jgrid.jqID(ts.p.id)+"_"+$.jgrid.jqID(this.id) )[ts.p.useProp ? 'prop': 'attr']("checked",true);
-								$(this).addClass("ui-state-highlight").attr("aria-selected","true");  
+								$(this).addClass("ui-state-highlight").attr("aria-selected","true");
 								ts.p.selarrrow.push(this.id);
 								ts.p.selrow = this.id;
 								if(froz) {
@@ -2670,7 +2670,7 @@ $.jgrid.extend({
 			if($t.p.frozenColumns === true ) {
 				fid = $t.p.id+"_frozen";
 			}
-			if(!$t.p.multiselect) {	
+			if(!$t.p.multiselect) {
 				if(pt.className !== "ui-subgrid") {
 					if( $t.p.selrow != pt.id) {
 						$($t.rows.namedItem($t.p.selrow)).removeClass("ui-state-highlight").attr({"aria-selected":"false", "tabindex" : "-1"});
@@ -2744,8 +2744,8 @@ $.jgrid.extend({
 					ind = t.rows.namedItem(n);
 					$(ind).removeClass("ui-state-highlight").attr("aria-selected","false");
 					$("#jqg_"+$.jgrid.jqID(t.p.id)+"_"+$.jgrid.jqID(n))[t.p.useProp ? 'prop': 'attr']("checked",false);
-					if(fid) { 
-						$("#"+$.jgrid.jqID(n), "#"+$.jgrid.jqID(fid)).removeClass("ui-state-highlight"); 
+					if(fid) {
+						$("#"+$.jgrid.jqID(n), "#"+$.jgrid.jqID(fid)).removeClass("ui-state-highlight");
 						$("#jqg_"+$.jgrid.jqID(t.p.id)+"_"+$.jgrid.jqID(n), "#"+$.jgrid.jqID(fid))[t.p.useProp ? 'prop': 'attr']("checked",false);
 					}
 				});
@@ -3141,7 +3141,7 @@ $.jgrid.extend({
 				shrink=$t.p.shrinkToFit;
 			}
 			if(isNaN(nwidth)) {return;}
-			nwidth = parseInt(nwidth,10); 
+			nwidth = parseInt(nwidth,10);
 			$t.grid.width = $t.p.width = nwidth;
 			$("#gbox_"+$.jgrid.jqID($t.p.id)).css("width",nwidth+"px");
 			$("#gview_"+$.jgrid.jqID($t.p.id)).css("width",nwidth+"px");
@@ -3535,8 +3535,8 @@ $.jgrid.extend({
 /**
  * jqGrid extension for custom methods
  * Tony Tomov tony@trirand.com
- * http://trirand.com/blog/ 
- * 
+ * http://trirand.com/blog/
+ *
  * Wildraid wildraid@mail.ru
  * Oleg Kiriljuk oleg.kiriljuk@ok-soft-gmbh.com
  * Dual licensed under the MIT and GPL licenses:
@@ -3595,7 +3595,7 @@ $.jgrid.extend({
 	},
 	GridDestroy : function () {
 		return this.each(function(){
-			if ( this.grid ) { 
+			if ( this.grid ) {
 				if ( this.p.pager ) { // if not part of grid
 					$(this.p.pager).remove();
 				}
@@ -3802,13 +3802,13 @@ $.jgrid.extend({
 			var toggleToolbar = function(){
 				var trow = $("tr.ui-search-toolbar",$t.grid.hDiv),
 				trow2 = $t.p.frozenColumns === true ?  $("tr.ui-search-toolbar",$t.grid.fhDiv) : false;
-				if(trow.css("display")=='none') { 
-					trow.show(); 
+				if(trow.css("display")=='none') {
+					trow.show();
 					if(trow2) {
 						trow2.show();
 					}
-				} else { 
-					trow.hide(); 
+				} else {
+					trow.hide();
 					if(trow2) {
 						trow2.hide();
 					}
@@ -3883,7 +3883,7 @@ $.jgrid.extend({
 								sep = cm.editoptions.separator === undefined ? ":" : cm.editoptions.separator;
 								delim = cm.editoptions.delimiter === undefined ? ";" : cm.editoptions.delimiter;
 							}
-							if (oSv) {	
+							if (oSv) {
 								var elem = document.createElement("select");
 								elem.style.width = "100%";
 								$(elem).attr({name:cm.index || cm.name, id: "gs_"+cm.name});
@@ -4010,7 +4010,7 @@ $.jgrid.extend({
 			}
 		});
 	},
-	
+
 	setGroupHeaders : function ( o ) {
 		o = $.extend({
 			useColSpanStyle :  false,
@@ -4146,7 +4146,7 @@ $.jgrid.extend({
 			$(ts).bind('jqGridResizeStop.setGroupHeaders', function (e, nw, idx) {
 				$firstRow.find('th').eq(idx).width(nw);
 			});
-		});				
+		});
 	},
 	setFrozenColumns : function () {
 		return this.each(function() {
@@ -4159,7 +4159,7 @@ $.jgrid.extend({
 			}
 			if($t.p.rownumbers) { i++; }
 			if($t.p.multiselect) { i++; }
-			
+
 			// get the max index of frozen col
 			while(i<len)
 			{
@@ -4224,9 +4224,9 @@ $.jgrid.extend({
 				});
 				$($t).bind('jqGridResizeStop.setFrozenColumns', function (e, w, index) {
 					var rhth = $(".ui-jqgrid-htable",$t.grid.fhDiv);
-					$("th:eq("+index+")",rhth).width( w ); 
+					$("th:eq("+index+")",rhth).width( w );
 					var btd = $(".ui-jqgrid-btable",$t.grid.fbDiv);
-					$("tr:first td:eq("+index+")",btd).width( w ); 
+					$("tr:first td:eq("+index+")",btd).width( w );
 				});
 				// sorting stuff
 				$($t).bind('jqGridOnSortCol.setFrozenColumns', function (index, idxcol) {
@@ -4244,7 +4244,7 @@ $.jgrid.extend({
 						}
 					}
 				});
-				
+
 				// data stuff
 				//TODO support for setRowData
 				$("#gview_"+$.jgrid.jqID($t.p.id)).append($t.grid.fbDiv);
@@ -4314,7 +4314,7 @@ $.jgrid.extend({
  * Dual licensed under the MIT and GPL licenses:
  *   http://www.opensource.org/licenses/mit-license.php
  *   http://www.gnu.org/licenses/gpl.html
- * 
+ *
  * $Version: 07/06/2008 +r13
  */
 (function($) {
@@ -4358,7 +4358,7 @@ open:function(s,t){var h=H[s],c=h.c,cc='.'+c.closeClass,z=(parseInt(h.w.css('z-i
   r.html(c.ajaxText).load(u,function(){if(c.onLoad)c.onLoad.call(this,h);if(cc)h.w.jqmAddClose($(cc,h.w));e(h);});}
  else if(cc)h.w.jqmAddClose($(cc,h.w));
 
- if(c.toTop&&h.o)h.w.before('<span id="jqmP'+h.w[0]._jqm+'"></span>').insertAfter(h.o);	
+ if(c.toTop&&h.o)h.w.before('<span id="jqmP'+h.w[0]._jqm+'"></span>').insertAfter(h.o);
  (c.onShow)?c.onShow(h):h.w.show();e(h);return F;
 },
 close:function(s){var h=H[s];if(!h.a)return F;h.a=F;
@@ -4380,7 +4380,7 @@ hs=function(w,t,c){return w.each(function(){var s=this._jqm;$(t).each(function()
  * Copyright (c) 2007 Brice Burgess <bh...@iceburg.net>, http://www.iceburg.net
  * Licensed under the MIT License:
  * http://www.opensource.org/licenses/mit-license.php
- * 
+ *
  * $Version: 2007.08.19 +r2
  */
 
@@ -4432,7 +4432,7 @@ i=function(e,h,k,aR){
 					pY:v.pageY,
 					k:d.k
 				};
-			} else {M1 = false;}			
+			} else {M1 = false;}
 			//E.css({opacity:0.8});
 			if($("input.hasDatepicker",E[0])[0]) {
 			try {$("input.hasDatepicker",E[0]).datepicker('hide');}catch (dpe){}
@@ -4451,7 +4451,7 @@ f1=function(k){return parseInt(E1.css(k),10)||false;};
 
 	License:     http://creativecommons.org/licenses/LGPL/2.1/
 	Author:      Stefan Goessner/2006
-	Web:         http://goessner.net/ 
+	Web:         http://goessner.net/
 
 	Modifications made:
 
@@ -4460,7 +4460,7 @@ f1=function(k){return parseInt(E1.css(k),10)||false;};
 	             added handling of empty arrays, empty strings, and int/floats values.
 	Author:      Michael Schøler/2008-01-29
 	Web:         http://michael.hinnerup.net/blog/2008/01/26/converting-json-to-xml-and-xml-to-json/
-	
+
 	Description: json2xml added support to convert functions as CDATA
 	             so it will be easy to write characters that cause some problems when convert
 	Author:      Tony Tomov
@@ -4535,7 +4535,7 @@ var xmlJsonClass = {
 				if (v === undefined ) { v = ""; }
 				if (v.toString() === "\"\"" || v.toString().length === 0) {
 					xml += ind + "<" + name + ">__EMPTY_STRING_</" + name + ">";
-				} 
+				}
 				else {
 					xml += ind + "<" + name + ">" + v.toString() + "</" + name + ">";
 				}
@@ -4597,7 +4597,7 @@ var xmlJsonClass = {
 								}
 							}
 							else if (o[n.nodeName]) {
-								// multiple occurence of element ..
+								// multiple occurrence of element ..
 								if (o[n.nodeName] instanceof Array) {
 									o[n.nodeName][o[n.nodeName].length] = this.toObj(n);
 								}
@@ -4606,7 +4606,7 @@ var xmlJsonClass = {
 								}
 							}
 							else {
-								// first occurence of element ..
+								// first occurrence of element ..
 								o[n.nodeName] = this.toObj(n);
 							}
 						}
@@ -4702,7 +4702,7 @@ var xmlJsonClass = {
 			if (objRegExp.test(os) || FuncTest.test(os) || os==="false" || os==="true") {
 				// int or float
 				json += (name && ":")  + "\"" +os + "\"";
-			} 
+			}
 			else {
 			*/
 				json += (name && ":") + "\"" + o.replace(/\\/g,'\\\\').replace(/\"/g,'\\"') + "\"";
@@ -4787,18 +4787,18 @@ var xmlJsonClass = {
  * formatter for values but most of the values if for jqGrid
  * Some of this was inspired and based on how YUI does the table datagrid but in jQuery fashion
  * we are trying to keep it as light as possible
- * Joshua Burnett josh@9ci.com	
+ * Joshua Burnett josh@9ci.com
  * http://www.greenbill.com
  *
  * Changes from Tony Tomov tony@trirand.com
  * Dual licensed under the MIT and GPL licenses:
  * http://www.opensource.org/licenses/mit-license.php
  * http://www.gnu.org/licenses/gpl-2.0.html
- * 
+ *
 **/
 
 ;(function($) {
-"use strict";	
+"use strict";
 	$.fmatter = {};
 	//opts can be id:row id for the row, rowdata:the data for the row, colmodel:the column model for this column
 	//example {id:1234,}
@@ -4831,7 +4831,7 @@ var xmlJsonClass = {
 				return true;
 			}
 			o = $.trim(o).replace(/\&nbsp\;/ig,'').replace(/\&#160\;/ig,'');
-			return o==="";	
+			return o==="";
 		}
 	});
 	$.fn.fmatter = function(formatType, cellval, opts, rwd, act) {
@@ -4897,7 +4897,7 @@ var xmlJsonClass = {
 				// Append suffix
 				sOutput = (opts.suffix) ? sOutput + opts.suffix : sOutput;
 				return sOutput;
-				
+
 			} else {
 				return nData;
 			}
@@ -4967,13 +4967,13 @@ var xmlJsonClass = {
 				else if (ty >=0 && ty <=69) {ts.y= 2000+ts.y;}
 				timestamp = new Date(ts.y, ts.m, ts.d, ts.h, ts.i, ts.s, ts.u);
 			}
-			
+
 			if( newformat in opts.masks )  {
 				newformat = opts.masks[newformat];
 			} else if ( !newformat ) {
 				newformat = 'Y-m-d';
 			}
-			var 
+			var
 				G = timestamp.getHours(),
 				i = timestamp.getMinutes(),
 				j = timestamp.getDate(),
@@ -5031,10 +5031,10 @@ var xmlJsonClass = {
 					c: '?',
 					r: '?',
 					U: Math.floor(timestamp / 1000)
-				};	
+				};
 			return newformat.replace(token, function ($0) {
 				return $0 in flags ? flags[$0] : $0.substring(1);
-			});			
+			});
 		}
 	};
 	$.fn.fmatter.defaultFormat = function(cellval, opts) {
@@ -5180,8 +5180,8 @@ var xmlJsonClass = {
 	$.fn.fmatter.rowactions = function(rid,gid,act,pos) {
 		var op ={
 			keys:false,
-			onEdit : null, 
-			onSuccess: null, 
+			onEdit : null,
+			onSuccess: null,
 			afterSave:null,
 			onError: null,
 			afterRestore: null,
@@ -5346,7 +5346,7 @@ var xmlJsonClass = {
 		var op = $.extend({}, !$.fmatter.isUndefined(options.colModel.formatoptions) ? options.colModel.formatoptions: options.colModel.editoptions),
 		sep = op.separator === undefined ? ":" : op.separator,
 		delim = op.delimiter === undefined ? ";" : op.delimiter;
-		
+
 		if(op.value){
 			var oSelect = op.value,
 			msl =  op.multiple === true ? true : false,
@@ -5358,7 +5358,7 @@ var xmlJsonClass = {
 					sv = so[i].split(sep);
 					if(sv.length > 2 ) {
 						sv[1] = $.map(sv,function(n,i){if(i>0) {return n;}}).join(sep);
-					}					
+					}
 					if(msl) {
 						if($.inArray(sv[1],scell)>-1) {
 							ret[j] = sv[0];
@@ -5391,7 +5391,7 @@ var xmlJsonClass = {
 		var op = $.jgrid.formatter.date || {};
 		if(!$.fmatter.isUndefined(opts.formatoptions)) {
 			op = $.extend({},op,opts.formatoptions);
-		}		
+		}
 		if(!$.fmatter.isEmpty(cellval)) {
 			return $.fmatter.util.DateFormat(op.newformat,cellval,op.srcformat,op);
 		} else {
@@ -5403,7 +5403,7 @@ var xmlJsonClass = {
 /*
  * jqGrid common function
  * Tony Tomov tony@trirand.com
- * http://trirand.com/blog/ 
+ * http://trirand.com/blog/
  * Dual licensed under the MIT and GPL licenses:
  * http://www.opensource.org/licenses/mit-license.php
  * http://www.gnu.org/licenses/gpl-2.0.html
@@ -5446,7 +5446,7 @@ $.extend($.jgrid,{
 		}
 		return [curleft,curtop];
 	},
-	createModal : function(aIDs, content, p, insertSelector, posSelector, appendsel, css) {		
+	createModal : function(aIDs, content, p, insertSelector, posSelector, appendsel, css) {
 		var mw  = document.createElement('div'), rtlsup, self = this;
 		css = $.extend({}, css || {});
 		rtlsup = $(p.gbox).attr("dir") == "rtl" ? true : false;
@@ -5794,7 +5794,7 @@ $.extend($.jgrid,{
 						ovm = $.map(ovm,function(n){return $.trim(n);});
 					}
 					if(typeof options.value === 'function') { options.value = options.value(); }
-					var so,sv, ov, 
+					var so,sv, ov,
 					sep = options.separator === undefined ? ":" : options.separator,
 					delim = options.delimiter === undefined ? ";" : options.delimiter;
 					if(typeof options.value === 'string') {
@@ -6077,23 +6077,23 @@ $.extend($.jgrid,{
  * Dual licensed under the MIT and GPL licenses
  * http://www.opensource.org/licenses/mit-license.php
  * http://www.gnu.org/licenses/gpl-2.0.html
- * 
+ *
  * The work is inspired from this Stefan Pirvu
  * http://www.codeproject.com/KB/scripting/json-filtering.aspx
  *
  * The filter uses JSON entities to hold filter rules and groups. Here is an example of a filter:
 
 { "groupOp": "AND",
-      "groups" : [ 
+      "groups" : [
         { "groupOp": "OR",
             "rules": [
-                { "field": "name", "op": "eq", "data": "England" }, 
+                { "field": "name", "op": "eq", "data": "England" },
                 { "field": "id", "op": "le", "data": "5"}
              ]
-        } 
+        }
       ],
       "rules": [
-        { "field": "name", "op": "eq", "data": "Romania" }, 
+        { "field": "name", "op": "eq", "data": "Romania" },
         { "field": "id", "op": "le", "data": "1"}
       ]
 }
@@ -6104,7 +6104,7 @@ $.extend($.jgrid,{
 
 $.fn.jqFilter = function( arg ) {
 	if (typeof arg === 'string') {
-		
+
 		var fn = $.fn.jqFilter[arg];
 		if (!fn) {
 			throw ("jqFilter - No such method: " + arg);
@@ -6235,7 +6235,7 @@ $.fn.jqFilter = function( arg ) {
 		*/
 
 		this.onchange = function (  ){
-			// clear any error 
+			// clear any error
 			this.p.error = false;
 			this.p.errmsg="";
 			return $.isFunction(this.p.onChange) ? this.p.onChange.call( this, this.p ) : false;
@@ -6336,7 +6336,7 @@ $.fn.jqFilter = function( arg ) {
 						break;
 					}
 				}
-				
+
 				var opr;
 				if( cm.searchoptions.sopt ) {opr = cm.searchoptions.sopt;}
 				else if(that.p.sopt) { opr= that.p.sopt; }
@@ -6895,7 +6895,7 @@ $.jgrid.extend({
 				showFilter($("#fbox_"+$.jgrid.jqID(+$t.p.id)));
 			} else {
 				var fil = $("<div><div id='"+fid+"' class='searchFilter' style='overflow:auto'></div></div>").insertBefore("#gview_"+$.jgrid.jqID($t.p.id)),
-				align = "left", butleft =""; 
+				align = "left", butleft ="";
 				if($t.p.direction == "rtl") {
 					align = "right";
 					butleft = " style='text-align:left'";
@@ -7152,7 +7152,7 @@ $.jgrid.extend({
 			var $t = this;
 			if (!$t.grid || !rowid) {return;}
 			var gID = $t.p.id,
-			frmgr = "FrmGrid_"+gID, frmtborg = "TblGrid_"+gID, frmtb = "#"+$.jgrid.jqID(frmtborg), 
+			frmgr = "FrmGrid_"+gID, frmtborg = "TblGrid_"+gID, frmtb = "#"+$.jgrid.jqID(frmtborg),
 			IDs = {themodal:'editmod'+gID,modalhead:'edithd'+gID,modalcontent:'editcnt'+gID, scrollelm : frmgr},
 			onBeforeShow = $.isFunction(rp_ge[$t.p.id].beforeShowForm) ? rp_ge[$t.p.id].beforeShowForm : false,
 			onAfterShow = $.isFunction(rp_ge[$t.p.id].afterShowForm) ? rp_ge[$t.p.id].afterShowForm : false,
@@ -7442,10 +7442,10 @@ $.jgrid.extend({
 			}
 			function postIt() {
 				var copydata, ret=[true,"",""], onCS = {}, opers = $t.p.prmNames, idname, oper, key, selr, i;
-				
+
 				var retvals = $($t).triggerHandler("jqGridAddEditBeforeCheckValues", [$("#"+frmgr), frmoper]);
 				if(retvals && typeof(retvals) === 'object') {postdata = retvals;}
-				
+
 				if($.isFunction(rp_ge[$t.p.id].beforeCheckValues)) {
 					retvals = rp_ge[$t.p.id].beforeCheckValues.call($t, postdata,$("#"+frmgr),postdata[$t.p.id+"_id"] == "_empty" ? opers.addoper : opers.editoper);
 					if(retvals && typeof(retvals) === 'object') {postdata = retvals;}
@@ -7459,8 +7459,8 @@ $.jgrid.extend({
 				setNulls();
 				if(ret[0]) {
 					onCS = $($t).triggerHandler("jqGridAddEditClickSubmit", [rp_ge[$t.p.id], postdata, frmoper]);
-					if( onCS === undefined && $.isFunction( rp_ge[$t.p.id].onclickSubmit)) { 
-						onCS = rp_ge[$t.p.id].onclickSubmit.call($t, rp_ge[$t.p.id], postdata) || {}; 
+					if( onCS === undefined && $.isFunction( rp_ge[$t.p.id].onclickSubmit)) {
+						onCS = rp_ge[$t.p.id].onclickSubmit.call($t, rp_ge[$t.p.id], postdata) || {};
 					}
 					ret = $($t).triggerHandler("jqGridAddEditBeforeSubmit", [postdata, $("#"+frmgr), frmoper]);
 					if(ret === undefined) {
@@ -7502,7 +7502,7 @@ $.jgrid.extend({
 							}
 						}
 					}
-					
+
 					postdata[idname] = $.jgrid.stripPref($t.p.idPrefix, postdata[idname]);
 					var ajaxOptions = $.extend({
 						url: rp_ge[$t.p.id].url ? rp_ge[$t.p.id].url : $($t).jqGrid('getGridParam','editurl'),
@@ -7631,7 +7631,7 @@ $.jgrid.extend({
 					}
 					if (ret[0]) {
 						if (rp_ge[$t.p.id].useDataProxy) {
-							var dpret = $t.p.dataProxy.call($t, ajaxOptions, "set_"+$t.p.id); 
+							var dpret = $t.p.dataProxy.call($t, ajaxOptions, "set_"+$t.p.id);
 							if(typeof(dpret) == "undefined") {
 								dpret = [true, ""];
 							}
@@ -7647,7 +7647,7 @@ $.jgrid.extend({
 								}
 							}
 						} else {
-							$.ajax(ajaxOptions); 
+							$.ajax(ajaxOptions);
 						}
 					}
 				}
@@ -8467,7 +8467,7 @@ $.jgrid.extend({
 						}
 						if (ret[0]) {
 							if (rp_ge[$t.p.id].useDataProxy) {
-								var dpret = $t.p.dataProxy.call($t, ajaxOptions, "del_"+$t.p.id); 
+								var dpret = $t.p.dataProxy.call($t, ajaxOptions, "del_"+$t.p.id);
 								if(typeof(dpret) == "undefined") {
 									dpret = [true, ""];
 								}
@@ -8888,11 +8888,11 @@ $.jgrid.extend({
 /**
  * jqGrid extension for manipulating Grid Data
  * Tony Tomov tony@trirand.com
- * http://trirand.com/blog/ 
+ * http://trirand.com/blog/
  * Dual licensed under the MIT and GPL licenses:
  * http://www.opensource.org/licenses/mit-license.php
  * http://www.gnu.org/licenses/gpl-2.0.html
-**/ 
+**/
 //jsHint options
 /*global alert, $, jQuery */
 "use strict";
@@ -8916,7 +8916,7 @@ $.jgrid.extend({
 			if ($.isFunction(afterrestorefunc)) { o.afterrestorefunc = afterrestorefunc; }
 			// last two not as param, but as object (sorry)
 			//if (typeof restoreAfterError !== "undefined") { o.restoreAfterError = restoreAfterError; }
-			//if (typeof mtype !== "undefined") { o.mtype = mtype || "POST"; }			
+			//if (typeof mtype !== "undefined") { o.mtype = mtype || "POST"; }
 		}
 		o = $.extend(true, {
 			keys : false,
@@ -9053,7 +9053,7 @@ $.jgrid.extend({
 							if(cm.editoptions ) {
 								cbv = cm.editoptions.value.split(":");
 							}
-							tmp[nm]=  $("input",this).is(":checked") ? cbv[0] : cbv[1]; 
+							tmp[nm]=  $("input",this).is(":checked") ? cbv[0] : cbv[1];
 							break;
 						case 'text':
 						case 'password':
@@ -9155,7 +9155,7 @@ $.jgrid.extend({
 							var ret = true, sucret;
 							sucret = $($t).triggerHandler("jqGridInlineSuccessSaveRow", [res, rowid, o]);
 							if (!$.isArray(sucret)) {sucret = [true, tmp];}
-							if (sucret[0] && $.isFunction(o.successfunc)) {sucret = o.successfunc.call($t, res);}							
+							if (sucret[0] && $.isFunction(o.successfunc)) {sucret = o.successfunc.call($t, res);}
 							if($.isArray(sucret)) {
 								// expect array - status, data, rowid
 								ret = sucret[0];
@@ -9375,7 +9375,7 @@ $.jgrid.extend({
 							$("#"+gID+"_iladd").addClass('ui-state-disabled');
 							$("#"+gID+"_iledit").addClass('ui-state-disabled');
 						} else {
-							$.jgrid.viewModal("#alertmod",{gbox:"#gbox_"+gID,jqm:true});$("#jqg_alrt").focus();							
+							$.jgrid.viewModal("#alertmod",{gbox:"#gbox_"+gID,jqm:true});$("#jqg_alrt").focus();
 						}
 					}
 				});
@@ -9403,7 +9403,7 @@ $.jgrid.extend({
 								$($t).jqGrid('showAddEditButtons');
 							}
 						} else {
-							$.jgrid.viewModal("#alertmod",{gbox:"#gbox_"+gID,jqm:true});$("#jqg_alrt").focus();							
+							$.jgrid.viewModal("#alertmod",{gbox:"#gbox_"+gID,jqm:true});$("#jqg_alrt").focus();
 						}
 					}
 				});
@@ -9421,7 +9421,7 @@ $.jgrid.extend({
 							$($t).jqGrid('restoreRow', sr, o.editParams);
 							$($t).jqGrid('showAddEditButtons');
 						} else {
-							$.jgrid.viewModal("#alertmod",{gbox:"#gbox_"+gID,jqm:true});$("#jqg_alrt").focus();							
+							$.jgrid.viewModal("#alertmod",{gbox:"#gbox_"+gID,jqm:true});$("#jqg_alrt").focus();
 						}
 					}
 				});
@@ -9470,11 +9470,11 @@ $.jgrid.extend({
 **
  * jqGrid extension for cellediting Grid Data
  * Tony Tomov tony@trirand.com
- * http://trirand.com/blog/ 
+ * http://trirand.com/blog/
  * Dual licensed under the MIT and GPL licenses:
  * http://www.opensource.org/licenses/mit-license.php
  * http://www.gnu.org/licenses/gpl-2.0.html
-**/ 
+**/
 /**
  * all events and options here are aded anonynous and not in the base grid
  * since the array is to big. Here is the order of execution.
@@ -9597,7 +9597,7 @@ $.jgrid.extend({
 		return this.each(function(){
 			var $t= this, fr;
 			if (!$t.grid || $t.p.cellEdit !== true) {return;}
-			if ( $t.p.savedRow.length >= 1) {fr = 0;} else {fr=null;} 
+			if ( $t.p.savedRow.length >= 1) {fr = 0;} else {fr=null;}
 			if(fr !== null) {
 				var cc = $("td:eq("+iCol+")",$t.rows[iRow]),v,v2,
 				cm = $t.p.colModel[iCol], nm = cm.name, nmjq = $.jgrid.jqID(nm) ;
@@ -9771,7 +9771,7 @@ $.jgrid.extend({
 				$($t).triggerHandler("jqGridAfterRestoreCell", [$t.rows[iRow].id, $t.p.savedRow[fr].v, iRow, iCol]);
 				if ($.isFunction($t.p.afterRestoreCell)) {
 					$t.p.afterRestoreCell.call($t, $t.rows[iRow].id, $t.p.savedRow[fr].v, iRow, iCol);
-				}				
+				}
 				$t.p.savedRow.splice(0,1);
 			}
 			window.setTimeout(function () { $("#"+$t.p.knv).attr("tabindex","-1").focus();},0);
@@ -9869,7 +9869,7 @@ $.jgrid.extend({
 						if ($t.p.colModel[i].hidden !== true) {
 							ind = i;
 							break;
-						}						
+						}
 					}
 				}
 				return ind;
@@ -9966,7 +9966,7 @@ $.jgrid.extend({
 /**
  * jqGrid extension for SubGrid Data
  * Tony Tomov tony@trirand.com
- * http://trirand.com/blog/ 
+ * http://trirand.com/blog/
  * Dual licensed under the MIT and GPL licenses:
  * http://www.opensource.org/licenses/mit-license.php
  * http://www.gnu.org/licenses/gpl-2.0.html
@@ -10333,7 +10333,7 @@ $.jgrid.extend({
 				} else {
 					twrap += ((ldat[isLeaf] === true) ? "'" : $t.p.treeIcons.minus+" tree-minus treeclick'");
 				}
-				
+
 				twrap += "></div></div>";
 				$($t.rows[i].cells[expCol]).wrapInner("<span class='cell-wrapper"+lf+"'></span>").prepend(twrap);
 
@@ -10443,7 +10443,7 @@ $.jgrid.extend({
 					$t.p.colNames.push(n);
 					$t.p.colModel.push({name:n,width:1,hidden:true,sortable:false,resizable:false,hidedlg:true,editable:true,search:false});
 				}
-			});			
+			});
 		});
 	},
 	expandRow: function (record){
@@ -10622,7 +10622,7 @@ $.jgrid.extend({
 			}
 		});
 		return result;
-	},	
+	},
 	// End NS, adjacency Model
 	getNodeAncestors : function(rc) {
 		var ancestors = [];
@@ -10631,7 +10631,7 @@ $.jgrid.extend({
 			var parent = $(this).jqGrid("getNodeParent",rc);
 			while (parent) {
 				ancestors.push(parent);
-				parent = $(this).jqGrid("getNodeParent",parent);	
+				parent = $(this).jqGrid("getNodeParent",parent);
 			}
 		});
 		return ancestors;
@@ -10702,7 +10702,7 @@ $.jgrid.extend({
 					if(this.p.treeGridModel == 'nested') {
 						$(this).jqGrid("setGridParam",{postData:{nodeid:'',n_left:'',n_right:'',n_level:''}});
 					} else {
-						$(this).jqGrid("setGridParam",{postData:{nodeid:'',parentid:'',n_level:''}}); 
+						$(this).jqGrid("setGridParam",{postData:{nodeid:'',parentid:'',n_level:''}});
 					}
 				}
 			}
@@ -10756,11 +10756,11 @@ $.jgrid.extend({
 			for (i = 0, len = children.length; i < len; i++) {
 				child = children[i];
 				records.push(child);
-				$(this).jqGrid("collectChildrenSortTree",records, child, sortname, newDir, st, datefmt); 
+				$(this).jqGrid("collectChildrenSortTree",records, child, sortname, newDir, st, datefmt);
 			}
 		});
 	},
-	// experimental 
+	// experimental
 	setTreeRow : function(rowid, data) {
 		var success=false;
 		this.each(function(){
@@ -11019,7 +11019,7 @@ $.jgrid.extend({
 	groupingPrepare : function (rData, gdata, record, irow) {
 		this.each(function(){
 			var grp = this.p.groupingView, $t= this;
-			var grlen = grp.groupField.length, 
+			var grlen = grp.groupField.length,
 			fieldName,
 			v,
 			changed = 0;
@@ -11145,7 +11145,7 @@ $.jgrid.extend({
 			var $t = this,
 			grp = $t.p.groupingView,
 			str = "", icon = "", hid, clid, pmrtl = grp.groupCollapse ? grp.plusicon : grp.minusicon, gv, cp=[], ii, len =grp.groupField.length;
-			pmrtl += " tree-wrap-"+$t.p.direction; 
+			pmrtl += " tree-wrap-"+$t.p.direction;
 			ii = 0;
 			$.each($t.p.colModel, function (i,n){
 				for(var ii=0;ii<len;ii++) {
@@ -11182,7 +11182,7 @@ $.jgrid.extend({
 					gv = n.value;
 				}
 				str += "<tr id=\""+hid+"\" role=\"row\" class= \"ui-widget-content jqgroup ui-row-"+$t.p.direction+" "+clid+"\"><td style=\"padding-left:"+(n.idx * 12) + "px;"+"\" colspan=\""+colspans+"\">"+icon+$.jgrid.template(grp.groupText[n.idx], gv, n.cnt, n.summary)+"</td></tr>";
-				var leaf = len-1 === n.idx; 
+				var leaf = len-1 === n.idx;
 				if( leaf ) {
 					var gg = grp.groups[i+1];
 					var end = gg !== undefined ?  grp.groups[i+1].startRow : grdata.length;
@@ -11251,7 +11251,7 @@ $.jgrid.extend({
 			var grp = $t.p.groupingView;
 			$t.p.grouping = true;
 
-			//Set default, in case visibilityOnNextGrouping is undefined 
+			//Set default, in case visibilityOnNextGrouping is undefined
 			if (typeof grp.visibiltyOnNextGrouping === "undefined") {
 				grp.visibiltyOnNextGrouping = [];
 			}
@@ -11346,7 +11346,7 @@ $.jgrid.extend({
 			}
 
 			return res;
-		}	
+		}
 	}
 });
 })(jQuery);
@@ -11354,11 +11354,11 @@ $.jgrid.extend({
 /*
  * jqGrid extension for constructing Grid Data from external file
  * Tony Tomov tony@trirand.com
- * http://trirand.com/blog/ 
+ * http://trirand.com/blog/
  * Dual licensed under the MIT and GPL licenses:
  * http://www.opensource.org/licenses/mit-license.php
  * http://www.gnu.org/licenses/gpl-2.0.html
-**/ 
+**/
 //jsHint options
 /*global jQuery, $, alert, xmlJsonClass */
 
@@ -11567,12 +11567,12 @@ $.jgrid.extend({
 })(jQuery);;(function($){
 /*
 **
- * jqGrid addons using jQuery UI 
+ * jqGrid addons using jQuery UI
  * Author: Mark Williams
  * Dual licensed under the MIT and GPL licenses:
  * http://www.opensource.org/licenses/mit-license.php
  * http://www.gnu.org/licenses/gpl-2.0.html
- * depends on jQuery UI 
+ * depends on jQuery UI
 **/
 if ($.browser.msie && $.browser.version==8) {
 	$.expr[":"].hidden = function(elem) {
@@ -11613,7 +11613,7 @@ if($.ui) {
 		$.jgrid._multiselect = true;
 	}
 }
-        
+
 $.jgrid.extend({
 	sortableColumns : function (tblrow)
 	{
@@ -11650,7 +11650,7 @@ $.jgrid.extend({
 								permutation.push(cmMap[id]);
 							}
 					});
-	
+
 					$(ts).jqGrid("remapColumns",permutation, true, true);
 					if ($.isFunction(ts.p.sortable.update)) {
 						ts.p.sortable.update(permutation);
@@ -11683,7 +11683,7 @@ $.jgrid.extend({
 		if($("#colchooser_"+$.jgrid.jqID(self[0].p.id)).length ) { return; }
         var selector = $('<div id="colchooser_'+self[0].p.id+'" style="position:relative;overflow:hidden"><div><select multiple="multiple"></select></div></div>');
         var select = $('select', selector);
-		
+
 		function insert(perm,i,v) {
 			if(i>=0){
 				var a = perm.slice();
@@ -11706,7 +11706,7 @@ $.jgrid.extend({
             "msel" : "multiselect",
             /* "msel_opts" : {}, */
 
-            /* dlog is either the name of a ui widget class that 
+            /* dlog is either the name of a ui widget class that
                behaves in a dialog-like way, or a function, that
                supports creating a dialog (when passed dlog_opts)
                or destroying a dialog (when passed the string
@@ -11716,7 +11716,7 @@ $.jgrid.extend({
 			"dialog_opts" : {
 				"minWidth": 470
 			},
-            /* dlog_opts is either an option object to be passed 
+            /* dlog_opts is either an option object to be passed
                to "dlog", or (more likely) a function that creates
                the options object.
                The default produces a suitable options object for
@@ -11750,7 +11750,7 @@ $.jgrid.extend({
                         self.jqGrid("hideCol", colModel[this.value].name);
                     }
                 });
-                
+
                 var perm = [];
 				//fixedCols.slice(0);
                 $('option:selected',select).each(function() { perm.push(parseInt(this.value,10)); });
@@ -11982,8 +11982,8 @@ $.jgrid.extend({
 						}
 						ui.helper.dropped = true;
 						if(opts.beforedrop && $.isFunction(opts.beforedrop) ) {
-							//parameters to this callback - event, element, data to be inserted, sender, reciever
-							// should return object which will be inserted into the reciever
+							//parameters to this callback - event, element, data to be inserted, sender, receiver
+							// should return object which will be inserted into the receiver
 							var datatoinsert = opts.beforedrop.call(this,ev,ui,getdata,$('#'+$.jgrid.jqID($t.p.id)),$(this));
 							if (typeof datatoinsert != "undefined" && datatoinsert !== null && typeof datatoinsert == "object") { getdata = datatoinsert; }
 						}
@@ -12024,12 +12024,12 @@ $.jgrid.extend({
 			"autoid" : true,
 			"autoidprefix" : "dnd_"
 		}, opts || {});
-		
+
 		if(!opts.connectWith) { return; }
 		opts.connectWith = opts.connectWith.split(",");
 		opts.connectWith = $.map(opts.connectWith,function(n){return $.trim(n);});
 		$.data($t,"dnd",opts);
-		
+
 		if($t.p.reccount != "0" && !$t.p.jqgdnd) {
 			updateDnD();
 		}
@@ -12076,7 +12076,7 @@ $.jgrid.extend({
 })(jQuery);
 /*
  Transform a table to a jqGrid.
- Peter Romianowski <pe...@optivo.de> 
+ Peter Romianowski <pe...@optivo.de>
  If the first column of the table contains checkboxes or
  radiobuttons then the jqGrid is made selectable.
 */
@@ -12164,7 +12164,7 @@ jQuery(selector).each(function() {
 			id = rowIds[a];
 			if (id && id.replace) {
 				// We have to do this since the value of a checkbox
-				// or radio button can be anything 
+				// or radio button can be anything
 				id = encodeURIComponent(id).replace(/[.\-%]/g, "_");
 			}
 		}
diff --git a/geode-pulse/src/main/webapp/scripts/lib/jquery.sparkline.js b/geode-pulse/src/main/webapp/scripts/lib/jquery.sparkline.js
index 3ffb051..5ded6cd 100644
--- a/geode-pulse/src/main/webapp/scripts/lib/jquery.sparkline.js
+++ b/geode-pulse/src/main/webapp/scripts/lib/jquery.sparkline.js
@@ -63,7 +63,7 @@
 *   <p>Sparkline: <span class="sparkline">1:1,2.7:4,3.4:6,5:6,6:8,8.7:5,9:3,10:5</span></p>
 *    $('#sparkline1').sparkline([ [1,1], [2.7,4], [3.4,6], [5,6], [6,8], [8.7,5], [9,3], [10,5] ])
 *
-* By default, options should be passed in as teh second argument to the sparkline function:
+* By default, options should be passed in as the second argument to the sparkline function:
 *   $('.sparkline').sparkline([1,2,3,4], {type: 'bar'})
 *
 * Options can also be set by passing them on the tag itself.  This feature is disabled by default though
diff --git a/geode-wan/src/test/java/org/apache/geode/internal/cache/wan/GatewayReceiverImplJUnitTest.java b/geode-wan/src/test/java/org/apache/geode/internal/cache/wan/GatewayReceiverImplJUnitTest.java
index 32edb9b..b737b8c 100644
--- a/geode-wan/src/test/java/org/apache/geode/internal/cache/wan/GatewayReceiverImplJUnitTest.java
+++ b/geode-wan/src/test/java/org/apache/geode/internal/cache/wan/GatewayReceiverImplJUnitTest.java
@@ -79,7 +79,7 @@ public class GatewayReceiverImplJUnitTest {
   }
 
   @Test
-  public void destroyCalledOnStoppedGatewayReceiverShouldRemoveRecieverFromCacheServers()
+  public void destroyCalledOnStoppedGatewayReceiverShouldRemoveReceiverFromCacheServers()
       throws IOException {
     InternalCache cache = mock(InternalCache.class);
     CacheServerImpl server = mock(CacheServerImpl.class);
@@ -96,7 +96,7 @@ public class GatewayReceiverImplJUnitTest {
   }
 
   @Test
-  public void destroyCalledOnStoppedGatewayReceiverShouldRemoveRecieverFromReceivers()
+  public void destroyCalledOnStoppedGatewayReceiverShouldRemoveReceiverFromReceivers()
       throws IOException {
     InternalCache cache = mock(InternalCache.class);
     CacheServerImpl server = mock(CacheServerImpl.class);
diff --git a/geode-web-api/src/main/java/org/apache/geode/rest/internal/web/controllers/PdxBasedCrudController.java b/geode-web-api/src/main/java/org/apache/geode/rest/internal/web/controllers/PdxBasedCrudController.java
index 7fdd07f..c0fbf4c 100644
--- a/geode-web-api/src/main/java/org/apache/geode/rest/internal/web/controllers/PdxBasedCrudController.java
+++ b/geode-web-api/src/main/java/org/apache/geode/rest/internal/web/controllers/PdxBasedCrudController.java
@@ -197,7 +197,7 @@ public class PdxBasedCrudController extends CommonCrudController {
    * Reading data for set of keys
    *
    * @param region gemfire region name
-   * @param keys string containing comma seperated keys
+   * @param keys string containing comma separated keys
    * @return JSON document
    */
   @RequestMapping(method = RequestMethod.GET, value = "/{region}/{keys}",

-- 
To stop receiving notification emails like this one, please contact
pivotalsarge@apache.org.