Fix checkstyle problems not detected by the current version 14/55814/2
authorDavid <david.suarez.fuentes@ericsson.com>
Thu, 20 Apr 2017 22:42:07 +0000 (00:42 +0200)
committerTom Pantelis <tompantelis@gmail.com>
Sat, 22 Apr 2017 13:53:53 +0000 (13:53 +0000)
This change is required for overall move to new Checkstyle version, see
https://git.opendaylight.org/gerrit/#/q/topic:bumpCheckstyle-stable/carbon

Most of the changes are redundant "final" modifiers.

Change-Id: I637dd46617ca144f0ed33bd705c6357493b887fe
Signed-off-by: David <david.suarez.fuentes@ericsson.com>
24 files changed:
opendaylight/md-sal/cds-access-api/src/main/java/org/opendaylight/controller/cluster/access/commands/AbstractReadTransactionRequest.java
opendaylight/md-sal/cds-access-api/src/main/java/org/opendaylight/controller/cluster/access/commands/LocalHistoryRequest.java
opendaylight/md-sal/cds-access-api/src/main/java/org/opendaylight/controller/cluster/access/commands/TransactionRequest.java
opendaylight/md-sal/cds-access-api/src/main/java/org/opendaylight/controller/cluster/access/concepts/Request.java
opendaylight/md-sal/cds-access-api/src/test/java/org/opendaylight/controller/cluster/access/commands/AbstractRequestSuccessTest.java
opendaylight/md-sal/cds-access-api/src/test/java/org/opendaylight/controller/cluster/access/concepts/AbstractRequestTest.java
opendaylight/md-sal/cds-access-client/src/main/java/org/opendaylight/controller/cluster/access/client/ProgressTracker.java
opendaylight/md-sal/sal-distributed-datastore/src/main/java/org/opendaylight/controller/cluster/datastore/ShardSnapshotCohort.java
opendaylight/md-sal/sal-distributed-datastore/src/main/java/org/opendaylight/controller/cluster/datastore/modification/AbstractModification.java
opendaylight/md-sal/sal-distributed-datastore/src/main/java/org/opendaylight/controller/cluster/datastore/policy/TestOnlyRaftPolicy.java
opendaylight/md-sal/sal-distributed-datastore/src/main/java/org/opendaylight/controller/cluster/sharding/DistributedShardedDOMDataTree.java
opendaylight/md-sal/sal-distributed-datastore/src/test/java/org/opendaylight/controller/cluster/databroker/ClientBackedDataStoreTest.java
opendaylight/md-sal/sal-distributed-datastore/src/test/java/org/opendaylight/controller/cluster/datastore/DistributedDataStoreIntegrationTest.java
opendaylight/md-sal/sal-distributed-datastore/src/test/java/org/opendaylight/controller/cluster/datastore/DistributedDataStoreRemotingIntegrationTest.java
opendaylight/md-sal/sal-distributed-datastore/src/test/java/org/opendaylight/controller/cluster/datastore/actors/ShardSnapshotActorTest.java
opendaylight/md-sal/sal-distributed-datastore/src/test/java/org/opendaylight/controller/cluster/datastore/messages/DatastoreSnapshotListTest.java
opendaylight/md-sal/sal-distributed-datastore/src/test/java/org/opendaylight/controller/cluster/datastore/persisted/ShardDataTreeSnapshotTest.java
opendaylight/md-sal/sal-distributed-datastore/src/test/java/org/opendaylight/controller/cluster/sharding/DistributedShardFrontendTest.java
opendaylight/md-sal/sal-remoterpc-connector/src/main/java/org/opendaylight/controller/remote/rpc/messages/ExecuteRpc.java
opendaylight/md-sal/sal-remoterpc-connector/src/main/java/org/opendaylight/controller/remote/rpc/registry/gossip/BucketStoreActor.java
opendaylight/md-sal/sal-remoterpc-connector/src/main/java/org/opendaylight/controller/remote/rpc/registry/mbeans/RemoteRpcRegistryMXBean.java
opendaylight/md-sal/sal-remoterpc-connector/src/test/java/org/opendaylight/controller/remote/rpc/RemoteRpcProviderTest.java
opendaylight/md-sal/sal-remoterpc-connector/src/test/java/org/opendaylight/controller/remote/rpc/RpcBrokerTest.java
opendaylight/md-sal/sal-remoterpc-connector/src/test/java/org/opendaylight/controller/remote/rpc/RpcListenerTest.java

index 6510d5b5b41ffeb9a90f53e25096af034b905041..c0d47145708c5e540e4e2a4fdff9ddcc4b48ad4c 100644 (file)
@@ -1,5 +1,5 @@
 /*
- * Copyright (c) 2016 Cisco Systems, Inc. and others.  All rights reserved.
+ * Copyright (c) 2016, 2017 Cisco Systems, Inc. and others.  All rights reserved.
  *
  * This program and the accompanying materials are made available under the
  * terms of the Eclipse Public License v1.0 which accompanies this distribution,
@@ -63,5 +63,5 @@ public abstract class AbstractReadTransactionRequest<T extends AbstractReadTrans
     }
 
     @Override
-    protected abstract AbstractReadTransactionRequestProxyV1<T> externalizableProxy(final ABIVersion version);
+    protected abstract AbstractReadTransactionRequestProxyV1<T> externalizableProxy(ABIVersion version);
 }
index 2955ed2b65eeac88e8dd9dd8d28a2ad42ff774d9..33d04850fb91d01a524a7f17ffc12820445e392a 100644 (file)
@@ -1,5 +1,5 @@
 /*
- * Copyright (c) 2016 Cisco Systems, Inc. and others.  All rights reserved.
+ * Copyright (c) 2016, 2017 Cisco Systems, Inc. and others.  All rights reserved.
  *
  * This program and the accompanying materials are made available under the
  * terms of the Eclipse Public License v1.0 which accompanies this distribution,
@@ -42,5 +42,5 @@ public abstract class LocalHistoryRequest<T extends LocalHistoryRequest<T>> exte
     }
 
     @Override
-    protected abstract AbstractLocalHistoryRequestProxy<T> externalizableProxy(final ABIVersion version);
+    protected abstract AbstractLocalHistoryRequestProxy<T> externalizableProxy(ABIVersion version);
 }
index 7ae6b81e3ba9db52c9e2f24f79e3226b65eaad68..4dcf6ea93c6451d5b0b96c3e3d24a29b9bbfe82f 100644 (file)
@@ -1,5 +1,5 @@
 /*
- * Copyright (c) 2016 Cisco Systems, Inc. and others.  All rights reserved.
+ * Copyright (c) 2016, 2017 Cisco Systems, Inc. and others.  All rights reserved.
  *
  * This program and the accompanying materials are made available under the
  * terms of the Eclipse Public License v1.0 which accompanies this distribution,
@@ -40,5 +40,5 @@ public abstract class TransactionRequest<T extends TransactionRequest<T>> extend
     }
 
     @Override
-    protected abstract AbstractTransactionRequestProxy<T> externalizableProxy(final ABIVersion version);
+    protected abstract AbstractTransactionRequestProxy<T> externalizableProxy(ABIVersion version);
 }
index 75fbadd00a702c0f5129a0a13686e2901382f823..5c8df7874163908f8869986e3db819dff9f0c3b2 100644 (file)
@@ -1,5 +1,5 @@
 /*
- * Copyright (c) 2016 Cisco Systems, Inc. and others.  All rights reserved.
+ * Copyright (c) 2016, 2017 Cisco Systems, Inc. and others.  All rights reserved.
  *
  * This program and the accompanying materials are made available under the
  * terms of the Eclipse Public License v1.0 which accompanies this distribution,
@@ -56,7 +56,7 @@ public abstract class Request<T extends WritableIdentifier, C extends Request<T,
      * @return {@link RequestFailure} corresponding to this request
      */
     @Nonnull
-    public abstract RequestFailure<T, ?> toRequestFailure(@Nonnull final RequestException cause);
+    public abstract RequestFailure<T, ?> toRequestFailure(@Nonnull RequestException cause);
 
     @Override
     protected ToStringHelper addToStringAttributes(final ToStringHelper toStringHelper) {
index f0bb6f325fb056faaff261cf1615edfca8981ccf..aea817dc03eda0bc03142eba4fb23dda5454408a 100644 (file)
@@ -38,5 +38,5 @@ public abstract class AbstractRequestSuccessTest<T extends RequestSuccess> {
         doAdditionalAssertions((T) deserialize);
     }
 
-    protected abstract void doAdditionalAssertions(final Object deserialize);
+    protected abstract void doAdditionalAssertions(Object deserialize);
 }
index 2229aff02206c1db1e7fdfcaa3979fb14f2811e1..16a2728b464d74cd2a08bf2e5a1c0d0c9e66be6e 100644 (file)
@@ -51,5 +51,5 @@ public abstract class AbstractRequestTest<T extends Request> {
         doAdditionalAssertions((T) deserialize);
     }
 
-    protected abstract void doAdditionalAssertions(final Object deserialize);
+    protected abstract void doAdditionalAssertions(Object deserialize);
 }
index 25b7d7edc94f5b97cf22c61536db872850461b8b..2a24077f6eb725c4374dfc4838c9bb1398d64b30 100644 (file)
@@ -1,5 +1,5 @@
 /*
- * Copyright (c) 2016 Cisco Systems, Inc. and others.  All rights reserved.
+ * Copyright (c) 2016, 2017 Cisco Systems, Inc. and others.  All rights reserved.
  *
  * This program and the accompanying materials are made available under the
  * terms of the Eclipse Public License v1.0 which accompanies this distribution,
@@ -306,5 +306,5 @@ abstract class ProgressTracker {
      * @param now tick number corresponding to caller's present
      * @return delay (in ticks) after which another openTask() would be fair to be called by the same thread again
      */
-    abstract long estimateIsolatedDelay(final long now);
+    abstract long estimateIsolatedDelay(long now);
 }
index c8f62e2a124817a156c8fa3ef434a7fbe373bf41..455c874229f3c1c86fd6c3fcfc5609a6c81a91bb 100644 (file)
@@ -1,5 +1,5 @@
 /*
- * Copyright (c) 2015 Brocade Communications Systems, Inc. and others.  All rights reserved.
+ * Copyright (c) 2015, 2017 Brocade Communications Systems, Inc. and others.  All rights reserved.
  *
  * This program and the accompanying materials are made available under the
  * terms of the Eclipse Public License v1.0 which accompanies this distribution,
@@ -98,7 +98,7 @@ class ShardSnapshotCohort implements RaftActorSnapshotCohort {
 
     @Override
     public State deserializeSnapshot(final ByteSource snapshotBytes) throws IOException {
-        try (final ObjectInputStream in = new ObjectInputStream(snapshotBytes.openStream())) {
+        try (ObjectInputStream in = new ObjectInputStream(snapshotBytes.openStream())) {
             return new ShardSnapshotState(ShardDataTreeSnapshot.deserialize(in));
         }
     }
index 02b8047b44bfae5ca1094acc5b26ddfd07890a1b..c81468d6617a9a2302a17a2218c9e613764ebe2a 100644 (file)
@@ -1,5 +1,5 @@
 /*
- * Copyright (c) 2014 Cisco Systems, Inc. and others.  All rights reserved.
+ * Copyright (c) 2014, 2017 Cisco Systems, Inc. and others.  All rights reserved.
  *
  * This program and the accompanying materials are made available under the
  * terms of the Eclipse Public License v1.0 which accompanies this distribution,
@@ -8,7 +8,6 @@
 
 package org.opendaylight.controller.cluster.datastore.modification;
 
-
 import org.opendaylight.yangtools.yang.data.api.YangInstanceIdentifier;
 
 /**
index 83f9d3d277f2bc89a39f3decf6edad4163cf5df0..1f786137f798ac1a65bdb2de8d07bf65b4a57e1e 100644 (file)
@@ -1,5 +1,5 @@
 /*
- * Copyright (c) 2015 Cisco Systems, Inc. and others.  All rights reserved.
+ * Copyright (c) 2015, 2017 Cisco Systems, Inc. and others.  All rights reserved.
  *
  * This program and the accompanying materials are made available under the
  * terms of the Eclipse Public License v1.0 which accompanies this distribution,
@@ -8,7 +8,6 @@
 
 package org.opendaylight.controller.cluster.datastore.policy;
 
-
 import org.opendaylight.controller.cluster.raft.policy.RaftPolicy;
 
 /**
index 506498ce9a77fecbf9d7911296aafb49c1160f11..424439f6e58bbc62e28e914514b6f23516771f1f 100644 (file)
@@ -1,5 +1,5 @@
 /*
- * Copyright (c) 2016 Cisco Systems, Inc. and others.  All rights reserved.
+ * Copyright (c) 2016, 2017 Cisco Systems, Inc. and others.  All rights reserved.
  *
  * This program and the accompanying materials are made available under the
  * terms of the Eclipse Public License v1.0 which accompanies this distribution,
@@ -402,7 +402,7 @@ public class DistributedShardedDOMDataTree implements DOMDataTreeService, DOMDat
                 prefix.getDatastoreType().equals(org.opendaylight.mdsal.common.api.LogicalDatastoreType.CONFIGURATION)
                         ? distributedConfigDatastore : distributedOperDatastore;
 
-        try (final DOMDataTreeProducer producer = localCreateProducer(Collections.singletonList(prefix))) {
+        try (DOMDataTreeProducer producer = localCreateProducer(Collections.singletonList(prefix))) {
             final Entry<DataStoreClient, ActorRef> entry =
                     createDatastoreClient(shardName, distributedDataStore.getActorContext());
 
index bf107514809355dbcb2cff65384b083178fe3781..d7d774d699b3d791d59fd8d17b3d484e90feaa6d 100644 (file)
@@ -78,7 +78,7 @@ public class ClientBackedDataStoreTest {
 
     @Test
     public void testCreateTransactionChain() throws Exception {
-        try (final ClientBackedDataStore clientBackedDataStore = new ClientBackedDataStore(
+        try (ClientBackedDataStore clientBackedDataStore = new ClientBackedDataStore(
                 actorContext, UNKNOWN_ID, clientActor)) {
             final DOMStoreTransactionChain txChain = clientBackedDataStore.createTransactionChain();
             Assert.assertNotNull(txChain);
@@ -88,7 +88,7 @@ public class ClientBackedDataStoreTest {
 
     @Test
     public void testNewReadOnlyTransaction() throws Exception {
-        try (final ClientBackedDataStore clientBackedDataStore = new ClientBackedDataStore(
+        try (ClientBackedDataStore clientBackedDataStore = new ClientBackedDataStore(
                 actorContext, UNKNOWN_ID, clientActor)) {
             final DOMStoreReadTransaction tx = clientBackedDataStore.newReadOnlyTransaction();
             Assert.assertNotNull(tx);
@@ -98,7 +98,7 @@ public class ClientBackedDataStoreTest {
 
     @Test
     public void testNewWriteOnlyTransaction() throws Exception {
-        try (final ClientBackedDataStore clientBackedDataStore = new ClientBackedDataStore(
+        try (ClientBackedDataStore clientBackedDataStore = new ClientBackedDataStore(
                 actorContext, UNKNOWN_ID, clientActor)) {
             final DOMStoreWriteTransaction tx = clientBackedDataStore.newWriteOnlyTransaction();
             Assert.assertNotNull(tx);
@@ -108,11 +108,11 @@ public class ClientBackedDataStoreTest {
 
     @Test
     public void testNewReadWriteTransaction() throws Exception {
-        try (final ClientBackedDataStore clientBackedDataStore = new ClientBackedDataStore(
+        try (ClientBackedDataStore clientBackedDataStore = new ClientBackedDataStore(
                 actorContext, UNKNOWN_ID, clientActor)) {
             final DOMStoreReadWriteTransaction tx = clientBackedDataStore.newReadWriteTransaction();
             Assert.assertNotNull(tx);
             Mockito.verify(clientActor, Mockito.times(1)).createTransaction();
         }
     }
-}
\ No newline at end of file
+}
index e3aae92f9c2c200d0598600e88dea2cabf9cd4dc..2cd2b29c8d3e38d65f241d164f93570f560a4e9a 100644 (file)
@@ -1,5 +1,5 @@
 /*
- * Copyright (c) 2014, 2015 Cisco Systems, Inc. and others.  All rights reserved.
+ * Copyright (c) 2014, 2017 Cisco Systems, Inc. and others.  All rights reserved.
  *
  * This program and the accompanying materials are made available under the
  * terms of the Eclipse Public License v1.0 which accompanies this distribution,
@@ -139,7 +139,7 @@ public class DistributedDataStoreIntegrationTest {
     public void testWriteTransactionWithSingleShard() throws Exception {
         new IntegrationTestKit(getSystem(), datastoreContextBuilder) {
             {
-                try (final AbstractDataStore dataStore = setupAbstractDataStore(
+                try (AbstractDataStore dataStore = setupAbstractDataStore(
                         testParameter, "transactionIntegrationTest", "test-1")) {
 
                     testWriteTransaction(dataStore, TestModel.TEST_PATH,
@@ -156,7 +156,7 @@ public class DistributedDataStoreIntegrationTest {
     public void testWriteTransactionWithMultipleShards() throws Exception {
         new IntegrationTestKit(getSystem(), datastoreContextBuilder) {
             {
-                try (final AbstractDataStore dataStore = setupAbstractDataStore(
+                try (AbstractDataStore dataStore = setupAbstractDataStore(
                         testParameter, "testWriteTransactionWithMultipleShards", "cars-1", "people-1")) {
 
                     DOMStoreWriteTransaction writeTx = dataStore.newWriteOnlyTransaction();
@@ -205,7 +205,7 @@ public class DistributedDataStoreIntegrationTest {
     public void testReadWriteTransactionWithSingleShard() throws Exception {
         new IntegrationTestKit(getSystem(), datastoreContextBuilder) {
             {
-                try (final AbstractDataStore dataStore = setupAbstractDataStore(
+                try (AbstractDataStore dataStore = setupAbstractDataStore(
                         testParameter, "testReadWriteTransactionWithSingleShard", "test-1")) {
 
                     // 1. Create a read-write Tx
@@ -246,7 +246,7 @@ public class DistributedDataStoreIntegrationTest {
     public void testReadWriteTransactionWithMultipleShards() throws Exception {
         new IntegrationTestKit(getSystem(), datastoreContextBuilder) {
             {
-                try (final AbstractDataStore dataStore = setupAbstractDataStore(
+                try (AbstractDataStore dataStore = setupAbstractDataStore(
                         testParameter, "testReadWriteTransactionWithMultipleShards", "cars-1", "people-1")) {
 
                     DOMStoreReadWriteTransaction readWriteTx = dataStore.newReadWriteTransaction();
@@ -303,7 +303,7 @@ public class DistributedDataStoreIntegrationTest {
     public void testSingleTransactionsWritesInQuickSuccession() throws Exception {
         new IntegrationTestKit(getSystem(), datastoreContextBuilder) {
             {
-                try (final AbstractDataStore dataStore = setupAbstractDataStore(
+                try (AbstractDataStore dataStore = setupAbstractDataStore(
                         testParameter, "testSingleTransactionsWritesInQuickSuccession", "cars-1")) {
 
                     final DOMStoreTransactionChain txChain = dataStore.createTransactionChain();
@@ -346,7 +346,7 @@ public class DistributedDataStoreIntegrationTest {
                 final CountDownLatch blockRecoveryLatch = new CountDownLatch(1);
                 InMemoryJournal.addBlockReadMessagesLatch(persistentID, blockRecoveryLatch);
 
-                try (final AbstractDataStore dataStore = setupAbstractDataStore(
+                try (AbstractDataStore dataStore = setupAbstractDataStore(
                         testParameter, testName, false, shardName)) {
 
                     // Create the write Tx
@@ -446,7 +446,7 @@ public class DistributedDataStoreIntegrationTest {
                 final CountDownLatch blockRecoveryLatch = new CountDownLatch(1);
                 InMemoryJournal.addBlockReadMessagesLatch(persistentID, blockRecoveryLatch);
 
-                try (final AbstractDataStore dataStore = setupAbstractDataStore(
+                try (AbstractDataStore dataStore = setupAbstractDataStore(
                         testParameter, testName, false, shardName)) {
 
                     // Create the read-write Tx
@@ -590,7 +590,7 @@ public class DistributedDataStoreIntegrationTest {
 
                 InMemoryJournal.addEntry(persistentID, 1, "Dummy data so akka will read from persistence");
 
-                try (final AbstractDataStore dataStore = setupAbstractDataStore(
+                try (AbstractDataStore dataStore = setupAbstractDataStore(
                         testParameter, testName, false, shardName)) {
 
                     // Create the read-write Tx
@@ -660,7 +660,7 @@ public class DistributedDataStoreIntegrationTest {
                 datastoreContextBuilder.shardHeartbeatIntervalInMillis(100).shardElectionTimeoutFactor(1)
                         .shardInitializationTimeout(200, TimeUnit.MILLISECONDS);
 
-                try (final AbstractDataStore dataStore = setupAbstractDataStore(
+                try (AbstractDataStore dataStore = setupAbstractDataStore(
                         testParameter, testName, false, shardName)) {
 
                     final Object result = dataStore.getActorContext().executeOperation(
@@ -668,7 +668,7 @@ public class DistributedDataStoreIntegrationTest {
                     assertTrue("Expected LocalShardFound. Actual: " + result, result instanceof LocalShardFound);
 
                     // Create the write Tx.
-                    try (final DOMStoreWriteTransaction writeTx = writeOnly ? dataStore.newWriteOnlyTransaction()
+                    try (DOMStoreWriteTransaction writeTx = writeOnly ? dataStore.newWriteOnlyTransaction()
                             : dataStore.newReadWriteTransaction()) {
                         assertNotNull("newReadWriteTransaction returned null", writeTx);
 
@@ -731,7 +731,7 @@ public class DistributedDataStoreIntegrationTest {
     public void testTransactionAbort() throws Exception {
         new IntegrationTestKit(getSystem(), datastoreContextBuilder) {
             {
-                try (final AbstractDataStore dataStore = setupAbstractDataStore(
+                try (AbstractDataStore dataStore = setupAbstractDataStore(
                         testParameter, "transactionAbortIntegrationTest", "test-1")) {
 
                     final DOMStoreWriteTransaction writeTx = dataStore.newWriteOnlyTransaction();
@@ -757,7 +757,7 @@ public class DistributedDataStoreIntegrationTest {
     public void testTransactionChainWithSingleShard() throws Exception {
         new IntegrationTestKit(getSystem(), datastoreContextBuilder) {
             {
-                try (final AbstractDataStore dataStore = setupAbstractDataStore(
+                try (AbstractDataStore dataStore = setupAbstractDataStore(
                         testParameter, "testTransactionChainWithSingleShard", "test-1")) {
 
                     // 1. Create a Tx chain and write-only Tx
@@ -841,7 +841,7 @@ public class DistributedDataStoreIntegrationTest {
     public void testTransactionChainWithMultipleShards() throws Exception {
         new IntegrationTestKit(getSystem(), datastoreContextBuilder) {
             {
-                try (final AbstractDataStore dataStore = setupAbstractDataStore(
+                try (AbstractDataStore dataStore = setupAbstractDataStore(
                         testParameter, "testTransactionChainWithMultipleShards", "cars-1", "people-1")) {
 
                     final DOMStoreTransactionChain txChain = dataStore.createTransactionChain();
@@ -909,7 +909,7 @@ public class DistributedDataStoreIntegrationTest {
     public void testCreateChainedTransactionsInQuickSuccession() throws Exception {
         new IntegrationTestKit(getSystem(), datastoreContextBuilder) {
             {
-                try (final AbstractDataStore dataStore = setupAbstractDataStore(
+                try (AbstractDataStore dataStore = setupAbstractDataStore(
                         testParameter, "testCreateChainedTransactionsInQuickSuccession", "cars-1")) {
 
                     final ConcurrentDOMDataBroker broker = new ConcurrentDOMDataBroker(
@@ -958,7 +958,7 @@ public class DistributedDataStoreIntegrationTest {
     public void testCreateChainedTransactionAfterEmptyTxReadied() throws Exception {
         new IntegrationTestKit(getSystem(), datastoreContextBuilder) {
             {
-                try (final AbstractDataStore dataStore = setupAbstractDataStore(
+                try (AbstractDataStore dataStore = setupAbstractDataStore(
                         testParameter, "testCreateChainedTransactionAfterEmptyTxReadied", "test-1")) {
 
                     final DOMStoreTransactionChain txChain = dataStore.createTransactionChain();
@@ -983,7 +983,7 @@ public class DistributedDataStoreIntegrationTest {
     public void testCreateChainedTransactionWhenPreviousNotReady() throws Exception {
         new IntegrationTestKit(getSystem(), datastoreContextBuilder) {
             {
-                try (final AbstractDataStore dataStore = setupAbstractDataStore(
+                try (AbstractDataStore dataStore = setupAbstractDataStore(
                         testParameter, "testCreateChainedTransactionWhenPreviousNotReady", "test-1")) {
 
                     final DOMStoreTransactionChain txChain = dataStore.createTransactionChain();
@@ -1024,7 +1024,7 @@ public class DistributedDataStoreIntegrationTest {
     public void testChainWithReadOnlyTxAfterPreviousReady() throws Exception {
         new IntegrationTestKit(getSystem(), datastoreContextBuilder) {
             {
-                try (final AbstractDataStore dataStore = setupAbstractDataStore(
+                try (AbstractDataStore dataStore = setupAbstractDataStore(
                         testParameter, "testChainWithReadOnlyTxAfterPreviousReady", "test-1")) {
 
                     final DOMStoreTransactionChain txChain = dataStore.createTransactionChain();
@@ -1068,7 +1068,7 @@ public class DistributedDataStoreIntegrationTest {
     public void testChainedTransactionFailureWithSingleShard() throws Exception {
         new IntegrationTestKit(getSystem(), datastoreContextBuilder) {
             {
-                try (final AbstractDataStore dataStore = setupAbstractDataStore(
+                try (AbstractDataStore dataStore = setupAbstractDataStore(
                         testParameter, "testChainedTransactionFailureWithSingleShard", "cars-1")) {
 
                     final ConcurrentDOMDataBroker broker = new ConcurrentDOMDataBroker(
@@ -1111,7 +1111,7 @@ public class DistributedDataStoreIntegrationTest {
     public void testChainedTransactionFailureWithMultipleShards() throws Exception {
         new IntegrationTestKit(getSystem(), datastoreContextBuilder) {
             {
-                try (final AbstractDataStore dataStore = setupAbstractDataStore(
+                try (AbstractDataStore dataStore = setupAbstractDataStore(
                         testParameter, "testChainedTransactionFailureWithMultipleShards", "cars-1", "people-1")) {
 
                     final ConcurrentDOMDataBroker broker = new ConcurrentDOMDataBroker(
@@ -1157,7 +1157,7 @@ public class DistributedDataStoreIntegrationTest {
     public void testChangeListenerRegistration() throws Exception {
         new IntegrationTestKit(getSystem(), datastoreContextBuilder) {
             {
-                try (final AbstractDataStore dataStore = setupAbstractDataStore(
+                try (AbstractDataStore dataStore = setupAbstractDataStore(
                         testParameter, "testChangeListenerRegistration", "test-1")) {
 
                     testWriteTransaction(dataStore, TestModel.TEST_PATH,
@@ -1210,7 +1210,7 @@ public class DistributedDataStoreIntegrationTest {
     public void testDataTreeChangeListenerRegistration() throws Exception {
         new IntegrationTestKit(getSystem(), datastoreContextBuilder) {
             {
-                try (final AbstractDataStore dataStore = setupAbstractDataStore(
+                try (AbstractDataStore dataStore = setupAbstractDataStore(
                         testParameter, "testDataTreeChangeListenerRegistration", "test-1")) {
 
                     testWriteTransaction(dataStore, TestModel.TEST_PATH,
@@ -1294,7 +1294,7 @@ public class DistributedDataStoreIntegrationTest {
                         new DatastoreSnapshot.ShardSnapshot("cars", carsSnapshot),
                         new DatastoreSnapshot.ShardSnapshot("people", peopleSnapshot)));
 
-                try (final AbstractDataStore dataStore = setupAbstractDataStore(
+                try (AbstractDataStore dataStore = setupAbstractDataStore(
                         testParameter, name, "module-shards-member1.conf", true, "cars", "people")) {
 
                     final DOMStoreReadTransaction readTx = dataStore.newReadOnlyTransaction();
@@ -1330,7 +1330,7 @@ public class DistributedDataStoreIntegrationTest {
 
                 MetadataShardDataTreeSnapshot shardSnapshot = new MetadataShardDataTreeSnapshot(root);
                 final ByteArrayOutputStream bos = new ByteArrayOutputStream();
-                try (final DataOutputStream dos = new DataOutputStream(bos)) {
+                try (DataOutputStream dos = new DataOutputStream(bos)) {
                     PayloadVersion.BORON.writeTo(dos);
                     try (ObjectOutputStream oos = new ObjectOutputStream(dos)) {
                         oos.writeObject(shardSnapshot);
index 0ba0b6ca6950666bbbe97234cf76e2ebd065491a..2bd389eda32a07c82a9b5a7818cf9db8749ba3cf 100644 (file)
@@ -1,5 +1,5 @@
 /*
- * Copyright (c) 2015 Brocade Communications Systems, Inc. and others.  All rights reserved.
+ * Copyright (c) 2015, 2017 Brocade Communications Systems, Inc. and others.  All rights reserved.
  *
  * This program and the accompanying materials are made available under the
  * terms of the Eclipse Public License v1.0 which accompanies this distribution,
@@ -604,7 +604,7 @@ public class DistributedDataStoreRemotingIntegrationTest extends AbstractTest {
                 .shardHeartbeatIntervalInMillis(100).shardElectionTimeoutFactor(5);
         IntegrationTestKit newMember1TestKit = new IntegrationTestKit(leaderSystem, newMember1Builder, commitTimeout);
 
-        try (final AbstractDataStore ds =
+        try (AbstractDataStore ds =
                 newMember1TestKit.setupAbstractDataStore(
                         testParameter, testName, MODULE_SHARDS_CARS_ONLY_1_2, false, CARS)) {
 
@@ -880,7 +880,7 @@ public class DistributedDataStoreRemotingIntegrationTest extends AbstractTest {
         final IntegrationTestKit follower2TestKit = new IntegrationTestKit(follower2System,
                 DatastoreContext.newBuilderFrom(followerDatastoreContextBuilder.build()).operationTimeoutInMillis(100),
                 commitTimeout);
-        try (final AbstractDataStore follower2DistributedDataStore = follower2TestKit.setupAbstractDataStore(
+        try (AbstractDataStore follower2DistributedDataStore = follower2TestKit.setupAbstractDataStore(
                 testParameter, testName, MODULE_SHARDS_CARS_PEOPLE_1_2_3, false)) {
 
             // Create and submit a couple tx's so they're pending.
@@ -1060,7 +1060,7 @@ public class DistributedDataStoreRemotingIntegrationTest extends AbstractTest {
         final IntegrationTestKit follower2TestKit = new IntegrationTestKit(
                 follower2System, follower2DatastoreContextBuilder, commitTimeout);
 
-        try (final AbstractDataStore ds =
+        try (AbstractDataStore ds =
                 follower2TestKit.setupAbstractDataStore(
                         testParameter, testName, MODULE_SHARDS_CARS_PEOPLE_1_2_3, false, CARS)) {
 
index ae9499744f924fd1f932565e4057c9e3519b9091..f3660da6466138614a0d32659dd972cb92b84566 100644 (file)
@@ -1,5 +1,5 @@
 /*
- * Copyright (c) 2016 Cisco Systems, Inc. and others.  All rights reserved.
+ * Copyright (c) 2016, 2017 Cisco Systems, Inc. and others.  All rights reserved.
  *
  * This program and the accompanying materials are made available under the
  * terms of the Eclipse Public License v1.0 which accompanies this distribution,
@@ -49,7 +49,7 @@ public class ShardSnapshotActorTest extends AbstractActorTest {
 
                 if (installSnapshotStream != null) {
                     final ShardDataTreeSnapshot deserialized;
-                    try (final ObjectInputStream in = new ObjectInputStream(new ByteArrayInputStream(
+                    try (ObjectInputStream in = new ObjectInputStream(new ByteArrayInputStream(
                             installSnapshotStream.toByteArray()))) {
                         deserialized = ShardDataTreeSnapshot.deserialize(in);
                     }
index f344815a873b083f64a09171427ae3c289ce0441..7ae0b1c4985c735411ac5fcf975d05a57185d9e2 100644 (file)
@@ -146,7 +146,7 @@ public class DatastoreSnapshotListTest {
         final ByteArrayOutputStream bos = new ByteArrayOutputStream();
         if (root != null) {
             MetadataShardDataTreeSnapshot snapshot = new MetadataShardDataTreeSnapshot(root);
-            try (final DataOutputStream dos = new DataOutputStream(bos)) {
+            try (DataOutputStream dos = new DataOutputStream(bos)) {
                 PayloadVersion.BORON.writeTo(dos);
                 try (ObjectOutputStream oos = new ObjectOutputStream(dos)) {
                     oos.writeObject(snapshot);
index d999620180357f9297568addbc9dd85bc05a7c2a..1912c21db52c8a8db2f22c0250ec8fae2b9721dd 100644 (file)
@@ -1,5 +1,5 @@
 /*
- * Copyright (c) 2016 Brocade Communications Systems, Inc. and others.  All rights reserved.
+ * Copyright (c) 2016, 2017 Brocade Communications Systems, Inc. and others.  All rights reserved.
  *
  * This program and the accompanying materials are made available under the
  * terms of the Eclipse Public License v1.0 which accompanies this distribution,
@@ -43,12 +43,12 @@ public class ShardDataTreeSnapshotTest {
 
         MetadataShardDataTreeSnapshot snapshot = new MetadataShardDataTreeSnapshot(expectedNode);
         ByteArrayOutputStream bos = new ByteArrayOutputStream();
-        try (final ObjectOutputStream out = new ObjectOutputStream(bos)) {
+        try (ObjectOutputStream out = new ObjectOutputStream(bos)) {
             snapshot.serialize(out);
         }
 
         ShardDataTreeSnapshot deserialized;
-        try (final ObjectInputStream in = new ObjectInputStream(new ByteArrayInputStream(bos.toByteArray()))) {
+        try (ObjectInputStream in = new ObjectInputStream(new ByteArrayInputStream(bos.toByteArray()))) {
             deserialized = ShardDataTreeSnapshot.deserialize(in);
         }
 
@@ -69,12 +69,12 @@ public class ShardDataTreeSnapshotTest {
                 ImmutableMap.of(TestShardDataTreeSnapshotMetadata.class, new TestShardDataTreeSnapshotMetadata("test"));
         MetadataShardDataTreeSnapshot snapshot = new MetadataShardDataTreeSnapshot(expectedNode, expMetadata);
         ByteArrayOutputStream bos = new ByteArrayOutputStream();
-        try (final ObjectOutputStream out = new ObjectOutputStream(bos)) {
+        try (ObjectOutputStream out = new ObjectOutputStream(bos)) {
             snapshot.serialize(out);
         }
 
         ShardDataTreeSnapshot deserialized;
-        try (final ObjectInputStream in = new ObjectInputStream(new ByteArrayInputStream(bos.toByteArray()))) {
+        try (ObjectInputStream in = new ObjectInputStream(new ByteArrayInputStream(bos.toByteArray()))) {
             deserialized = ShardDataTreeSnapshot.deserialize(in);
         }
 
index 53840049b4f9b283aabb1060069b935295208e3a..b71095808468428e295cd1a155095b466529dba8 100644 (file)
@@ -1,5 +1,5 @@
 /*
- * Copyright (c) 2016 Cisco Systems, Inc. and others.  All rights reserved.
+ * Copyright (c) 2016, 2017 Cisco Systems, Inc. and others.  All rights reserved.
  *
  * This program and the accompanying materials are made available under the
  * terms of the Eclipse Public License v1.0 which accompanies this distribution,
@@ -116,7 +116,7 @@ public class DistributedShardFrontendTest {
 
         final DistributedShardFrontend rootShard = new DistributedShardFrontend(distributedDataStore, client, ROOT);
 
-        try (final DOMDataTreeProducer producer = shardedDOMDataTree.createProducer(Collections.singletonList(ROOT))) {
+        try (DOMDataTreeProducer producer = shardedDOMDataTree.createProducer(Collections.singletonList(ROOT))) {
             shardedDOMDataTree.registerDataTreeShard(ROOT, rootShard, producer);
         }
 
@@ -142,7 +142,7 @@ public class DistributedShardFrontendTest {
 
         final DistributedShardFrontend outerListShard = new DistributedShardFrontend(
                 distributedDataStore, outerListClient, OUTER_LIST_ID);
-        try (final DOMDataTreeProducer producer =
+        try (DOMDataTreeProducer producer =
                      shardedDOMDataTree.createProducer(Collections.singletonList(OUTER_LIST_ID))) {
             shardedDOMDataTree.registerDataTreeShard(OUTER_LIST_ID, outerListShard, producer);
         }
@@ -213,6 +213,4 @@ public class DistributedShardFrontendTest {
 
         return testContainer;
     }
-
-
-}
\ No newline at end of file
+}
index 4824cd71cc3fe4a2b6324a2b0ae0ce2cd7b238ec..7d647cff8c1c4a5305e2f43b69b665c8c7de7da9 100644 (file)
@@ -1,5 +1,5 @@
 /*
- * Copyright (c) 2014 Cisco Systems, Inc. and others.  All rights reserved.
+ * Copyright (c) 2014, 2017 Cisco Systems, Inc. and others.  All rights reserved.
  *
  * This program and the accompanying materials are made available under the
  * terms of the Eclipse Public License v1.0 which accompanies this distribution,
@@ -7,7 +7,6 @@
  */
 package org.opendaylight.controller.remote.rpc.messages;
 
-
 import com.google.common.base.MoreObjects;
 import com.google.common.base.Preconditions;
 import edu.umd.cs.findbugs.annotations.SuppressFBWarnings;
index f627138c67f17db857b46aaa59760ef4488bf06d..02e8770337f0dbb407fed53bb08d98ecec6d38a4 100644 (file)
@@ -1,5 +1,5 @@
 /*
- * Copyright (c) 2014 Cisco Systems, Inc. and others.  All rights reserved.
+ * Copyright (c) 2014, 2017 Cisco Systems, Inc. and others.  All rights reserved.
  *
  * This program and the accompanying materials are made available under the
  * terms of the Eclipse Public License v1.0 which accompanies this distribution,
@@ -230,14 +230,14 @@ public abstract class BucketStoreActor<T extends BucketData<T>> extends
      * @param address Remote address
      * @param bucket Bucket removed
      */
-    protected abstract void onBucketRemoved(final Address address, final Bucket<T> bucket);
+    protected abstract void onBucketRemoved(Address address, Bucket<T> bucket);
 
     /**
      * Callback to subclasses invoked when the set of remote buckets is updated.
      *
      * @param newBuckets Map of address to new bucket. Never null, but can be empty.
      */
-    protected abstract void onBucketsUpdated(final Map<Address, Bucket<T>> newBuckets);
+    protected abstract void onBucketsUpdated(Map<Address, Bucket<T>> newBuckets);
 
     /**
      * Helper to collect all known buckets.
index ea54e67b06acafc183975d2144a82338261e1d45..47903bb114221df67c2cbb899ea46c54780910d3 100644 (file)
@@ -1,5 +1,5 @@
 /*
- * Copyright (c) 2015 Cisco Systems, Inc. and others.  All rights reserved.
+ * Copyright (c) 2015, 2017 Cisco Systems, Inc. and others.  All rights reserved.
  *
  * This program and the accompanying materials are made available under the
  * terms of the Eclipse Public License v1.0 which accompanies this distribution,
@@ -8,7 +8,6 @@
 
 package org.opendaylight.controller.remote.rpc.registry.mbeans;
 
-
 import java.util.Map;
 import java.util.Set;
 
index 45fc9ffbbc7f4eea33586935a82b74a7f5ed1f20..a5158bc94db0dc76cd36a781680bd97e355219af 100644 (file)
@@ -1,5 +1,5 @@
 /*
- * Copyright (c) 2014 Cisco Systems, Inc. and others.  All rights reserved.
+ * Copyright (c) 2014, 2017 Cisco Systems, Inc. and others.  All rights reserved.
  *
  * This program and the accompanying materials are made available under the
  * terms of the Eclipse Public License v1.0 which accompanies this distribution,
@@ -46,7 +46,7 @@ public class RemoteRpcProviderTest {
 
     @Test
     public void testRemoteRpcProvider() throws Exception {
-        try (final RemoteRpcProvider rpcProvider = new RemoteRpcProvider(system, mock(DOMRpcProviderService.class),
+        try (RemoteRpcProvider rpcProvider = new RemoteRpcProvider(system, mock(DOMRpcProviderService.class),
             mock(DOMRpcService.class), new RemoteRpcProviderConfig(system.settings().config()))) {
 
             rpcProvider.start();
index 4fb0083863ee6e689284f9e78a8a44ab9a2b519a..02d46319e9fb022581ef97a3e0c254a178d83317 100644 (file)
@@ -1,5 +1,5 @@
 /*
- * Copyright (c) 2014 Cisco Systems, Inc. and others.  All rights reserved.
+ * Copyright (c) 2014, 2017 Cisco Systems, Inc. and others.  All rights reserved.
  *
  * This program and the accompanying materials are made available under the
  * terms of the Eclipse Public License v1.0 which accompanies this distribution,
@@ -8,7 +8,6 @@
 
 package org.opendaylight.controller.remote.rpc;
 
-
 import static org.junit.Assert.assertEquals;
 import static org.mockito.Matchers.eq;
 import static org.mockito.Mockito.when;
index 37d81c7afb7859e9e18b616afdef46befad71f42..fa64bbd15b5ff12633c21ef37537d337e7596ec4 100644 (file)
@@ -1,5 +1,5 @@
 /*
- * Copyright (c) 2014 Cisco Systems, Inc. and others.  All rights reserved.
+ * Copyright (c) 2014, 2017 Cisco Systems, Inc. and others.  All rights reserved.
  *
  * This program and the accompanying materials are made available under the
  * terms of the Eclipse Public License v1.0 which accompanies this distribution,
@@ -8,7 +8,6 @@
 
 package org.opendaylight.controller.remote.rpc;
 
-
 import akka.actor.ActorRef;
 import akka.actor.ActorSystem;
 import akka.testkit.JavaTestKit;