You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@accumulo.apache.org by el...@apache.org on 2016/01/13 21:11:20 UTC

[1/6] accumulo git commit: ACCUMULO-3509 Fix a compiler warning.

Repository: accumulo
Updated Branches:
  refs/heads/1.6 29c6052d6 -> 8c6866efb
  refs/heads/1.7 94f4a19c0 -> a4a1d6eb3
  refs/heads/master 081eb1fac -> bd515fceb


ACCUMULO-3509 Fix a compiler warning.


Project: http://git-wip-us.apache.org/repos/asf/accumulo/repo
Commit: http://git-wip-us.apache.org/repos/asf/accumulo/commit/8c6866ef
Tree: http://git-wip-us.apache.org/repos/asf/accumulo/tree/8c6866ef
Diff: http://git-wip-us.apache.org/repos/asf/accumulo/diff/8c6866ef

Branch: refs/heads/1.6
Commit: 8c6866efbb40aa1732b79f99c92458f3e672d14a
Parents: 29c6052
Author: Josh Elser <el...@apache.org>
Authored: Wed Jan 13 14:08:50 2016 -0500
Committer: Josh Elser <el...@apache.org>
Committed: Wed Jan 13 14:08:50 2016 -0500

----------------------------------------------------------------------
 .../main/java/org/apache/accumulo/tserver/TabletServer.java    | 6 ++++--
 1 file changed, 4 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/8c6866ef/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java
----------------------------------------------------------------------
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java
index b7aaf06..4e3e00b 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java
@@ -923,15 +923,17 @@ public class TabletServer extends AbstractMetricsImpl implements org.apache.accu
 
     @Override
     public boolean cleanup() {
+      final boolean ret;
       try {
         if (nextBatchTask != null)
           nextBatchTask.cancel(true);
       } finally {
         if (scanner != null)
-          return scanner.close();
+          ret = scanner.close();
         else
-          return true;
+          ret = true;
       }
+      return ret;
     }
 
   }


[5/6] accumulo git commit: Merge branch '1.6' into 1.7

Posted by el...@apache.org.
Merge branch '1.6' into 1.7

Conflicts:
	server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java


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

Branch: refs/heads/1.7
Commit: a4a1d6eb3d810201cfe7e2d72cea475bd952055e
Parents: 94f4a19 8c6866e
Author: Josh Elser <el...@apache.org>
Authored: Wed Jan 13 14:54:15 2016 -0500
Committer: Josh Elser <el...@apache.org>
Committed: Wed Jan 13 14:54:15 2016 -0500

----------------------------------------------------------------------
 .../java/org/apache/accumulo/tserver/session/ScanSession.java  | 6 ++++--
 1 file changed, 4 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/a4a1d6eb/server/tserver/src/main/java/org/apache/accumulo/tserver/session/ScanSession.java
----------------------------------------------------------------------
diff --cc server/tserver/src/main/java/org/apache/accumulo/tserver/session/ScanSession.java
index 743f4d3,0000000..36a86ad
mode 100644,000000..100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/session/ScanSession.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/session/ScanSession.java
@@@ -1,72 -1,0 +1,74 @@@
 +/*
 + * Licensed to the Apache Software Foundation (ASF) under one or more
 + * contributor license agreements.  See the NOTICE file distributed with
 + * this work for additional information regarding copyright ownership.
 + * The ASF licenses this file to You under the Apache License, Version 2.0
 + * (the "License"); you may not use this file except in compliance with
 + * the License.  You may obtain a copy of the License at
 + *
 + *     http://www.apache.org/licenses/LICENSE-2.0
 + *
 + * Unless required by applicable law or agreed to in writing, software
 + * distributed under the License is distributed on an "AS IS" BASIS,
 + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
 + * See the License for the specific language governing permissions and
 + * limitations under the License.
 + */
 +package org.apache.accumulo.tserver.session;
 +
 +import java.util.List;
 +import java.util.Map;
 +import java.util.Set;
 +import java.util.concurrent.atomic.AtomicBoolean;
 +
 +import org.apache.accumulo.core.data.Column;
 +import org.apache.accumulo.core.data.impl.KeyExtent;
 +import org.apache.accumulo.core.data.thrift.IterInfo;
 +import org.apache.accumulo.core.security.Authorizations;
 +import org.apache.accumulo.core.security.thrift.TCredentials;
 +import org.apache.accumulo.core.util.Stat;
 +import org.apache.accumulo.tserver.scan.ScanTask;
 +import org.apache.accumulo.tserver.tablet.ScanBatch;
 +import org.apache.accumulo.tserver.tablet.Scanner;
 +
 +public class ScanSession extends Session {
 +  public final Stat nbTimes = new Stat();
 +  public final KeyExtent extent;
 +  public final Set<Column> columnSet;
 +  public final List<IterInfo> ssiList;
 +  public final Map<String,Map<String,String>> ssio;
 +  public final Authorizations auths;
 +  public final AtomicBoolean interruptFlag = new AtomicBoolean();
 +  public long entriesReturned = 0;
 +  public long batchCount = 0;
 +  public volatile ScanTask<ScanBatch> nextBatchTask;
 +  public Scanner scanner;
 +  public final long readaheadThreshold;
 +
 +  public ScanSession(TCredentials credentials, KeyExtent extent, Set<Column> columnSet, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio,
 +      Authorizations authorizations, long readaheadThreshold) {
 +    super(credentials);
 +    this.extent = extent;
 +    this.columnSet = columnSet;
 +    this.ssiList = ssiList;
 +    this.ssio = ssio;
 +    this.auths = authorizations;
 +    this.readaheadThreshold = readaheadThreshold;
 +  }
 +
 +  @Override
 +  public boolean cleanup() {
++    final boolean ret;
 +    try {
 +      if (nextBatchTask != null)
 +        nextBatchTask.cancel(true);
 +    } finally {
 +      if (scanner != null)
-         return scanner.close();
++        ret = scanner.close();
 +      else
-         return true;
++        ret = true;
 +    }
++    return ret;
 +  }
 +
 +}


[4/6] accumulo git commit: Merge branch '1.6' into 1.7

Posted by el...@apache.org.
Merge branch '1.6' into 1.7

Conflicts:
	server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java


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

Branch: refs/heads/master
Commit: a4a1d6eb3d810201cfe7e2d72cea475bd952055e
Parents: 94f4a19 8c6866e
Author: Josh Elser <el...@apache.org>
Authored: Wed Jan 13 14:54:15 2016 -0500
Committer: Josh Elser <el...@apache.org>
Committed: Wed Jan 13 14:54:15 2016 -0500

----------------------------------------------------------------------
 .../java/org/apache/accumulo/tserver/session/ScanSession.java  | 6 ++++--
 1 file changed, 4 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/a4a1d6eb/server/tserver/src/main/java/org/apache/accumulo/tserver/session/ScanSession.java
----------------------------------------------------------------------
diff --cc server/tserver/src/main/java/org/apache/accumulo/tserver/session/ScanSession.java
index 743f4d3,0000000..36a86ad
mode 100644,000000..100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/session/ScanSession.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/session/ScanSession.java
@@@ -1,72 -1,0 +1,74 @@@
 +/*
 + * Licensed to the Apache Software Foundation (ASF) under one or more
 + * contributor license agreements.  See the NOTICE file distributed with
 + * this work for additional information regarding copyright ownership.
 + * The ASF licenses this file to You under the Apache License, Version 2.0
 + * (the "License"); you may not use this file except in compliance with
 + * the License.  You may obtain a copy of the License at
 + *
 + *     http://www.apache.org/licenses/LICENSE-2.0
 + *
 + * Unless required by applicable law or agreed to in writing, software
 + * distributed under the License is distributed on an "AS IS" BASIS,
 + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
 + * See the License for the specific language governing permissions and
 + * limitations under the License.
 + */
 +package org.apache.accumulo.tserver.session;
 +
 +import java.util.List;
 +import java.util.Map;
 +import java.util.Set;
 +import java.util.concurrent.atomic.AtomicBoolean;
 +
 +import org.apache.accumulo.core.data.Column;
 +import org.apache.accumulo.core.data.impl.KeyExtent;
 +import org.apache.accumulo.core.data.thrift.IterInfo;
 +import org.apache.accumulo.core.security.Authorizations;
 +import org.apache.accumulo.core.security.thrift.TCredentials;
 +import org.apache.accumulo.core.util.Stat;
 +import org.apache.accumulo.tserver.scan.ScanTask;
 +import org.apache.accumulo.tserver.tablet.ScanBatch;
 +import org.apache.accumulo.tserver.tablet.Scanner;
 +
 +public class ScanSession extends Session {
 +  public final Stat nbTimes = new Stat();
 +  public final KeyExtent extent;
 +  public final Set<Column> columnSet;
 +  public final List<IterInfo> ssiList;
 +  public final Map<String,Map<String,String>> ssio;
 +  public final Authorizations auths;
 +  public final AtomicBoolean interruptFlag = new AtomicBoolean();
 +  public long entriesReturned = 0;
 +  public long batchCount = 0;
 +  public volatile ScanTask<ScanBatch> nextBatchTask;
 +  public Scanner scanner;
 +  public final long readaheadThreshold;
 +
 +  public ScanSession(TCredentials credentials, KeyExtent extent, Set<Column> columnSet, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio,
 +      Authorizations authorizations, long readaheadThreshold) {
 +    super(credentials);
 +    this.extent = extent;
 +    this.columnSet = columnSet;
 +    this.ssiList = ssiList;
 +    this.ssio = ssio;
 +    this.auths = authorizations;
 +    this.readaheadThreshold = readaheadThreshold;
 +  }
 +
 +  @Override
 +  public boolean cleanup() {
++    final boolean ret;
 +    try {
 +      if (nextBatchTask != null)
 +        nextBatchTask.cancel(true);
 +    } finally {
 +      if (scanner != null)
-         return scanner.close();
++        ret = scanner.close();
 +      else
-         return true;
++        ret = true;
 +    }
++    return ret;
 +  }
 +
 +}


[2/6] accumulo git commit: ACCUMULO-3509 Fix a compiler warning.

Posted by el...@apache.org.
ACCUMULO-3509 Fix a compiler warning.


Project: http://git-wip-us.apache.org/repos/asf/accumulo/repo
Commit: http://git-wip-us.apache.org/repos/asf/accumulo/commit/8c6866ef
Tree: http://git-wip-us.apache.org/repos/asf/accumulo/tree/8c6866ef
Diff: http://git-wip-us.apache.org/repos/asf/accumulo/diff/8c6866ef

Branch: refs/heads/1.7
Commit: 8c6866efbb40aa1732b79f99c92458f3e672d14a
Parents: 29c6052
Author: Josh Elser <el...@apache.org>
Authored: Wed Jan 13 14:08:50 2016 -0500
Committer: Josh Elser <el...@apache.org>
Committed: Wed Jan 13 14:08:50 2016 -0500

----------------------------------------------------------------------
 .../main/java/org/apache/accumulo/tserver/TabletServer.java    | 6 ++++--
 1 file changed, 4 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/8c6866ef/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java
----------------------------------------------------------------------
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java
index b7aaf06..4e3e00b 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java
@@ -923,15 +923,17 @@ public class TabletServer extends AbstractMetricsImpl implements org.apache.accu
 
     @Override
     public boolean cleanup() {
+      final boolean ret;
       try {
         if (nextBatchTask != null)
           nextBatchTask.cancel(true);
       } finally {
         if (scanner != null)
-          return scanner.close();
+          ret = scanner.close();
         else
-          return true;
+          ret = true;
       }
+      return ret;
     }
 
   }


[3/6] accumulo git commit: ACCUMULO-3509 Fix a compiler warning.

Posted by el...@apache.org.
ACCUMULO-3509 Fix a compiler warning.


Project: http://git-wip-us.apache.org/repos/asf/accumulo/repo
Commit: http://git-wip-us.apache.org/repos/asf/accumulo/commit/8c6866ef
Tree: http://git-wip-us.apache.org/repos/asf/accumulo/tree/8c6866ef
Diff: http://git-wip-us.apache.org/repos/asf/accumulo/diff/8c6866ef

Branch: refs/heads/master
Commit: 8c6866efbb40aa1732b79f99c92458f3e672d14a
Parents: 29c6052
Author: Josh Elser <el...@apache.org>
Authored: Wed Jan 13 14:08:50 2016 -0500
Committer: Josh Elser <el...@apache.org>
Committed: Wed Jan 13 14:08:50 2016 -0500

----------------------------------------------------------------------
 .../main/java/org/apache/accumulo/tserver/TabletServer.java    | 6 ++++--
 1 file changed, 4 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/8c6866ef/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java
----------------------------------------------------------------------
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java
index b7aaf06..4e3e00b 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/TabletServer.java
@@ -923,15 +923,17 @@ public class TabletServer extends AbstractMetricsImpl implements org.apache.accu
 
     @Override
     public boolean cleanup() {
+      final boolean ret;
       try {
         if (nextBatchTask != null)
           nextBatchTask.cancel(true);
       } finally {
         if (scanner != null)
-          return scanner.close();
+          ret = scanner.close();
         else
-          return true;
+          ret = true;
       }
+      return ret;
     }
 
   }


[6/6] accumulo git commit: Merge branch '1.7'

Posted by el...@apache.org.
Merge branch '1.7'


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

Branch: refs/heads/master
Commit: bd515fceb461854c78521beb9dad7121bbe75c08
Parents: 081eb1f a4a1d6e
Author: Josh Elser <el...@apache.org>
Authored: Wed Jan 13 15:11:10 2016 -0500
Committer: Josh Elser <el...@apache.org>
Committed: Wed Jan 13 15:11:10 2016 -0500

----------------------------------------------------------------------
 .../java/org/apache/accumulo/tserver/session/ScanSession.java  | 6 ++++--
 1 file changed, 4 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/bd515fce/server/tserver/src/main/java/org/apache/accumulo/tserver/session/ScanSession.java
----------------------------------------------------------------------