You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@cassandra.apache.org by db...@apache.org on 2016/06/19 01:54:09 UTC

cassandra git commit: minor javadoc fixes

Repository: cassandra
Updated Branches:
  refs/heads/trunk 4754cddfb -> 79c5bc314


minor javadoc fixes


Project: http://git-wip-us.apache.org/repos/asf/cassandra/repo
Commit: http://git-wip-us.apache.org/repos/asf/cassandra/commit/79c5bc31
Tree: http://git-wip-us.apache.org/repos/asf/cassandra/tree/79c5bc31
Diff: http://git-wip-us.apache.org/repos/asf/cassandra/diff/79c5bc31

Branch: refs/heads/trunk
Commit: 79c5bc314b09e8cbcc353798945f67b409301999
Parents: 4754cdd
Author: Dave Brosius <db...@mebigfatguy.com>
Authored: Sat Jun 18 21:53:25 2016 -0400
Committer: Dave Brosius <db...@mebigfatguy.com>
Committed: Sat Jun 18 21:53:25 2016 -0400

----------------------------------------------------------------------
 src/java/org/apache/cassandra/db/filter/RowFilter.java         | 2 +-
 .../org/apache/cassandra/db/rows/UnfilteredSerializer.java     | 6 +++---
 src/java/org/apache/cassandra/db/rows/WithOnlyQueriedData.java | 2 +-
 src/java/org/apache/cassandra/db/view/View.java                | 3 ---
 .../org/apache/cassandra/hadoop/cql3/CqlBulkOutputFormat.java  | 4 ++--
 src/java/org/apache/cassandra/index/Index.java                 | 4 ++--
 .../org/apache/cassandra/index/IndexNotAvailableException.java | 2 +-
 src/java/org/apache/cassandra/index/SecondaryIndexManager.java | 2 +-
 src/java/org/apache/cassandra/locator/TokenMetadata.java       | 2 +-
 src/java/org/apache/cassandra/metrics/HintsServiceMetrics.java | 2 +-
 src/java/org/apache/cassandra/utils/concurrent/Ref.java        | 3 ++-
 11 files changed, 15 insertions(+), 17 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/cassandra/blob/79c5bc31/src/java/org/apache/cassandra/db/filter/RowFilter.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/db/filter/RowFilter.java b/src/java/org/apache/cassandra/db/filter/RowFilter.java
index e187e3d..6626275 100644
--- a/src/java/org/apache/cassandra/db/filter/RowFilter.java
+++ b/src/java/org/apache/cassandra/db/filter/RowFilter.java
@@ -1011,7 +1011,7 @@ public abstract class RowFilter implements Iterable<RowFilter.Expression>
      * registered before sending or receiving any messages containing expressions of that type.
      * Use of custom filtering expressions in a mixed version cluster should be handled with caution
      * as the order in which types are registered is significant: if continuity of use during upgrades
-     * is important, new types should registered last & obsoleted types should still be registered (
+     * is important, new types should registered last and obsoleted types should still be registered (
      * or dummy implementations registered in their place) to preserve consistent identifiers across
      * the cluster).
      *

http://git-wip-us.apache.org/repos/asf/cassandra/blob/79c5bc31/src/java/org/apache/cassandra/db/rows/UnfilteredSerializer.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/db/rows/UnfilteredSerializer.java b/src/java/org/apache/cassandra/db/rows/UnfilteredSerializer.java
index e28528c..890806c 100644
--- a/src/java/org/apache/cassandra/db/rows/UnfilteredSerializer.java
+++ b/src/java/org/apache/cassandra/db/rows/UnfilteredSerializer.java
@@ -48,7 +48,7 @@ import org.apache.cassandra.io.util.DataOutputPlus;
  *     where:
  *     <ul>
  *       <li>{@code <clustering>} is the row clustering as serialized by
- *           {@link Clustering.serializer} (note that static row are an
+ *           {@link org.apache.cassandra.db.Clustering.Serializer} (note that static row are an
  *           exception and don't have this). </li>
  *       <li>{@code <sizes>} are the sizes of the whole unfiltered on disk and
  *           of the previous unfiltered. This is only present for sstables and
@@ -60,7 +60,7 @@ import org.apache.cassandra.io.util.DataOutputPlus;
  *           by the flags and if present, it conists of both the deletion
  *           timestamp and local deletion time.</li>
  *       <li>{@code <columns>} are the columns present in the row  encoded by
- *           {@link Columns.serializer#serializeSubset}. It is absent if the row
+ *           {@link org.apache.cassandra.db.Columns.Serializer#serializeSubset}. It is absent if the row
  *           contains all the columns of the {@code SerializationHeader} (which
  *           is then indicated by a flag). </li>
  *       <li>{@code <columns_data>} is the data for each of the column present
@@ -80,7 +80,7 @@ import org.apache.cassandra.io.util.DataOutputPlus;
  *   </li>
  *   <li>
  *     {@code <marker>} is {@code <bound><deletion>} where {@code <bound>} is
- *     the marker bound as serialized by {@link ClusteringBoundOrBoundary.serializer}
+ *     the marker bound as serialized by {@link org.apache.cassandra.db.ClusteringBoundOrBoundary.Serializer}
  *     and {@code <deletion>} is the marker deletion time.
  *   </li>
  * </ul>

http://git-wip-us.apache.org/repos/asf/cassandra/blob/79c5bc31/src/java/org/apache/cassandra/db/rows/WithOnlyQueriedData.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/db/rows/WithOnlyQueriedData.java b/src/java/org/apache/cassandra/db/rows/WithOnlyQueriedData.java
index 3930f91..5e7d905 100644
--- a/src/java/org/apache/cassandra/db/rows/WithOnlyQueriedData.java
+++ b/src/java/org/apache/cassandra/db/rows/WithOnlyQueriedData.java
@@ -23,7 +23,7 @@ import org.apache.cassandra.db.transform.Transformation;
 
 /**
  * Function to skip cells (from an iterator) that are not part of those queried by the user
- * according to the provided {@code ColumnFilter}. See {@link UnfilteredRowIterators#withoutSkippedValues}
+ * according to the provided {@code ColumnFilter}. See {@link UnfilteredRowIterators#withOnlyQueriedData}
  * for more details.
  */
 public class WithOnlyQueriedData<I extends BaseRowIterator<?>> extends Transformation<I>

http://git-wip-us.apache.org/repos/asf/cassandra/blob/79c5bc31/src/java/org/apache/cassandra/db/view/View.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/db/view/View.java b/src/java/org/apache/cassandra/db/view/View.java
index 8babc99..0b8de9e 100644
--- a/src/java/org/apache/cassandra/db/view/View.java
+++ b/src/java/org/apache/cassandra/db/view/View.java
@@ -81,9 +81,6 @@ public class View
 
     /**
      * This updates the columns stored which are dependent on the base CFMetaData.
-     *
-     * @return true if the view contains only columns which are part of the base's primary key; false if there is at
-     *         least one column which is not.
      */
     public void updateDefinition(ViewDefinition definition)
     {

http://git-wip-us.apache.org/repos/asf/cassandra/blob/79c5bc31/src/java/org/apache/cassandra/hadoop/cql3/CqlBulkOutputFormat.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/hadoop/cql3/CqlBulkOutputFormat.java b/src/java/org/apache/cassandra/hadoop/cql3/CqlBulkOutputFormat.java
index 051447c..dfdf855 100644
--- a/src/java/org/apache/cassandra/hadoop/cql3/CqlBulkOutputFormat.java
+++ b/src/java/org/apache/cassandra/hadoop/cql3/CqlBulkOutputFormat.java
@@ -45,10 +45,10 @@ import org.apache.hadoop.util.Progressable;
  * As is the case with the {@link org.apache.cassandra.hadoop.cql3.CqlOutputFormat}, 
  * you need to set the prepared statement in your
  * Hadoop job Configuration. The {@link CqlConfigHelper} class, through its
- * {@link ConfigHelper#setOutputPreparedStatement} method, is provided to make this
+ * {@link org.apache.cassandra.hadoop.ConfigHelper#setOutputPreparedStatement} method, is provided to make this
  * simple.
  * you need to set the Keyspace. The {@link ConfigHelper} class, through its
- * {@link ConfigHelper#setOutputColumnFamily} method, is provided to make this
+ * {@link org.apache.cassandra.hadoop.ConfigHelper#setOutputColumnFamily} method, is provided to make this
  * simple.
  * </p>
  */

http://git-wip-us.apache.org/repos/asf/cassandra/blob/79c5bc31/src/java/org/apache/cassandra/index/Index.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/index/Index.java b/src/java/org/apache/cassandra/index/Index.java
index f855965..251d331 100644
--- a/src/java/org/apache/cassandra/index/Index.java
+++ b/src/java/org/apache/cassandra/index/Index.java
@@ -75,7 +75,7 @@ import org.apache.cassandra.utils.concurrent.OpOrder;
  * scheduling its execution can rest with SecondaryIndexManager. For instance, a task like reloading index metadata
  * following potential updates caused by modifications to the base table may be performed in a blocking way. In
  * contrast, adding a new index may require it to be built from existing SSTable data, a potentially expensive task
- * which should be performed asyncronously.
+ * which should be performed asynchronously.
  *
  * Index Selection:
  * There are two facets to index selection, write time and read time selection. The former is concerned with
@@ -108,7 +108,7 @@ import org.apache.cassandra.utils.concurrent.OpOrder;
  * whether any of them are supported by a registered Index. supportsExpression is used to filter out Indexes which
  * cannot support a given Expression. After filtering, the set of candidate indexes are ranked according to the result
  * of getEstimatedResultRows and the most selective (i.e. the one expected to return the smallest number of results) is
- * chosen. A Searcher instance is then obtained from the searcherFor method & used to perform the actual Index lookup.
+ * chosen. A Searcher instance is then obtained from the searcherFor method and used to perform the actual Index lookup.
  * Finally, Indexes can define a post processing step to be performed on the coordinator, after results (partitions from
  * the primary table) have been received from replicas and reconciled. This post processing is defined as a
  * java.util.functions.BiFunction<PartitionIterator, RowFilter, PartitionIterator>, that is a function which takes as

http://git-wip-us.apache.org/repos/asf/cassandra/blob/79c5bc31/src/java/org/apache/cassandra/index/IndexNotAvailableException.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/index/IndexNotAvailableException.java b/src/java/org/apache/cassandra/index/IndexNotAvailableException.java
index 5440e2a..5e5a753 100644
--- a/src/java/org/apache/cassandra/index/IndexNotAvailableException.java
+++ b/src/java/org/apache/cassandra/index/IndexNotAvailableException.java
@@ -25,7 +25,7 @@ public final class IndexNotAvailableException extends RuntimeException
 {
     /**
      * Creates a new <code>IndexNotAvailableException</code> for the specified index.
-     * @param name the index name
+     * @param index the index
      */
     public IndexNotAvailableException(Index index)
     {

http://git-wip-us.apache.org/repos/asf/cassandra/blob/79c5bc31/src/java/org/apache/cassandra/index/SecondaryIndexManager.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/index/SecondaryIndexManager.java b/src/java/org/apache/cassandra/index/SecondaryIndexManager.java
index b5ebd58..cfc73ce 100644
--- a/src/java/org/apache/cassandra/index/SecondaryIndexManager.java
+++ b/src/java/org/apache/cassandra/index/SecondaryIndexManager.java
@@ -561,7 +561,7 @@ public class SecondaryIndexManager implements IndexRegistry
      * Delete all data from all indexes for this partition.
      * For when cleanup rips a partition out entirely.
      *
-     * TODO : improve cleanup transaction to batch updates & perform them async
+     * TODO : improve cleanup transaction to batch updates and perform them async
      */
     public void deletePartition(UnfilteredRowIterator partition, int nowInSec)
     {

http://git-wip-us.apache.org/repos/asf/cassandra/blob/79c5bc31/src/java/org/apache/cassandra/locator/TokenMetadata.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/locator/TokenMetadata.java b/src/java/org/apache/cassandra/locator/TokenMetadata.java
index caa7661..8e43016 100644
--- a/src/java/org/apache/cassandra/locator/TokenMetadata.java
+++ b/src/java/org/apache/cassandra/locator/TokenMetadata.java
@@ -126,7 +126,7 @@ public class TokenMetadata
     }
 
     /**
-     * To be used by tests only (via {@link StorageService.setPartitionerUnsafe}).
+     * To be used by tests only (via {@link org.apache.cassandra.service.StorageService#setPartitionerUnsafe}).
      */
     @VisibleForTesting
     public TokenMetadata cloneWithNewPartitioner(IPartitioner newPartitioner)

http://git-wip-us.apache.org/repos/asf/cassandra/blob/79c5bc31/src/java/org/apache/cassandra/metrics/HintsServiceMetrics.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/metrics/HintsServiceMetrics.java b/src/java/org/apache/cassandra/metrics/HintsServiceMetrics.java
index 062f67d..0d36905 100644
--- a/src/java/org/apache/cassandra/metrics/HintsServiceMetrics.java
+++ b/src/java/org/apache/cassandra/metrics/HintsServiceMetrics.java
@@ -18,7 +18,7 @@
 package org.apache.cassandra.metrics;
 
 /**
- * Metrics for {@link HintsService}.
+ * Metrics for {@link org.apache.cassandra.hints.HintsService}.
  */
 public final class HintsServiceMetrics
 {

http://git-wip-us.apache.org/repos/asf/cassandra/blob/79c5bc31/src/java/org/apache/cassandra/utils/concurrent/Ref.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/utils/concurrent/Ref.java b/src/java/org/apache/cassandra/utils/concurrent/Ref.java
index 71d04f0..c3dd8b2 100644
--- a/src/java/org/apache/cassandra/utils/concurrent/Ref.java
+++ b/src/java/org/apache/cassandra/utils/concurrent/Ref.java
@@ -68,13 +68,14 @@ import static org.apache.cassandra.utils.Throwables.merge;
  * This class' functionality is achieved by what may look at first glance like a complex web of references,
  * but boils down to:
  *
+ * {@code
  * Target --> selfRef --> [Ref.State] <--> Ref.GlobalState --> Tidy
  *                                             ^
  *                                             |
  * Ref ----------------------------------------
  *                                             |
  * Global -------------------------------------
- *
+ * }
  * So that, if Target is collected, Impl is collected and, hence, so is selfRef.
  *
  * Once ref or selfRef are collected, the paired Ref.State's release method is called, which if it had