Return-Path: X-Original-To: apmail-accumulo-commits-archive@www.apache.org Delivered-To: apmail-accumulo-commits-archive@www.apache.org Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by minotaur.apache.org (Postfix) with SMTP id 56192176DE for ; Fri, 9 Jan 2015 02:44:10 +0000 (UTC) Received: (qmail 3552 invoked by uid 500); 9 Jan 2015 02:44:11 -0000 Delivered-To: apmail-accumulo-commits-archive@accumulo.apache.org Received: (qmail 3457 invoked by uid 500); 9 Jan 2015 02:44:11 -0000 Mailing-List: contact commits-help@accumulo.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: dev@accumulo.apache.org Delivered-To: mailing list commits@accumulo.apache.org Received: (qmail 779 invoked by uid 99); 9 Jan 2015 02:44:07 -0000 Received: from tyr.zones.apache.org (HELO tyr.zones.apache.org) (140.211.11.114) by apache.org (qpsmtpd/0.29) with ESMTP; Fri, 09 Jan 2015 02:44:07 +0000 Received: by tyr.zones.apache.org (Postfix, from userid 65534) id E75FD90DE25; Fri, 9 Jan 2015 02:44:06 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit From: ctubbsii@apache.org To: commits@accumulo.apache.org Date: Fri, 09 Jan 2015 02:44:51 -0000 Message-Id: In-Reply-To: References: X-Mailer: ASF-Git Admin Mailer Subject: [47/66] [abbrv] accumulo git commit: ACCUMULO-3451 Format master branch (1.7.0-SNAPSHOT) http://git-wip-us.apache.org/repos/asf/accumulo/blob/6bc67602/core/src/main/java/org/apache/accumulo/core/client/MutationsRejectedException.java ---------------------------------------------------------------------- diff --git a/core/src/main/java/org/apache/accumulo/core/client/MutationsRejectedException.java b/core/src/main/java/org/apache/accumulo/core/client/MutationsRejectedException.java index 37233f5..962ef25 100644 --- a/core/src/main/java/org/apache/accumulo/core/client/MutationsRejectedException.java +++ b/core/src/main/java/org/apache/accumulo/core/client/MutationsRejectedException.java @@ -32,16 +32,16 @@ import org.apache.accumulo.core.data.KeyExtent; /** * Communicate the failed mutations of a BatchWriter back to the client. - * + * */ public class MutationsRejectedException extends AccumuloException { private static final long serialVersionUID = 1L; - + private List cvsl; private Map> af; private Collection es; private int unknownErrors; - + /** * @param cvsList * list of constraint violations @@ -51,7 +51,7 @@ public class MutationsRejectedException extends AccumuloException { * server side errors * @param unknownErrors * number of unknown errors - * + * * @deprecated since 1.6.0, see {@link #MutationsRejectedException(Instance, List, HashMap, Collection, int, Throwable)} */ @Deprecated @@ -64,7 +64,7 @@ public class MutationsRejectedException extends AccumuloException { this.es = serverSideErrors; this.unknownErrors = unknownErrors; } - + /** * @param cvsList * list of constraint violations @@ -84,30 +84,30 @@ public class MutationsRejectedException extends AccumuloException { this.es = serverSideErrors; this.unknownErrors = unknownErrors; } - + private static String format(HashMap> hashMap, Instance instance) { Map> result = new HashMap>(); - + for (Entry> entry : hashMap.entrySet()) { String tableInfo = Tables.getPrintableTableInfoFromId(instance, entry.getKey().getTableId().toString()); - + if (!result.containsKey(tableInfo)) { result.put(tableInfo, new HashSet()); } - + result.get(tableInfo).addAll(hashMap.get(entry.getKey())); } - + return result.toString(); } - + /** * @return the internal list of constraint violations */ public List getConstraintViolationSummaries() { return cvsl; } - + /** * @return the internal list of authorization failures * @deprecated since 1.5, see {@link #getAuthorizationFailuresMap()} @@ -116,7 +116,7 @@ public class MutationsRejectedException extends AccumuloException { public List getAuthorizationFailures() { return new ArrayList(af.keySet()); } - + /** * @return the internal mapping of keyextent mappings to SecurityErrorCode * @since 1.5.0 @@ -124,18 +124,18 @@ public class MutationsRejectedException extends AccumuloException { public Map> getAuthorizationFailuresMap() { return af; } - + /** - * + * * @return A list of servers that had internal errors when mutations were written - * + * */ public Collection getErrorServers() { return es; } - + /** - * + * * @return a count of unknown exceptions that occurred during processing */ public int getUnknownExceptions() { http://git-wip-us.apache.org/repos/asf/accumulo/blob/6bc67602/core/src/main/java/org/apache/accumulo/core/client/NamespaceExistsException.java ---------------------------------------------------------------------- diff --git a/core/src/main/java/org/apache/accumulo/core/client/NamespaceExistsException.java b/core/src/main/java/org/apache/accumulo/core/client/NamespaceExistsException.java index d2cb607..223ab3f 100644 --- a/core/src/main/java/org/apache/accumulo/core/client/NamespaceExistsException.java +++ b/core/src/main/java/org/apache/accumulo/core/client/NamespaceExistsException.java @@ -24,7 +24,7 @@ import org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException public class NamespaceExistsException extends Exception { /** * Exception to throw if an operation is attempted on a namespace that already exists. - * + * */ private static final long serialVersionUID = 1L; http://git-wip-us.apache.org/repos/asf/accumulo/blob/6bc67602/core/src/main/java/org/apache/accumulo/core/client/NamespaceNotFoundException.java ---------------------------------------------------------------------- diff --git a/core/src/main/java/org/apache/accumulo/core/client/NamespaceNotFoundException.java b/core/src/main/java/org/apache/accumulo/core/client/NamespaceNotFoundException.java index 031cf16..e330d69 100644 --- a/core/src/main/java/org/apache/accumulo/core/client/NamespaceNotFoundException.java +++ b/core/src/main/java/org/apache/accumulo/core/client/NamespaceNotFoundException.java @@ -24,7 +24,7 @@ import org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException public class NamespaceNotFoundException extends Exception { /** * Exception to throw if an operation is attempted on a namespace that doesn't exist. - * + * */ private static final long serialVersionUID = 1L; http://git-wip-us.apache.org/repos/asf/accumulo/blob/6bc67602/core/src/main/java/org/apache/accumulo/core/client/RowIterator.java ---------------------------------------------------------------------- diff --git a/core/src/main/java/org/apache/accumulo/core/client/RowIterator.java b/core/src/main/java/org/apache/accumulo/core/client/RowIterator.java index f5e9547..190b0b2 100644 --- a/core/src/main/java/org/apache/accumulo/core/client/RowIterator.java +++ b/core/src/main/java/org/apache/accumulo/core/client/RowIterator.java @@ -27,13 +27,13 @@ import org.apache.hadoop.io.Text; /** * Group Key/Value pairs into Iterators over rows. Suggested usage: - * + * *
  * RowIterator rowIterator = new RowIterator(connector.createScanner(tableName, authorizations));
  * 
*/ public class RowIterator implements Iterator>> { - + /** * Iterate over entries in a single row. */ @@ -42,7 +42,7 @@ public class RowIterator implements Iterator>> { private Text currentRow = null; private long count = 0; private boolean disabled = false; - + /** * SingleRowIter must be passed a PeekingIterator so that it can peek at the next entry to see if it belongs in the current row or not. */ @@ -51,21 +51,21 @@ public class RowIterator implements Iterator>> { if (source.hasNext()) currentRow = source.peek().getKey().getRow(); } - + @Override public boolean hasNext() { if (disabled) throw new IllegalStateException("SingleRowIter no longer valid"); return currentRow != null; } - + @Override public Entry next() { if (disabled) throw new IllegalStateException("SingleRowIter no longer valid"); return _next(); } - + private Entry _next() { if (currentRow == null) throw new NoSuchElementException(); @@ -76,19 +76,19 @@ public class RowIterator implements Iterator>> { } return kv; } - + @Override public void remove() { throw new UnsupportedOperationException(); } - + /** * Get a count of entries read from the row (only equals the number of entries in the row when the row has been read fully). */ public long getCount() { return count; } - + /** * Consume the rest of the row. Disables the iterator from future use. */ @@ -98,28 +98,28 @@ public class RowIterator implements Iterator>> { _next(); } } - + private final PeekingIterator> iter; private long count = 0; private SingleRowIter lastIter = null; - + /** * Create an iterator from an (ordered) sequence of KeyValue pairs. */ public RowIterator(Iterator> iterator) { this.iter = new PeekingIterator>(iterator); } - + /** * Create an iterator from an Iterable. */ public RowIterator(Iterable> iterable) { this(iterable.iterator()); } - + /** * Returns true if there is at least one more row to get. - * + * * If the last row hasn't been fully read, this method will read through the end of the last row so it can determine if the underlying iterator has a next * row. The last row is disabled from future use. */ @@ -132,7 +132,7 @@ public class RowIterator implements Iterator>> { } return iter.hasNext(); } - + /** * Fetch the next row. */ @@ -142,7 +142,7 @@ public class RowIterator implements Iterator>> { throw new NoSuchElementException(); return lastIter = new SingleRowIter(iter); } - + /** * Unsupported. */ @@ -150,7 +150,7 @@ public class RowIterator implements Iterator>> { public void remove() { throw new UnsupportedOperationException(); } - + /** * Get a count of the total number of entries in all rows read so far. */ http://git-wip-us.apache.org/repos/asf/accumulo/blob/6bc67602/core/src/main/java/org/apache/accumulo/core/client/Scanner.java ---------------------------------------------------------------------- diff --git a/core/src/main/java/org/apache/accumulo/core/client/Scanner.java b/core/src/main/java/org/apache/accumulo/core/client/Scanner.java index 112179e..372ee42 100644 --- a/core/src/main/java/org/apache/accumulo/core/client/Scanner.java +++ b/core/src/main/java/org/apache/accumulo/core/client/Scanner.java @@ -20,83 +20,86 @@ import org.apache.accumulo.core.data.Range; /** * Scans a table over a given range. - * + * * "Clients can iterate over multiple column families, and there are several mechanisms for limiting the rows, columns, and timestamps traversed by a scan. For * example, we could restrict [a] scan ... to only produce anchors whose columns match [a] regular expression ..., or to only produce anchors whose timestamps * fall within ten days of the current time." */ public interface Scanner extends ScannerBase { - + /** * This setting determines how long a scanner will automatically retry when a failure occurs. By default a scanner will retry forever. - * + * * @param timeOut * in seconds * @deprecated Since 1.5. See {@link ScannerBase#setTimeout(long, java.util.concurrent.TimeUnit)} */ @Deprecated void setTimeOut(int timeOut); - + /** * Returns the setting for how long a scanner will automatically retry when a failure occurs. - * + * * @return the timeout configured for this scanner * @deprecated Since 1.5. See {@link ScannerBase#getTimeout(java.util.concurrent.TimeUnit)} */ @Deprecated int getTimeOut(); - + /** * Sets the range of keys to scan over. - * + * * @param range * key range to begin and end scan */ void setRange(Range range); - + /** * Returns the range of keys to scan over. - * + * * @return the range configured for this scanner */ Range getRange(); - + /** * Sets the number of Key/Value pairs that will be fetched at a time from a tablet server. - * + * * @param size * the number of Key/Value pairs to fetch per call to Accumulo */ void setBatchSize(int size); - + /** * Returns the batch size (number of Key/Value pairs) that will be fetched at a time from a tablet server. - * + * * @return the batch size configured for this scanner */ int getBatchSize(); - + /** * Enables row isolation. Writes that occur to a row after a scan of that row has begun will not be seen if this option is enabled. */ void enableIsolation(); - + /** * Disables row isolation. Writes that occur to a row after a scan of that row has begun may be seen if this option is enabled. */ void disableIsolation(); - + /** * The number of batches of Key/Value pairs returned before the {@link Scanner} will begin to prefetch the next batch + * * @return Number of batches before read-ahead begins * @since 1.6.0 */ long getReadaheadThreshold(); - + /** * Sets the number of batches of Key/Value pairs returned before the {@link Scanner} will begin to prefetch the next batch - * @param batches Non-negative number of batches + * + * @param batches + * Non-negative number of batches * @since 1.6.0 */ - void setReadaheadThreshold(long batches); + void setReadaheadThreshold(long batches); } http://git-wip-us.apache.org/repos/asf/accumulo/blob/6bc67602/core/src/main/java/org/apache/accumulo/core/client/ScannerBase.java ---------------------------------------------------------------------- diff --git a/core/src/main/java/org/apache/accumulo/core/client/ScannerBase.java b/core/src/main/java/org/apache/accumulo/core/client/ScannerBase.java index 335b63a..82a3299 100644 --- a/core/src/main/java/org/apache/accumulo/core/client/ScannerBase.java +++ b/core/src/main/java/org/apache/accumulo/core/client/ScannerBase.java @@ -26,13 +26,13 @@ import org.apache.hadoop.io.Text; /** * This class hosts configuration methods that are shared between different types of scanners. - * + * */ public interface ScannerBase extends Iterable> { - + /** * Add a server-side scan iterator. - * + * * @param cfg * fully specified scan-time iterator, including all options for the iterator. Any changes to the iterator setting after this call are not propagated * to the stored iterator. @@ -40,19 +40,19 @@ public interface ScannerBase extends Iterable> { * if the setting conflicts with existing iterators */ void addScanIterator(IteratorSetting cfg); - + /** * Remove an iterator from the list of iterators. - * + * * @param iteratorName * nickname used for the iterator */ void removeScanIterator(String iteratorName); - + /** * Update the options for an iterator. Note that this does not change the iterator options during a scan, it just replaces the given option on a * configured iterator before a scan is started. - * + * * @param iteratorName * the name of the iterator to change * @param key @@ -61,61 +61,61 @@ public interface ScannerBase extends Iterable> { * the new value for the named option */ void updateScanIteratorOption(String iteratorName, String key, String value); - + /** * Adds a column family to the list of columns that will be fetched by this scanner. By default when no columns have been added the scanner fetches all * columns. - * + * * @param col * the column family to be fetched */ void fetchColumnFamily(Text col); - + /** * Adds a column to the list of columns that will be fetched by this scanner. The column is identified by family and qualifier. By default when no columns * have been added the scanner fetches all columns. - * + * * @param colFam * the column family of the column to be fetched * @param colQual * the column qualifier of the column to be fetched */ void fetchColumn(Text colFam, Text colQual); - + /** * Clears the columns to be fetched (useful for resetting the scanner for reuse). Once cleared, the scanner will fetch all columns. */ void clearColumns(); - + /** * Clears scan iterators prior to returning a scanner to the pool. */ void clearScanIterators(); - + /** * Returns an iterator over an accumulo table. This iterator uses the options that are currently set for its lifetime, so setting options will have no effect * on existing iterators. - * + * * Keys returned by the iterator are not guaranteed to be in sorted order. - * + * * @return an iterator over Key,Value pairs which meet the restrictions set on the scanner */ Iterator> iterator(); - + /** * This setting determines how long a scanner will automatically retry when a failure occurs. By default a scanner will retry forever. - * + * * Setting to zero or Long.MAX_VALUE and TimeUnit.MILLISECONDS means to retry forever. - * + * * @param timeUnit * determines how timeout is interpreted * @since 1.5.0 */ void setTimeout(long timeOut, TimeUnit timeUnit); - + /** * Returns the setting for how long a scanner will automatically retry when a failure occurs. - * + * * @return the timeout configured for this scanner * @since 1.5.0 */ @@ -123,6 +123,7 @@ public interface ScannerBase extends Iterable> { /** * Closes any underlying connections on the scanner + * * @since 1.5.0 */ void close(); http://git-wip-us.apache.org/repos/asf/accumulo/blob/6bc67602/core/src/main/java/org/apache/accumulo/core/client/TableDeletedException.java ---------------------------------------------------------------------- diff --git a/core/src/main/java/org/apache/accumulo/core/client/TableDeletedException.java b/core/src/main/java/org/apache/accumulo/core/client/TableDeletedException.java index bc0b105..c1b1d6f 100644 --- a/core/src/main/java/org/apache/accumulo/core/client/TableDeletedException.java +++ b/core/src/main/java/org/apache/accumulo/core/client/TableDeletedException.java @@ -18,21 +18,21 @@ package org.apache.accumulo.core.client; /** * This exception is thrown if a table is deleted after an operation starts. - * + * * For example if table A exist when a scan is started, but is deleted during the scan then this exception is thrown. - * + * */ public class TableDeletedException extends RuntimeException { - + private static final long serialVersionUID = 1L; private String tableId; - + public TableDeletedException(String tableId) { super("Table ID " + tableId + " was deleted"); this.tableId = tableId; } - + public String getTableId() { return tableId; } http://git-wip-us.apache.org/repos/asf/accumulo/blob/6bc67602/core/src/main/java/org/apache/accumulo/core/client/TableExistsException.java ---------------------------------------------------------------------- diff --git a/core/src/main/java/org/apache/accumulo/core/client/TableExistsException.java b/core/src/main/java/org/apache/accumulo/core/client/TableExistsException.java index bec008d..72c633c 100644 --- a/core/src/main/java/org/apache/accumulo/core/client/TableExistsException.java +++ b/core/src/main/java/org/apache/accumulo/core/client/TableExistsException.java @@ -24,10 +24,10 @@ import org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException public class TableExistsException extends Exception { /** * Exception to throw if an operation is attempted on a table that already exists. - * + * */ private static final long serialVersionUID = 1L; - + /** * @param tableId * the internal id of the table that exists @@ -40,7 +40,7 @@ public class TableExistsException extends Exception { super("Table" + (tableName != null && !tableName.isEmpty() ? " " + tableName : "") + (tableId != null && !tableId.isEmpty() ? " (Id=" + tableId + ")" : "") + " exists" + (description != null && !description.isEmpty() ? " (" + description + ")" : "")); } - + /** * @param tableId * the internal id of the table that exists @@ -55,7 +55,7 @@ public class TableExistsException extends Exception { this(tableId, tableName, description); super.initCause(cause); } - + /** * @param e * constructs an exception from a thrift exception http://git-wip-us.apache.org/repos/asf/accumulo/blob/6bc67602/core/src/main/java/org/apache/accumulo/core/client/TableNotFoundException.java ---------------------------------------------------------------------- diff --git a/core/src/main/java/org/apache/accumulo/core/client/TableNotFoundException.java b/core/src/main/java/org/apache/accumulo/core/client/TableNotFoundException.java index 6d27336..1e53936 100644 --- a/core/src/main/java/org/apache/accumulo/core/client/TableNotFoundException.java +++ b/core/src/main/java/org/apache/accumulo/core/client/TableNotFoundException.java @@ -25,7 +25,7 @@ import org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException public class TableNotFoundException extends Exception { /** * Exception to throw if an operation is attempted on a table that doesn't exist. - * + * */ private static final long serialVersionUID = 1L; http://git-wip-us.apache.org/repos/asf/accumulo/blob/6bc67602/core/src/main/java/org/apache/accumulo/core/client/TableOfflineException.java ---------------------------------------------------------------------- diff --git a/core/src/main/java/org/apache/accumulo/core/client/TableOfflineException.java b/core/src/main/java/org/apache/accumulo/core/client/TableOfflineException.java index 9edb904..ef63228 100644 --- a/core/src/main/java/org/apache/accumulo/core/client/TableOfflineException.java +++ b/core/src/main/java/org/apache/accumulo/core/client/TableOfflineException.java @@ -19,9 +19,9 @@ package org.apache.accumulo.core.client; import org.apache.accumulo.core.client.impl.Tables; public class TableOfflineException extends RuntimeException { - + private static final long serialVersionUID = 1L; - + private static String getTableName(Instance instance, String tableId) { if (tableId == null) return " "; @@ -32,7 +32,7 @@ public class TableOfflineException extends RuntimeException { return " (" + tableId + ")"; } } - + public TableOfflineException(Instance instance, String tableId) { super("Table " + getTableName(instance, tableId) + " is offline"); } http://git-wip-us.apache.org/repos/asf/accumulo/blob/6bc67602/core/src/main/java/org/apache/accumulo/core/client/TimedOutException.java ---------------------------------------------------------------------- diff --git a/core/src/main/java/org/apache/accumulo/core/client/TimedOutException.java b/core/src/main/java/org/apache/accumulo/core/client/TimedOutException.java index 4b142e9..5ec9c59 100644 --- a/core/src/main/java/org/apache/accumulo/core/client/TimedOutException.java +++ b/core/src/main/java/org/apache/accumulo/core/client/TimedOutException.java @@ -24,23 +24,23 @@ import java.util.Set; * @since 1.5.0 */ public class TimedOutException extends RuntimeException { - + private Set timedoutServers; - + private static final long serialVersionUID = 1L; - + private static String shorten(Set set) { if (set.size() < 10) { return set.toString(); } - + return new ArrayList(set).subList(0, 10).toString() + " ... " + (set.size() - 10) + " servers not shown"; } public TimedOutException(Set timedoutServers) { super("Servers timed out " + shorten(timedoutServers)); this.timedoutServers = timedoutServers; - + } public TimedOutException(String msg) { http://git-wip-us.apache.org/repos/asf/accumulo/blob/6bc67602/core/src/main/java/org/apache/accumulo/core/client/ZooKeeperInstance.java ---------------------------------------------------------------------- diff --git a/core/src/main/java/org/apache/accumulo/core/client/ZooKeeperInstance.java b/core/src/main/java/org/apache/accumulo/core/client/ZooKeeperInstance.java index b12e189..7c8f2e2 100644 --- a/core/src/main/java/org/apache/accumulo/core/client/ZooKeeperInstance.java +++ b/core/src/main/java/org/apache/accumulo/core/client/ZooKeeperInstance.java @@ -129,8 +129,8 @@ public class ZooKeeperInstance implements Instance { /** * @param config - * Client configuration for specifying connection options. - * See {@link ClientConfiguration} which extends Configuration with convenience methods specific to Accumulo. + * Client configuration for specifying connection options. See {@link ClientConfiguration} which extends Configuration with convenience methods + * specific to Accumulo. * @since 1.6.0 */ public ZooKeeperInstance(Configuration config) { @@ -140,7 +140,7 @@ public class ZooKeeperInstance implements Instance { ZooKeeperInstance(Configuration config, ZooCacheFactory zcf) { checkArgument(config != null, "config is null"); if (config instanceof ClientConfiguration) { - this.clientConf = (ClientConfiguration)config; + this.clientConf = (ClientConfiguration) config; } else { this.clientConf = new ClientConfiguration(config); } http://git-wip-us.apache.org/repos/asf/accumulo/blob/6bc67602/core/src/main/java/org/apache/accumulo/core/client/admin/ActiveCompaction.java ---------------------------------------------------------------------- diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/ActiveCompaction.java b/core/src/main/java/org/apache/accumulo/core/client/admin/ActiveCompaction.java index 41b9c67..b9de4c2 100644 --- a/core/src/main/java/org/apache/accumulo/core/client/admin/ActiveCompaction.java +++ b/core/src/main/java/org/apache/accumulo/core/client/admin/ActiveCompaction.java @@ -22,9 +22,8 @@ import org.apache.accumulo.core.client.IteratorSetting; import org.apache.accumulo.core.client.TableNotFoundException; import org.apache.accumulo.core.data.KeyExtent; - /** - * + * * @since 1.5.0 */ public abstract class ActiveCompaction { @@ -47,7 +46,7 @@ public abstract class ActiveCompaction { */ FULL }; - + public static enum CompactionReason { /** * compaction initiated by user @@ -70,48 +69,48 @@ public abstract class ActiveCompaction { */ CLOSE }; - + /** - * + * * @return name of the table the compaction is running against */ public abstract String getTable() throws TableNotFoundException; - + /** * @return tablet thats is compacting */ public abstract KeyExtent getExtent(); - + /** * @return how long the compaction has been running in milliseconds */ public abstract long getAge(); - + /** * @return the files the compaction is reading from */ public abstract List getInputFiles(); - + /** * @return file compactions is writing too */ public abstract String getOutputFile(); - + /** * @return the type of compaction */ public abstract CompactionType getType(); - + /** * @return the reason the compaction was started */ public abstract CompactionReason getReason(); - + /** * @return the locality group that is compacting */ public abstract String getLocalityGroup(); - + /** * @return the number of key/values read by the compaction */ @@ -121,7 +120,7 @@ public abstract class ActiveCompaction { * @return the number of key/values written by the compaction */ public abstract long getEntriesWritten(); - + /** * @return the per compaction iterators configured */ http://git-wip-us.apache.org/repos/asf/accumulo/blob/6bc67602/core/src/main/java/org/apache/accumulo/core/client/admin/ActiveScan.java ---------------------------------------------------------------------- diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/ActiveScan.java b/core/src/main/java/org/apache/accumulo/core/client/admin/ActiveScan.java index fc9808f..cde5d27 100644 --- a/core/src/main/java/org/apache/accumulo/core/client/admin/ActiveScan.java +++ b/core/src/main/java/org/apache/accumulo/core/client/admin/ActiveScan.java @@ -25,7 +25,7 @@ import org.apache.accumulo.core.security.Authorizations; /** * A class that contains information about an ActiveScan - * + * */ public abstract class ActiveScan { @@ -33,62 +33,62 @@ public abstract class ActiveScan { * @return an id that uniquely identifies that scan on the server */ public abstract long getScanid(); - + /** * @return the address of the client that initiated the scan */ public abstract String getClient(); - + /** * @return the user that initiated the scan */ public abstract String getUser(); - + /** * @return the table the scan is running against */ public abstract String getTable(); - + /** * @return the age of the scan in milliseconds */ public abstract long getAge(); - + /** * @return milliseconds since last time client read data from the scan */ public abstract long getLastContactTime(); - + public abstract ScanType getType(); - + public abstract ScanState getState(); - + /** * @return tablet the scan is running against, if a batch scan may be one of many or null */ public abstract KeyExtent getExtent(); - + /** * @return columns requested by the scan */ public abstract List getColumns(); - + /** * @return server side iterators used by the scan */ public abstract List getSsiList(); - + /** * @return server side iterator options */ public abstract Map> getSsio(); - + /** * @return the authorizations being used for this scan * @since 1.5.0 */ public abstract Authorizations getAuthorizations(); - + /** * @return the time this scan has been idle in the tablet server * @since 1.5.0 http://git-wip-us.apache.org/repos/asf/accumulo/blob/6bc67602/core/src/main/java/org/apache/accumulo/core/client/admin/CompactionConfig.java ---------------------------------------------------------------------- diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/CompactionConfig.java b/core/src/main/java/org/apache/accumulo/core/client/admin/CompactionConfig.java index f59c70b..38e5efd 100644 --- a/core/src/main/java/org/apache/accumulo/core/client/admin/CompactionConfig.java +++ b/core/src/main/java/org/apache/accumulo/core/client/admin/CompactionConfig.java @@ -22,13 +22,14 @@ import java.util.Collections; import java.util.List; import java.util.Map; -import com.google.common.base.Preconditions; import org.apache.accumulo.core.client.IteratorSetting; import org.apache.hadoop.io.Text; +import com.google.common.base.Preconditions; + /** * This class exist to pass parameters to {@link TableOperations#compact(String, CompactionConfig)} - * + * * @since 1.7.0 */ @@ -64,7 +65,7 @@ public class CompactionConfig { } /** - * + * * @param end * Last tablet to be compacted contains this row, null means the last tablet in table. The default is null. * @return this @@ -110,7 +111,7 @@ public class CompactionConfig { } /** - * + * * @return The previously set wait. The default is true. */ public boolean getWait() { http://git-wip-us.apache.org/repos/asf/accumulo/blob/6bc67602/core/src/main/java/org/apache/accumulo/core/client/admin/CompactionStrategyConfig.java ---------------------------------------------------------------------- diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/CompactionStrategyConfig.java b/core/src/main/java/org/apache/accumulo/core/client/admin/CompactionStrategyConfig.java index 14b275e..c23b511 100644 --- a/core/src/main/java/org/apache/accumulo/core/client/admin/CompactionStrategyConfig.java +++ b/core/src/main/java/org/apache/accumulo/core/client/admin/CompactionStrategyConfig.java @@ -24,7 +24,7 @@ import java.util.Map; import com.google.common.base.Preconditions; /** - * + * * @since 1.7.0 */ @@ -33,7 +33,7 @@ public class CompactionStrategyConfig { private Map options = Collections.emptyMap(); /** - * + * * @param className * The name of a class that implements org.apache.accumulo.tserver.compaction.CompactionStrategy. This class must be exist on tservers. */ @@ -64,7 +64,7 @@ public class CompactionStrategyConfig { } /** - * + * * @return The previously set options. Returns an unmodifiable map. The default is an empty map. */ http://git-wip-us.apache.org/repos/asf/accumulo/blob/6bc67602/core/src/main/java/org/apache/accumulo/core/client/admin/DiskUsage.java ---------------------------------------------------------------------- diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/DiskUsage.java b/core/src/main/java/org/apache/accumulo/core/client/admin/DiskUsage.java index 5c549ff..b62843b 100644 --- a/core/src/main/java/org/apache/accumulo/core/client/admin/DiskUsage.java +++ b/core/src/main/java/org/apache/accumulo/core/client/admin/DiskUsage.java @@ -19,47 +19,47 @@ package org.apache.accumulo.core.client.admin; import java.util.SortedSet; public class DiskUsage { - + protected final SortedSet tables; protected Long usage; - + public DiskUsage(SortedSet tables, Long usage) { this.tables = tables; this.usage = usage; } - + public SortedSet getTables() { return tables; } - + public Long getUsage() { return usage; } - + @Override public boolean equals(Object o) { if (this == o) return true; if (!(o instanceof DiskUsage)) return false; - + DiskUsage diskUsage = (DiskUsage) o; - + if (tables != null ? !tables.equals(diskUsage.tables) : diskUsage.tables != null) return false; if (usage != null ? !usage.equals(diskUsage.usage) : diskUsage.usage != null) return false; - + return true; } - + @Override public int hashCode() { int result = tables != null ? tables.hashCode() : 0; result = 31 * result + (usage != null ? usage.hashCode() : 0); return result; } - + @Override public String toString() { return "DiskUsage{" + "tables=" + tables + ", usage=" + usage + '}'; http://git-wip-us.apache.org/repos/asf/accumulo/blob/6bc67602/core/src/main/java/org/apache/accumulo/core/client/admin/FindMax.java ---------------------------------------------------------------------- diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/FindMax.java b/core/src/main/java/org/apache/accumulo/core/client/admin/FindMax.java index 3bb56a8..00fe950 100644 --- a/core/src/main/java/org/apache/accumulo/core/client/admin/FindMax.java +++ b/core/src/main/java/org/apache/accumulo/core/client/admin/FindMax.java @@ -36,35 +36,35 @@ public class FindMax { for (int i = 0; i < num; i++) baos.write(0); } - + private static Text findMidPoint(Text minBS, Text maxBS) { ByteArrayOutputStream startOS = new ByteArrayOutputStream(); startOS.write(0); // add a leading zero so bigint does not think its negative startOS.write(minBS.getBytes(), 0, minBS.getLength()); - + ByteArrayOutputStream endOS = new ByteArrayOutputStream(); endOS.write(0);// add a leading zero so bigint does not think its negative endOS.write(maxBS.getBytes(), 0, maxBS.getLength()); - + // make the numbers of the same magnitude if (startOS.size() < endOS.size()) appendZeros(startOS, endOS.size() - startOS.size()); else if (endOS.size() < startOS.size()) appendZeros(endOS, startOS.size() - endOS.size()); - + BigInteger min = new BigInteger(startOS.toByteArray()); BigInteger max = new BigInteger(endOS.toByteArray()); - + BigInteger mid = max.subtract(min).divide(BigInteger.valueOf(2)).add(min); - + byte[] ba = mid.toByteArray(); - + Text ret = new Text(); - + if (ba.length == startOS.size()) { if (ba[0] != 0) throw new RuntimeException(); - + // big int added a zero so it would not be negative, drop it ret.set(ba, 1, ba.length - 1); } else { @@ -73,27 +73,27 @@ public class FindMax { for (int i = ba.length; i < expLen; i++) { ret.append(new byte[] {0}, 0, 1); } - + ret.append(ba, 0, ba.length); } - + // remove trailing 0x0 bytes while (ret.getLength() > 0 && ret.getBytes()[ret.getLength() - 1] == 0 && ret.compareTo(minBS) > 0) { Text t = new Text(); t.set(ret.getBytes(), 0, ret.getLength() - 1); ret = t; } - + return ret; } - + private static Text _findMax(Scanner scanner, Text start, boolean inclStart, Text end, boolean inclEnd) { - + // System.out.printf("findMax(%s, %s, %s, %s)%n", Key.toPrintableString(start.getBytes(), 0, start.getLength(), 1000), inclStart, // Key.toPrintableString(end.getBytes(), 0, end.getLength(), 1000), inclEnd); - + int cmp = start.compareTo(end); - + if (cmp >= 0) { if (inclStart && inclEnd && cmp == 0) { scanner.setRange(new Range(start, true, end, true)); @@ -101,45 +101,45 @@ public class FindMax { if (iter.hasNext()) return iter.next().getKey().getRow(); } - + return null; } - + Text mid = findMidPoint(start, end); // System.out.println("mid = :"+Key.toPrintableString(mid.getBytes(), 0, mid.getLength(), 1000)+":"); - + scanner.setRange(new Range(mid, mid.equals(start) ? inclStart : true, end, inclEnd)); - + Iterator> iter = scanner.iterator(); - + if (iter.hasNext()) { Key next = iter.next().getKey(); - + int count = 0; while (count < 10 && iter.hasNext()) { next = iter.next().getKey(); count++; } - + if (!iter.hasNext()) return next.getRow(); - + Text ret = _findMax(scanner, next.followingKey(PartialKey.ROW).getRow(), true, end, inclEnd); if (ret == null) return next.getRow(); else return ret; } else { - + return _findMax(scanner, start, inclStart, mid, mid.equals(start) ? inclStart : false); } } - + private static Text findInitialEnd(Scanner scanner) { Text end = new Text(new byte[] {(byte) 0xff, (byte) 0xff, (byte) 0xff, (byte) 0xff}); - + scanner.setRange(new Range(end, null)); - + while (scanner.iterator().hasNext()) { Text t = new Text(); t.append(end.getBytes(), 0, end.getLength()); @@ -147,24 +147,24 @@ public class FindMax { end = t; scanner.setRange(new Range(end, null)); } - + return end; } - + public static Text findMax(Scanner scanner, Text start, boolean is, Text end, boolean ie) throws TableNotFoundException { - + scanner.setBatchSize(12); IteratorSetting cfg = new IteratorSetting(Integer.MAX_VALUE, SortedKeyIterator.class); scanner.addScanIterator(cfg); - + if (start == null) { start = new Text(); is = true; } - + if (end == null) end = findInitialEnd(scanner); - + return _findMax(scanner, start, is, end, ie); } } http://git-wip-us.apache.org/repos/asf/accumulo/blob/6bc67602/core/src/main/java/org/apache/accumulo/core/client/admin/InstanceOperations.java ---------------------------------------------------------------------- diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/InstanceOperations.java b/core/src/main/java/org/apache/accumulo/core/client/admin/InstanceOperations.java index 04e1d0d..4bb4747 100644 --- a/core/src/main/java/org/apache/accumulo/core/client/admin/InstanceOperations.java +++ b/core/src/main/java/org/apache/accumulo/core/client/admin/InstanceOperations.java @@ -23,14 +23,14 @@ import org.apache.accumulo.core.client.AccumuloException; import org.apache.accumulo.core.client.AccumuloSecurityException; /** - * + * */ public interface InstanceOperations { - + /** * Sets an system property in zookeeper. Tablet servers will pull this setting and override the equivalent setting in accumulo-site.xml. Changes can be seen * using {@link #getSystemConfiguration()} - * + * * @param property * the name of a per-table property * @param value @@ -41,10 +41,10 @@ public interface InstanceOperations { * if the user does not have permission */ void setProperty(final String property, final String value) throws AccumuloException, AccumuloSecurityException; - + /** * Removes a system property from zookeeper. Changes can be seen using {@link #getSystemConfiguration()} - * + * * @param property * the name of a per-table property * @throws AccumuloException @@ -53,72 +53,73 @@ public interface InstanceOperations { * if the user does not have permission */ void removeProperty(final String property) throws AccumuloException, AccumuloSecurityException; - + /** - * + * * @return A map of system properties set in zookeeper. If a property is not set in zookeeper, then it will return the value set in accumulo-site.xml on some * server. If nothing is set in an accumulo-site.xml file it will return the default value for each property. */ Map getSystemConfiguration() throws AccumuloException, AccumuloSecurityException; - + /** - * + * * @return A map of system properties set in accumulo-site.xml on some server. If nothing is set in an accumulo-site.xml file it will return the default value * for each property. */ Map getSiteConfiguration() throws AccumuloException, AccumuloSecurityException; - + /** * List the currently active tablet servers participating in the accumulo instance - * + * * @return A list of currently active tablet servers. */ - + List getTabletServers(); - + /** * List the active scans on tablet server. - * + * * @param tserver * The tablet server address should be of the form : * @return A list of active scans on tablet server. */ - + List getActiveScans(String tserver) throws AccumuloException, AccumuloSecurityException; - + /** * List the active compaction running on a tablet server - * + * * @param tserver * The tablet server address should be of the form : * @return the list of active compactions * @since 1.5.0 */ - + List getActiveCompactions(String tserver) throws AccumuloException, AccumuloSecurityException; - + /** * Throws an exception if a tablet server can not be contacted. - * + * * @param tserver * The tablet server address should be of the form : * @since 1.5.0 */ void ping(String tserver) throws AccumuloException; - + /** * Test to see if the instance can load the given class as the given type. This check does not consider per table classpaths, see * {@link TableOperations#testClassLoad(String, String, String)} - * + * * @return true if the instance can load the given class as the given type, false otherwise */ boolean testClassLoad(final String className, final String asTypeName) throws AccumuloException, AccumuloSecurityException; - + /** - * Waits for the tablet balancer to run and return no migrations. - * @since 1.7.0 + * Waits for the tablet balancer to run and return no migrations. + * + * @since 1.7.0 */ void waitForBalance() throws AccumuloException; } http://git-wip-us.apache.org/repos/asf/accumulo/blob/6bc67602/core/src/main/java/org/apache/accumulo/core/client/admin/NamespaceOperations.java ---------------------------------------------------------------------- diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/NamespaceOperations.java b/core/src/main/java/org/apache/accumulo/core/client/admin/NamespaceOperations.java index c6dff92..b2e7198 100644 --- a/core/src/main/java/org/apache/accumulo/core/client/admin/NamespaceOperations.java +++ b/core/src/main/java/org/apache/accumulo/core/client/admin/NamespaceOperations.java @@ -31,17 +31,17 @@ import org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope; /** * Provides an API for administering namespaces - * + * * All tables exist in a namespace. The default namespace has no name, and is used if an explicit namespace is not specified. Fully qualified table names look * like "namespaceName.tableName". Tables in the default namespace are fully qualified simply as "tableName". - * + * * @since 1.6.0 */ public interface NamespaceOperations { /** * Returns the name of the system reserved namespace - * + * * @return the name of the system namespace * @since 1.6.0 */ @@ -49,7 +49,7 @@ public interface NamespaceOperations { /** * Returns the name of the default namespace - * + * * @return the name of the default namespace * @since 1.6.0 */ @@ -57,7 +57,7 @@ public interface NamespaceOperations { /** * Retrieve a list of namespaces in Accumulo. - * + * * @return List of namespaces in accumulo * @throws AccumuloException * if a general error occurs @@ -69,7 +69,7 @@ public interface NamespaceOperations { /** * A method to check if a namespace exists in Accumulo. - * + * * @param namespace * the name of the namespace * @return true if the namespace exists @@ -83,7 +83,7 @@ public interface NamespaceOperations { /** * Create an empty namespace with no initial configuration. Valid names for a namespace contain letters, numbers, and the underscore character. - * + * * @param namespace * the name of the namespace * @throws AccumuloException @@ -98,7 +98,7 @@ public interface NamespaceOperations { /** * Delete an empty namespace - * + * * @param namespace * the name of the namespace * @throws AccumuloException @@ -115,7 +115,7 @@ public interface NamespaceOperations { /** * Rename a namespace - * + * * @param oldNamespaceName * the old namespace name * @param newNamespaceName @@ -135,7 +135,7 @@ public interface NamespaceOperations { /** * Sets a property on a namespace which applies to all tables in the namespace. Note that it may take a few seconds to propagate the change everywhere. - * + * * @param namespace * the name of the namespace * @param property @@ -154,7 +154,7 @@ public interface NamespaceOperations { /** * Removes a property from a namespace. Note that it may take a few seconds to propagate the change everywhere. - * + * * @param namespace * the name of the namespace * @param property @@ -171,7 +171,7 @@ public interface NamespaceOperations { /** * Gets properties of a namespace, which are inherited by tables in this namespace. Note that recently changed properties may not be available immediately. - * + * * @param namespace * the name of the namespace * @return all properties visible by this namespace (system and per-table properties). Note that recently changed properties may not be visible immediately. @@ -187,7 +187,7 @@ public interface NamespaceOperations { /** * Get a mapping of namespace name to internal namespace id. - * + * * @return the map from namespace name to internal namespace id * @throws AccumuloException * if a general error occurs @@ -199,7 +199,7 @@ public interface NamespaceOperations { /** * Add an iterator to a namespace on all scopes. - * + * * @param namespace * the name of the namespace * @param setting @@ -216,7 +216,7 @@ public interface NamespaceOperations { /** * Add an iterator to a namespace on the given scopes. - * + * * @param namespace * the name of the namespace * @param setting @@ -236,7 +236,7 @@ public interface NamespaceOperations { /** * Remove an iterator from a namespace by name. - * + * * @param namespace * the name of the namespace * @param name @@ -256,7 +256,7 @@ public interface NamespaceOperations { /** * Get the settings for an iterator. - * + * * @param namespace * the name of the namespace * @param name @@ -277,7 +277,7 @@ public interface NamespaceOperations { /** * Get a list of iterators for this namespace. - * + * * @param namespace * the name of the namespace * @return a set of iterator names @@ -294,7 +294,7 @@ public interface NamespaceOperations { /** * Check whether a given iterator configuration conflicts with existing configuration; in particular, determine if the name or priority are already in use for * the specified scopes. If so, an IllegalArgumentException is thrown, wrapped in an AccumuloException. - * + * * @param namespace * the name of the namespace * @param setting @@ -314,7 +314,7 @@ public interface NamespaceOperations { /** * Add a new constraint to a namespace. - * + * * @param namespace * the name of the namespace * @param constraintClassName @@ -332,7 +332,7 @@ public interface NamespaceOperations { /** * Remove a constraint from a namespace. - * + * * @param namespace * the name of the namespace * @param id @@ -349,7 +349,7 @@ public interface NamespaceOperations { /** * List constraints on a namespace with their assigned numbers. - * + * * @param namespace * the name of the namespace * @return a map from constraint class name to assigned number @@ -365,7 +365,7 @@ public interface NamespaceOperations { /** * Test to see if the instance can load the given class as the given type. This check uses the table classpath property if it is set. - * + * * @param namespace * the name of the namespace * @param className http://git-wip-us.apache.org/repos/asf/accumulo/blob/6bc67602/core/src/main/java/org/apache/accumulo/core/client/admin/ReplicationOperations.java ---------------------------------------------------------------------- diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/ReplicationOperations.java b/core/src/main/java/org/apache/accumulo/core/client/admin/ReplicationOperations.java index 4e24552..699d9d5 100644 --- a/core/src/main/java/org/apache/accumulo/core/client/admin/ReplicationOperations.java +++ b/core/src/main/java/org/apache/accumulo/core/client/admin/ReplicationOperations.java @@ -27,52 +27,63 @@ import org.apache.accumulo.core.client.replication.ReplicaSystem; /** * Supports replication configuration + * * @since 1.7.0 */ public interface ReplicationOperations { /** * Defines a cluster with the given name using the given {@link ReplicaSystem} implementation. - * @param name Name of the cluster, used for configuring replication on tables - * @param system Type of system to be replicated to + * + * @param name + * Name of the cluster, used for configuring replication on tables + * @param system + * Type of system to be replicated to */ public void addPeer(String name, Class system) throws AccumuloException, AccumuloSecurityException, PeerExistsException; /** * Defines a cluster with the given name and the given name system. - * @param name Unique name for the cluster - * @param replicaType {@link ReplicaSystem} class name to use to replicate the data + * + * @param name + * Unique name for the cluster + * @param replicaType + * {@link ReplicaSystem} class name to use to replicate the data */ public void addPeer(String name, String replicaType) throws AccumuloException, AccumuloSecurityException, PeerExistsException; /** * Removes a cluster with the given name. - * @param name Name of the cluster to remove + * + * @param name + * Name of the cluster to remove */ public void removePeer(String name) throws AccumuloException, AccumuloSecurityException, PeerNotFoundException; /** - * Waits for a table to be fully replicated, given the state of files pending replication for the provided table - * at the point in time which this method is invoked. - * @param tableName The table to wait for + * Waits for a table to be fully replicated, given the state of files pending replication for the provided table at the point in time which this method is + * invoked. + * + * @param tableName + * The table to wait for */ public void drain(String tableName) throws AccumuloException, AccumuloSecurityException, TableNotFoundException; /** - * Given the provided set of files that are pending replication for a table, wait for those - * files to be fully replicated to all configured peers. This allows for the accurate calculation - * when a table, at a given point in time, has been fully replicated. - * @param tableName The table to wait for + * Given the provided set of files that are pending replication for a table, wait for those files to be fully replicated to all configured peers. This allows + * for the accurate calculation when a table, at a given point in time, has been fully replicated. + * + * @param tableName + * The table to wait for */ public void drain(String tableName, Set files) throws AccumuloException, AccumuloSecurityException, TableNotFoundException; /** - * Gets all of the referenced files for a table from the metadata table. The result of this method - * is intended to be directly supplied to {@link #drain(String, Set)}. This helps determine when all - * data from a given point in time has been fully replicated. + * Gets all of the referenced files for a table from the metadata table. The result of this method is intended to be directly supplied to + * {@link #drain(String, Set)}. This helps determine when all data from a given point in time has been fully replicated. *

- * This also allows callers to get the {@link Set} of files for a table at some time, and later provide that - * {@link Set} to {@link #drain(String,Set)} to wait for all of those files to be replicated. + * This also allows callers to get the {@link Set} of files for a table at some time, and later provide that {@link Set} to {@link #drain(String,Set)} to wait + * for all of those files to be replicated. */ public Set referencedFiles(String tableName) throws AccumuloException, AccumuloSecurityException, TableNotFoundException; } http://git-wip-us.apache.org/repos/asf/accumulo/blob/6bc67602/core/src/main/java/org/apache/accumulo/core/client/admin/SecurityOperations.java ---------------------------------------------------------------------- diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/SecurityOperations.java b/core/src/main/java/org/apache/accumulo/core/client/admin/SecurityOperations.java index ea1fde1..efeafc0 100644 --- a/core/src/main/java/org/apache/accumulo/core/client/admin/SecurityOperations.java +++ b/core/src/main/java/org/apache/accumulo/core/client/admin/SecurityOperations.java @@ -34,7 +34,7 @@ public interface SecurityOperations { /** * Create a user - * + * * @param user * the name of the user to create * @param password @@ -52,7 +52,7 @@ public interface SecurityOperations { /** * Create a user - * + * * @param principal * the name of the user to create * @param password @@ -67,7 +67,7 @@ public interface SecurityOperations { /** * Delete a user - * + * * @param user * the user name to delete * @throws AccumuloException @@ -81,7 +81,7 @@ public interface SecurityOperations { /** * Delete a user - * + * * @param principal * the user name to delete * @throws AccumuloException @@ -94,7 +94,7 @@ public interface SecurityOperations { /** * Verify a username/password combination is valid - * + * * @param user * the name of the user to authenticate * @param password @@ -111,7 +111,7 @@ public interface SecurityOperations { /** * Verify a username/password combination is valid - * + * * @param principal * the name of the user to authenticate * @param token @@ -127,7 +127,7 @@ public interface SecurityOperations { /** * Set the user's password - * + * * @param user * the name of the user to modify * @param password @@ -144,7 +144,7 @@ public interface SecurityOperations { /** * Set the user's password - * + * * @param principal * the name of the user to modify * @param token @@ -159,7 +159,7 @@ public interface SecurityOperations { /** * Set the user's record-level authorizations - * + * * @param principal * the name of the user to modify * @param authorizations @@ -173,7 +173,7 @@ public interface SecurityOperations { /** * Retrieves the user's authorizations for scanning - * + * * @param principal * the name of the user to query * @return the set of authorizations the user has available for scanning @@ -186,7 +186,7 @@ public interface SecurityOperations { /** * Verify the user has a particular system permission - * + * * @param principal * the name of the user to query * @param perm @@ -201,7 +201,7 @@ public interface SecurityOperations { /** * Verify the user has a particular table permission - * + * * @param principal * the name of the user to query * @param table @@ -218,7 +218,7 @@ public interface SecurityOperations { /** * Verify the user has a particular namespace permission - * + * * @param principal * the name of the user to query * @param namespace @@ -235,7 +235,7 @@ public interface SecurityOperations { /** * Grant a user a system permission - * + * * @param principal * the name of the user to modify * @param permission @@ -249,7 +249,7 @@ public interface SecurityOperations { /** * Grant a user a specific permission for a specific table - * + * * @param principal * the name of the user to modify * @param table @@ -265,7 +265,7 @@ public interface SecurityOperations { /** * Grant a user a specific permission for a specific namespace - * + * * @param principal * the name of the user to modify * @param namespace @@ -281,7 +281,7 @@ public interface SecurityOperations { /** * Revoke a system permission from a user - * + * * @param principal * the name of the user to modify * @param permission @@ -295,7 +295,7 @@ public interface SecurityOperations { /** * Revoke a table permission for a specific user on a specific table - * + * * @param principal * the name of the user to modify * @param table @@ -311,7 +311,7 @@ public interface SecurityOperations { /** * Revoke a namespace permission for a specific user on a specific namespace - * + * * @param principal * the name of the user to modify * @param namespace @@ -327,7 +327,7 @@ public interface SecurityOperations { /** * Return a list of users in accumulo - * + * * @return a set of user names * @throws AccumuloException * if a general error occurs @@ -340,7 +340,7 @@ public interface SecurityOperations { /** * Return a list of users in accumulo - * + * * @return a set of user names * @throws AccumuloException * if a general error occurs http://git-wip-us.apache.org/repos/asf/accumulo/blob/6bc67602/core/src/main/java/org/apache/accumulo/core/client/admin/TableOperations.java ---------------------------------------------------------------------- diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/TableOperations.java b/core/src/main/java/org/apache/accumulo/core/client/admin/TableOperations.java index 63ac7b4..5c1260c 100644 --- a/core/src/main/java/org/apache/accumulo/core/client/admin/TableOperations.java +++ b/core/src/main/java/org/apache/accumulo/core/client/admin/TableOperations.java @@ -38,21 +38,21 @@ import org.apache.hadoop.io.Text; /** * Provides a class for administering tables - * + * */ public interface TableOperations { /** * Retrieve a list of tables in Accumulo. - * + * * @return List of tables in accumulo */ SortedSet list(); /** * A method to check if a table exists in Accumulo. - * + * * @param tableName * the name of the table * @return true if the table exists @@ -61,7 +61,7 @@ public interface TableOperations { /** * Create a table with no special configuration - * + * * @param tableName * the name of the table * @throws AccumuloException @@ -126,7 +126,7 @@ public interface TableOperations { /** * Imports a table exported via exportTable and copied via hadoop distcp. - * + * * @param tableName * Name of a table to create and import into. * @param importDir @@ -138,10 +138,10 @@ public interface TableOperations { /** * Exports a table. The tables data is not exported, just table metadata and a list of files to distcp. The table being exported must be offline and stay * offline for the duration of distcp. To avoid losing access to a table it can be cloned and the clone taken offline for export. - * + * *

* See docs/examples/README.export - * + * * @param tableName * Name of the table to export. * @param exportDir @@ -153,7 +153,8 @@ public interface TableOperations { /** * Ensures that tablets are split along a set of keys. *

- * Note that while the documentation for Text specifies that its bytestream should be UTF-8, the encoding is not enforced by operations that work with byte arrays. + * Note that while the documentation for Text specifies that its bytestream should be UTF-8, the encoding is not enforced by operations that work with byte + * arrays. *

* For example, you can create 256 evenly-sliced splits via the following code sample even though the given byte sequences are not valid UTF-8. * @@ -232,7 +233,7 @@ public interface TableOperations { /** * Finds the max row within a given range. To find the max row in a table, pass null for start and end row. - * + * * @param auths * find the max row that can seen with these auths * @param startRow @@ -243,7 +244,7 @@ public interface TableOperations { * row to stop looking at, null means Infinity * @param endInclusive * determines if the end row is included - * + * * @return The max row in the range, or null if there is no visible data in the range. */ Text getMaxRow(String tableName, Authorizations auths, Text startRow, boolean startInclusive, Text endRow, boolean endInclusive) @@ -251,7 +252,7 @@ public interface TableOperations { /** * Merge tablets between (start, end] - * + * * @param tableName * the table to merge * @param start @@ -263,7 +264,7 @@ public interface TableOperations { /** * Delete rows between (start, end] - * + * * @param tableName * the table to merge * @param start @@ -275,7 +276,7 @@ public interface TableOperations { /** * Starts a full major compaction of the tablets in the range (start, end]. The compaction is preformed even for tablets that have only one file. - * + * * @param tableName * the table to compact * @param start @@ -287,12 +288,11 @@ public interface TableOperations { * @param wait * when true, the call will not return until compactions are finished */ - void compact(String tableName, Text start, Text end, boolean flush, boolean wait) throws AccumuloSecurityException, TableNotFoundException, - AccumuloException; + void compact(String tableName, Text start, Text end, boolean flush, boolean wait) throws AccumuloSecurityException, TableNotFoundException, AccumuloException; /** * Starts a full major compaction of the tablets in the range (start, end]. The compaction is preformed even for tablets that have only one file. - * + * * @param tableName * the table to compact * @param start @@ -313,16 +313,16 @@ public interface TableOperations { /** * Starts a full major compaction of the tablets in the range (start, end]. If the config does not specify a compaction strategy, then all files in a tablet * are compacted. The compaction is performed even for tablets that have only one file. - * + * *

* Only one compact call at a time can pass iterators and/or a compaction strategy. If two threads call compaction with iterators and/or a copmaction * strategy, then one will fail. - * + * * @param tableName * the table to compact * @param config * the configuration to use - * + * * @since 1.7.0 */ void compact(String tableName, CompactionConfig config) throws AccumuloSecurityException, TableNotFoundException, AccumuloException; @@ -331,7 +331,7 @@ public interface TableOperations { * Cancels a user initiated major compaction of a table initiated with {@link #compact(String, Text, Text, boolean, boolean)} or * {@link #compact(String, Text, Text, List, boolean, boolean)}. Compactions of tablets that are currently running may finish, but new compactions of tablets * will not start. - * + * * @param tableName * the name of the table * @throws AccumuloException @@ -346,7 +346,7 @@ public interface TableOperations { /** * Delete a table - * + * * @param tableName * the name of the table * @throws AccumuloException @@ -362,9 +362,9 @@ public interface TableOperations { * Clone a table from an existing table. The cloned table will have the same data as the source table it was created from. After cloning, the two tables can * mutate independently. Initially the cloned table should not use any extra space, however as the source table and cloned table major compact extra space * will be used by the clone. - * + * * Initially the cloned table is only readable and writable by the user who created it. - * + * * @param srcTableName * the table to clone * @param newTableName @@ -382,7 +382,7 @@ public interface TableOperations { /** * Rename a table - * + * * @param oldTableName * the old table name * @param newTableName @@ -396,19 +396,18 @@ public interface TableOperations { * @throws TableExistsException * if the new table name already exists */ - void rename(String oldTableName, String newTableName) throws AccumuloSecurityException, TableNotFoundException, AccumuloException, - TableExistsException; + void rename(String oldTableName, String newTableName) throws AccumuloSecurityException, TableNotFoundException, AccumuloException, TableExistsException; /** * Initiate a flush of a table's data that is in memory - * + * * @param tableName * the name of the table * @throws AccumuloException * if a general error occurs * @throws AccumuloSecurityException * if the user does not have permission - * + * * @deprecated As of release 1.4, replaced by {@link #flush(String, Text, Text, boolean)} */ @Deprecated @@ -416,7 +415,7 @@ public interface TableOperations { /** * Flush a table's data that is currently in memory. - * + * * @param tableName * the name of the table * @param wait @@ -431,7 +430,7 @@ public interface TableOperations { /** * Sets a property on a table. Note that it may take a short period of time (a second) to propagate the change everywhere. - * + * * @param tableName * the name of the table * @param property @@ -447,7 +446,7 @@ public interface TableOperations { /** * Removes a property from a table. Note that it may take a short period of time (a second) to propagate the change everywhere. - * + * * @param tableName * the name of the table * @param property @@ -461,7 +460,7 @@ public interface TableOperations { /** * Gets properties of a table. Note that recently changed properties may not be available immediately. - * + * * @param tableName * the name of the table * @return all properties visible by this table (system and per-table properties). Note that recently changed properties may not be visible immediately. @@ -472,7 +471,7 @@ public interface TableOperations { /** * Sets a table's locality groups. A table's locality groups can be changed at any time. - * + * * @param tableName * the name of the table * @param groups @@ -487,9 +486,9 @@ public interface TableOperations { void setLocalityGroups(String tableName, Map> groups) throws AccumuloException, AccumuloSecurityException, TableNotFoundException; /** - * + * * Gets the locality groups currently set for a table. - * + * * @param tableName * the name of the table * @return mapping of locality group names to column families in the locality group @@ -515,12 +514,11 @@ public interface TableOperations { * @throws TableNotFoundException * if the table does not exist */ - Set splitRangeByTablets(String tableName, Range range, int maxSplits) throws AccumuloException, AccumuloSecurityException, - TableNotFoundException; + Set splitRangeByTablets(String tableName, Range range, int maxSplits) throws AccumuloException, AccumuloSecurityException, TableNotFoundException; /** * Bulk import all the files in a directory into a table. - * + * * @param tableName * the name of the table * @param dir @@ -537,14 +535,14 @@ public interface TableOperations { * when the user does not have the proper permissions * @throws TableNotFoundException * when the table no longer exists - * + * */ void importDirectory(String tableName, String dir, String failureDir, boolean setTime) throws TableNotFoundException, IOException, AccumuloException, AccumuloSecurityException; /** * Initiates taking a table offline, but does not wait for action to complete - * + * * @param tableName * the table to take offline * @throws AccumuloException @@ -555,7 +553,7 @@ public interface TableOperations { void offline(String tableName) throws AccumuloSecurityException, AccumuloException, TableNotFoundException; /** - * + * * @param tableName * the table to take offline * @param wait @@ -570,7 +568,7 @@ public interface TableOperations { /** * Initiates bringing a table online, but does not wait for action to complete - * + * * @param tableName * the table to take online * @throws AccumuloException @@ -581,7 +579,7 @@ public interface TableOperations { void online(String tableName) throws AccumuloSecurityException, AccumuloException, TableNotFoundException; /** - * + * * @param tableName * the table to take online * @param wait @@ -596,7 +594,7 @@ public interface TableOperations { /** * Clears the tablet locator cache for a specified table - * + * * @param tableName * the name of the table * @throws TableNotFoundException @@ -606,14 +604,14 @@ public interface TableOperations { /** * Get a mapping of table name to internal table id. - * + * * @return the map from table name to internal table id */ Map tableIdMap(); /** * Add an iterator to a table on all scopes. - * + * * @param tableName * the name of the table * @param setting @@ -629,7 +627,7 @@ public interface TableOperations { /** * Add an iterator to a table on the given scopes. - * + * * @param tableName * the name of the table * @param setting @@ -646,7 +644,7 @@ public interface TableOperations { /** * Remove an iterator from a table by name. - * + * * @param tableName * the name of the table * @param name @@ -658,12 +656,11 @@ public interface TableOperations { * @throws TableNotFoundException * throw if the table no longer exists */ - void removeIterator(String tableName, String name, EnumSet scopes) throws AccumuloSecurityException, AccumuloException, - TableNotFoundException; + void removeIterator(String tableName, String name, EnumSet scopes) throws AccumuloSecurityException, AccumuloException, TableNotFoundException; /** * Get the settings for an iterator. - * + * * @param tableName * the name of the table * @param name @@ -681,7 +678,7 @@ public interface TableOperations { /** * Get a list of iterators for this table. - * + * * @param tableName * the name of the table * @return a set of iterator names @@ -691,7 +688,7 @@ public interface TableOperations { /** * Check whether a given iterator configuration conflicts with existing configuration; in particular, determine if the name or priority are already in use for * the specified scopes. - * + * * @param tableName * the name of the table * @param setting @@ -701,7 +698,7 @@ public interface TableOperations { /** * Add a new constraint to a table. - * + * * @param tableName * the name of the table * @param constraintClassName @@ -717,7 +714,7 @@ public interface TableOperations { /** * Remove a constraint from a table. - * + * * @param tableName * the name of the table * @param number @@ -730,7 +727,7 @@ public interface TableOperations { /** * List constraints on a table with their assigned numbers. - * + * * @param tableName * the name of the table * @return a map from constraint class name to assigned number @@ -742,7 +739,7 @@ public interface TableOperations { /** * Gets the number of bytes being used in the files for a set of tables - * + * * @param tables * a set of tables * @return a list of disk usage objects containing linked table names and sizes @@ -752,9 +749,9 @@ public interface TableOperations { /** * Test to see if the instance can load the given class as the given type. This check uses the table classpath if it is set. - * + * * @return true if the instance can load the given class as the given type, false otherwise - * + * * @since 1.5.0 */ boolean testClassLoad(String tableName, final String className, final String asTypeName) throws AccumuloException, AccumuloSecurityException, http://git-wip-us.apache.org/repos/asf/accumulo/blob/6bc67602/core/src/main/java/org/apache/accumulo/core/client/admin/TimeType.java ---------------------------------------------------------------------- diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/TimeType.java b/core/src/main/java/org/apache/accumulo/core/client/admin/TimeType.java index 3f5de94..426d384 100644 --- a/core/src/main/java/org/apache/accumulo/core/client/admin/TimeType.java +++ b/core/src/main/java/org/apache/accumulo/core/client/admin/TimeType.java @@ -24,7 +24,7 @@ public enum TimeType { * Used to guarantee ordering of data sequentially as inserted */ LOGICAL, - + /** * This is the default. Tries to ensure that inserted data is stored with the timestamp closest to the machine's time to the nearest millisecond, without * going backwards to guarantee insertion sequence. Note that using this time type can cause time to "skip" forward if a machine has a time that is too far http://git-wip-us.apache.org/repos/asf/accumulo/blob/6bc67602/core/src/main/java/org/apache/accumulo/core/client/impl/AccumuloServerException.java ---------------------------------------------------------------------- diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/AccumuloServerException.java b/core/src/main/java/org/apache/accumulo/core/client/impl/AccumuloServerException.java index a440aaf..c689c91 100644 --- a/core/src/main/java/org/apache/accumulo/core/client/impl/AccumuloServerException.java +++ b/core/src/main/java/org/apache/accumulo/core/client/impl/AccumuloServerException.java @@ -21,24 +21,24 @@ import org.apache.thrift.TApplicationException; /** * This class is intended to encapsulate errors that occurred on the server side. - * + * */ public class AccumuloServerException extends AccumuloException { private static final long serialVersionUID = 1L; private String server; - + public AccumuloServerException(final String server, final TApplicationException tae) { super("Error on server " + server, tae); this.setServer(server); } - + private void setServer(final String server) { this.server = server; } - + public String getServer() { return server; } - + } http://git-wip-us.apache.org/repos/asf/accumulo/blob/6bc67602/core/src/main/java/org/apache/accumulo/core/client/impl/ActiveCompactionImpl.java ---------------------------------------------------------------------- diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/ActiveCompactionImpl.java b/core/src/main/java/org/apache/accumulo/core/client/impl/ActiveCompactionImpl.java index a413195..46259d1 100644 --- a/core/src/main/java/org/apache/accumulo/core/client/impl/ActiveCompactionImpl.java +++ b/core/src/main/java/org/apache/accumulo/core/client/impl/ActiveCompactionImpl.java @@ -27,7 +27,6 @@ import org.apache.accumulo.core.client.admin.ActiveCompaction; import org.apache.accumulo.core.data.KeyExtent; import org.apache.accumulo.core.data.thrift.IterInfo; - /** * * @since 1.6.0 http://git-wip-us.apache.org/repos/asf/accumulo/blob/6bc67602/core/src/main/java/org/apache/accumulo/core/client/impl/ActiveScanImpl.java ---------------------------------------------------------------------- diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/ActiveScanImpl.java b/core/src/main/java/org/apache/accumulo/core/client/impl/ActiveScanImpl.java index 0f0e64c..5f953e2 100644 --- a/core/src/main/java/org/apache/accumulo/core/client/impl/ActiveScanImpl.java +++ b/core/src/main/java/org/apache/accumulo/core/client/impl/ActiveScanImpl.java @@ -23,8 +23,8 @@ import java.util.Map; import org.apache.accumulo.core.client.Instance; import org.apache.accumulo.core.client.TableNotFoundException; import org.apache.accumulo.core.client.admin.ActiveScan; -import org.apache.accumulo.core.client.admin.ScanType; import org.apache.accumulo.core.client.admin.ScanState; +import org.apache.accumulo.core.client.admin.ScanType; import org.apache.accumulo.core.data.Column; import org.apache.accumulo.core.data.KeyExtent; import org.apache.accumulo.core.data.thrift.IterInfo; @@ -33,6 +33,7 @@ import org.apache.accumulo.core.security.Authorizations; /** * A class that contains information about an ActiveScan + * * @since 1.6.0 */ public class ActiveScanImpl extends ActiveScan { http://git-wip-us.apache.org/repos/asf/accumulo/blob/6bc67602/core/src/main/java/org/apache/accumulo/core/client/impl/BatchWriterImpl.java ---------------------------------------------------------------------- diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/BatchWriterImpl.java b/core/src/main/java/org/apache/accumulo/core/client/impl/BatchWriterImpl.java index 08f1475..c173333 100644 --- a/core/src/main/java/org/apache/accumulo/core/client/impl/BatchWriterImpl.java +++ b/core/src/main/java/org/apache/accumulo/core/client/impl/BatchWriterImpl.java @@ -24,10 +24,10 @@ import org.apache.accumulo.core.client.MutationsRejectedException; import org.apache.accumulo.core.data.Mutation; public class BatchWriterImpl implements BatchWriter { - + private final String table; private final TabletServerBatchWriter bw; - + public BatchWriterImpl(ClientContext context, String table, BatchWriterConfig config) { checkArgument(context != null, "context is null"); checkArgument(table != null, "table is null"); @@ -36,27 +36,27 @@ public class BatchWriterImpl implements BatchWriter { this.table = table; this.bw = new TabletServerBatchWriter(context, config); } - + @Override public void addMutation(Mutation m) throws MutationsRejectedException { checkArgument(m != null, "m is null"); bw.addMutation(table, m); } - + @Override public void addMutations(Iterable iterable) throws MutationsRejectedException { checkArgument(iterable != null, "iterable is null"); bw.addMutation(table, iterable.iterator()); } - + @Override public void close() throws MutationsRejectedException { bw.close(); } - + @Override public void flush() throws MutationsRejectedException { bw.flush(); } - + } http://git-wip-us.apache.org/repos/asf/accumulo/blob/6bc67602/core/src/main/java/org/apache/accumulo/core/client/impl/CompressedIterators.java ---------------------------------------------------------------------- diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/CompressedIterators.java b/core/src/main/java/org/apache/accumulo/core/client/impl/CompressedIterators.java index 549322e..3fcce90 100644 --- a/core/src/main/java/org/apache/accumulo/core/client/impl/CompressedIterators.java +++ b/core/src/main/java/org/apache/accumulo/core/client/impl/CompressedIterators.java @@ -33,7 +33,7 @@ public class CompressedIterators { private Map symbolMap; private List symbolTable; private Map cache; - + public static class IterConfig { public List ssiList = new ArrayList(); public Map> ssio = new HashMap>(); @@ -43,7 +43,7 @@ public class CompressedIterators { symbolMap = new HashMap(); symbolTable = new ArrayList(); } - + public CompressedIterators(List symbols) { this.symbolTable = symbols; this.cache = new HashMap(); @@ -56,36 +56,36 @@ public class CompressedIterators { symbolTable.add(symbol); symbolMap.put(symbol, id); } - + return id; } - + public ByteBuffer compress(IteratorSetting[] iterators) { - + UnsynchronizedBuffer.Writer out = new UnsynchronizedBuffer.Writer(iterators.length * 8); - + out.writeVInt(iterators.length); for (IteratorSetting is : iterators) { out.writeVInt(getSymbolID(is.getName())); out.writeVInt(getSymbolID(is.getIteratorClass())); out.writeVInt(is.getPriority()); - + Map opts = is.getOptions(); out.writeVInt(opts.size()); - + for (Entry entry : opts.entrySet()) { out.writeVInt(getSymbolID(entry.getKey())); out.writeVInt(getSymbolID(entry.getValue())); } } - + return out.toByteBuffer(); - + } - + public IterConfig decompress(ByteBuffer iterators) { - + ByteSequence iterKey = new ArrayByteSequence(iterators); IterConfig config = cache.get(iterKey); if (config != null) { @@ -97,27 +97,27 @@ public class CompressedIterators { UnsynchronizedBuffer.Reader in = new UnsynchronizedBuffer.Reader(iterators); int num = in.readVInt(); - + for (int i = 0; i < num; i++) { String name = symbolTable.get(in.readVInt()); String iterClass = symbolTable.get(in.readVInt()); int prio = in.readVInt(); - + config.ssiList.add(new IterInfo(prio, iterClass, name)); - + int numOpts = in.readVInt(); - + HashMap opts = new HashMap(); - + for (int j = 0; j < numOpts; j++) { String key = symbolTable.get(in.readVInt()); String val = symbolTable.get(in.readVInt()); - + opts.put(key, val); } - + config.ssio.put(name, opts); - + } cache.put(iterKey, config);