You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ace.apache.org by ja...@apache.org on 2016/01/29 09:59:34 UTC

svn commit: r1727499 [4/5] - in /ace/trunk: ./ org.apache.ace.agent.controller.itest/src/org/apache/ace/agent/itest/ org.apache.ace.agent.itest/src/org/apache/ace/agent/itest/ org.apache.ace.agent.launcher/src/org/apache/ace/agent/launcher/ org.apache....

Modified: ace/trunk/org.apache.ace.gogo/src/org/apache/ace/gogo/queue/QueueCommands.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.gogo/src/org/apache/ace/gogo/queue/QueueCommands.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.gogo/src/org/apache/ace/gogo/queue/QueueCommands.java (original)
+++ ace/trunk/org.apache.ace.gogo/src/org/apache/ace/gogo/queue/QueueCommands.java Fri Jan 29 08:59:31 2016
@@ -73,7 +73,7 @@ public class QueueCommands {
     public final static String SCOPE = "queue";
     public final static String[] FUNCTIONS = new String[] { "put", "get", "contains" };
 
-    private final BlockingQueue<Dictionary<String, String>> m_queue = new LinkedBlockingQueue<Dictionary<String, String>>();
+    private final BlockingQueue<Dictionary<String, String>> m_queue = new LinkedBlockingQueue<>();
 
     @Descriptor("puts a new script definition on the queue")
     public void put(@Descriptor("the script definition to put onto the queue, which consists of a map with at least a 'script' key") Map<String, String> def) throws Exception {
@@ -94,7 +94,7 @@ public class QueueCommands {
 
     @Descriptor("returns whether anything is present on the queue matchin a given filter definition")
     public boolean contains(@Descriptor("Represents an OSGi-filter to search with") String filter) throws Exception {
-        List<Dictionary<String, String>> copy = new ArrayList<Dictionary<String, String>>(m_queue);
+        List<Dictionary<String, String>> copy = new ArrayList<>(m_queue);
         if (filter == null || "".equals(filter.trim())) {
             return !copy.isEmpty();
         }
@@ -117,9 +117,9 @@ public class QueueCommands {
 
     @Descriptor("returns the script definition from the queue matching a given filter, if available")
     public Map<String, String>[] get(@Descriptor("Represents an OSGi-filter to match against the script definitions") String filter) throws Exception {
-        List<Dictionary<String, String>> copy = new ArrayList<Dictionary<String, String>>(m_queue);
+        List<Dictionary<String, String>> copy = new ArrayList<>(m_queue);
 
-        List<Map<String, String>> result = new ArrayList<Map<String, String>>();
+        List<Map<String, String>> result = new ArrayList<>();
 
         Filter f = FrameworkUtil.createFilter(filter);
         for (Dictionary<String, String> entry : copy) {
@@ -133,7 +133,7 @@ public class QueueCommands {
     }
 
     private static Dictionary<String, String> toDictionary(Map<String, String> map) {
-        Dictionary<String, String> result = new Hashtable<String, String>();
+        Dictionary<String, String> result = new Hashtable<>();
         for (Map.Entry<String, String> entry : map.entrySet()) {
             result.put(entry.getKey(), entry.getValue());
         }
@@ -141,7 +141,7 @@ public class QueueCommands {
     }
 
     private static Map<String, String> toMap(Dictionary<String, String> dict) {
-        Map<String, String> result = new HashMap<String, String>();
+        Map<String, String> result = new HashMap<>();
         Enumeration<String> keys = dict.keys();
         while (keys.hasMoreElements()) {
             String key = keys.nextElement();

Modified: ace/trunk/org.apache.ace.gogo/src/org/apache/ace/gogo/repo/CommandResource.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.gogo/src/org/apache/ace/gogo/repo/CommandResource.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.gogo/src/org/apache/ace/gogo/repo/CommandResource.java (original)
+++ ace/trunk/org.apache.ace.gogo/src/org/apache/ace/gogo/repo/CommandResource.java Fri Jan 29 08:59:31 2016
@@ -28,7 +28,7 @@ import org.osgi.resource.Resource;
 public class CommandResource {
 
     public static List<CommandResource> wrap(CommandRepo repo, List<Resource> resources) {
-        List<CommandResource> commandResources = new LinkedList<CommandResource>();
+        List<CommandResource> commandResources = new LinkedList<>();
         for (Resource resource : resources) {
             commandResources.add(new CommandResource(repo, resource));
         }

Modified: ace/trunk/org.apache.ace.gogo/src/org/apache/ace/gogo/repo/ContinuousDeployer.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.gogo/src/org/apache/ace/gogo/repo/ContinuousDeployer.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.gogo/src/org/apache/ace/gogo/repo/ContinuousDeployer.java (original)
+++ ace/trunk/org.apache.ace.gogo/src/org/apache/ace/gogo/repo/ContinuousDeployer.java Fri Jan 29 08:59:31 2016
@@ -66,7 +66,7 @@ public class ContinuousDeployer {
      */
     public List<Resource> deployResources() throws Exception {
         List<Resource> developmentResources = findResources(m_developmentRepo, "*", "*");
-        List<Resource> deployedResources = new ArrayList<Resource>();
+        List<Resource> deployedResources = new ArrayList<>();
         for (Resource developmentResource : developmentResources) {
             deployedResources.add(deployResource(developmentResource));
         }

Modified: ace/trunk/org.apache.ace.gogo/src/org/apache/ace/gogo/repo/RepositoryUtil.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.gogo/src/org/apache/ace/gogo/repo/RepositoryUtil.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.gogo/src/org/apache/ace/gogo/repo/RepositoryUtil.java (original)
+++ ace/trunk/org.apache.ace.gogo/src/org/apache/ace/gogo/repo/RepositoryUtil.java Fri Jan 29 08:59:31 2016
@@ -54,7 +54,7 @@ import aQute.bnd.service.Strategy;
 public class RepositoryUtil {
 
     public static AceObrRepository createRepository(String type, String location) throws Exception {
-        Map<String, String> properties = new HashMap<String, String>();
+        Map<String, String> properties = new HashMap<>();
         properties.put(AceObrRepository.PROP_REPO_TYPE, type);
         properties.put(AceObrRepository.PROP_LOCATIONS, location);
         AceObrRepository repository = new AceObrRepository();
@@ -70,8 +70,8 @@ public class RepositoryUtil {
         }
 
         File indexFile = new File(rootDir, "index.xml");
-        Set<File> files = new HashSet<File>();
-        Stack<File> dirs = new Stack<File>();
+        Set<File> files = new HashSet<>();
+        Stack<File> dirs = new Stack<>();
         dirs.push(rootDir);
         while (!dirs.isEmpty()) {
             File dir = dirs.pop();
@@ -86,7 +86,7 @@ public class RepositoryUtil {
         }
 
         RepoIndex indexer = new RepoIndex();
-        Map<String, String> config = new HashMap<String, String>();
+        Map<String, String> config = new HashMap<>();
         config.put(ResourceIndexer.REPOSITORY_NAME, "empty");
         config.put(ResourceIndexer.PRETTY, "true");
         config.put(ResourceIndexer.ROOT_URL, rootDir.getAbsoluteFile().toURI().toURL().toString());
@@ -203,7 +203,7 @@ public class RepositoryUtil {
 
     public static List<Resource> copyResources(AbstractIndexedRepo sourceRepo, AbstractIndexedRepo targetRepo, Requirement requirement) throws Exception {
         List<Resource> sourceResources = findResources(sourceRepo, requirement);
-        List<Resource> targetResources = new ArrayList<Resource>();
+        List<Resource> targetResources = new ArrayList<>();
         for (Resource resource : sourceResources) {
             targetResources.add(copyResource(sourceRepo, targetRepo, resource));
         }
@@ -211,7 +211,7 @@ public class RepositoryUtil {
     }
 
     public static List<Resource> copyResources(AbstractIndexedRepo sourceRepo, AbstractIndexedRepo targetRepo, List<Resource> resources) throws Exception {
-        List<Resource> targetResources = new LinkedList<Resource>();
+        List<Resource> targetResources = new LinkedList<>();
         for (Resource resource : resources) {
             Resource targetResource = copyResource(sourceRepo, targetRepo, resource);
             targetResources.add(targetResource);
@@ -297,7 +297,7 @@ public class RepositoryUtil {
         if (sourceResources.isEmpty() || sourceResources.get(requirement).isEmpty()) {
             return Collections.emptyList();
         }
-        List<Resource> resources = new ArrayList<Resource>();
+        List<Resource> resources = new ArrayList<>();
         Iterator<Capability> capabilities = sourceResources.get(requirement).iterator();
         while (capabilities.hasNext()) {
             Capability capability = capabilities.next();
@@ -315,7 +315,7 @@ public class RepositoryUtil {
     }
 
     public static List<Version> getVersions(List<Resource> resources) {
-        List<Version> versions = new ArrayList<Version>();
+        List<Version> versions = new ArrayList<>();
         for (Resource resource : resources) {
             versions.add(getVersion(resource));
         }

Modified: ace/trunk/org.apache.ace.http.itest/src/org/apache/ace/it/http/ServletConfiguratorIntegrationTest.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.http.itest/src/org/apache/ace/it/http/ServletConfiguratorIntegrationTest.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.http.itest/src/org/apache/ace/it/http/ServletConfiguratorIntegrationTest.java (original)
+++ ace/trunk/org.apache.ace.http.itest/src/org/apache/ace/it/http/ServletConfiguratorIntegrationTest.java Fri Jan 29 08:59:31 2016
@@ -75,7 +75,7 @@ public class ServletConfiguratorIntegrat
 	protected void configureProvisionedServices() throws Exception {
         m_echoServlet = new EchoServlet();
 
-        Dictionary<String, String> dictionary = new Hashtable<String, String>();
+        Dictionary<String, String> dictionary = new Hashtable<>();
         dictionary.put(HttpConstants.ENDPOINT, "/echoServlet");
         m_echoServletService = m_dependencyManager.createComponent()
             .setImplementation(m_echoServlet)

Modified: ace/trunk/org.apache.ace.http/src/org/apache/ace/http/listener/Activator.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.http/src/org/apache/ace/http/listener/Activator.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.http/src/org/apache/ace/http/listener/Activator.java (original)
+++ ace/trunk/org.apache.ace.http/src/org/apache/ace/http/listener/Activator.java Fri Jan 29 08:59:31 2016
@@ -108,7 +108,7 @@ public class Activator extends Dependenc
     }
 
     private Dictionary<String, Object> getInitParams(ServiceReference ref) {
-        Dictionary<String, Object> initParams = new Hashtable<String, Object>();
+        Dictionary<String, Object> initParams = new Hashtable<>();
         for (String key : ref.getPropertyKeys()) {
             if (key.startsWith(INIT_PREFIX)) {
                 initParams.put(key.substring(INIT_PREFIX.length()), ref.getProperty(key));

Modified: ace/trunk/org.apache.ace.http/src/org/apache/ace/http/redirector/Activator.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.http/src/org/apache/ace/http/redirector/Activator.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.http/src/org/apache/ace/http/redirector/Activator.java (original)
+++ ace/trunk/org.apache.ace.http/src/org/apache/ace/http/redirector/Activator.java Fri Jan 29 08:59:31 2016
@@ -34,7 +34,7 @@ import org.osgi.service.cm.ManagedServic
 
 public class Activator extends DependencyActivatorBase implements ManagedServiceFactory {
     private static final String PID = "org.apache.ace.http.redirector.factory";
-    private final ConcurrentHashMap<String, Component> m_servlets = new ConcurrentHashMap<String, Component>();
+    private final ConcurrentHashMap<String, Component> m_servlets = new ConcurrentHashMap<>();
     
     @Override
     public void init(BundleContext context, DependencyManager manager) throws Exception {

Modified: ace/trunk/org.apache.ace.identification/src/org/apache/ace/identification/property/Activator.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.identification/src/org/apache/ace/identification/property/Activator.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.identification/src/org/apache/ace/identification/property/Activator.java (original)
+++ ace/trunk/org.apache.ace.identification/src/org/apache/ace/identification/property/Activator.java Fri Jan 29 08:59:31 2016
@@ -37,7 +37,7 @@ import org.osgi.service.log.LogService;
 public class Activator extends DependencyActivatorBase implements ManagedServiceFactory {
     private static final String MA_NAME = "ma";
     private DependencyManager m_manager;
-    private final Map<String, Component> m_instances = new HashMap<String, Component>();
+    private final Map<String, Component> m_instances = new HashMap<>();
     
     public synchronized void init(BundleContext context, DependencyManager manager) throws Exception {
         m_manager = manager;

Modified: ace/trunk/org.apache.ace.log.itest/src/org/apache/ace/it/log/LogIntegrationTest.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.log.itest/src/org/apache/ace/it/log/LogIntegrationTest.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.log.itest/src/org/apache/ace/it/log/LogIntegrationTest.java (original)
+++ ace/trunk/org.apache.ace.log.itest/src/org/apache/ace/it/log/LogIntegrationTest.java Fri Jan 29 08:59:31 2016
@@ -138,7 +138,7 @@ public class LogIntegrationTest extends
 
     private void doTestServlet() throws Exception {
         // prepare the store
-        List<Event> events = new ArrayList<Event>();
+        List<Event> events = new ArrayList<>();
         events.add(new Event("42", 1, 1, 1, 1));
         events.add(new Event("47", 1, 1, 1, 1));
         events.add(new Event("47", 2, 1, 1, 1));

Modified: ace/trunk/org.apache.ace.log.server.ui/src/org/apache/ace/log/server/ui/LogViewerExtension.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.log.server.ui/src/org/apache/ace/log/server/ui/LogViewerExtension.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.log.server.ui/src/org/apache/ace/log/server/ui/LogViewerExtension.java (original)
+++ ace/trunk/org.apache.ace.log.server.ui/src/org/apache/ace/log/server/ui/LogViewerExtension.java Fri Jan 29 08:59:31 2016
@@ -73,7 +73,7 @@ public class LogViewerExtension implemen
     /**
      * contains a mapping of event type to a string representation of that type.
      */
-    private final Map<Integer, String> m_eventTypeMapping = new HashMap<Integer, String>();
+    private final Map<Integer, String> m_eventTypeMapping = new HashMap<>();
 
     /**
      * {@inheritDoc}

Modified: ace/trunk/org.apache.ace.log/src/org/apache/ace/log/listener/Activator.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.log/src/org/apache/ace/log/listener/Activator.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.log/src/org/apache/ace/log/listener/Activator.java (original)
+++ ace/trunk/org.apache.ace.log/src/org/apache/ace/log/listener/Activator.java Fri Jan 29 08:59:31 2016
@@ -53,7 +53,7 @@ public class Activator implements Bundle
         context.addFrameworkListener(m_listener);
 
         // listen for deployment events
-        Dictionary<String, Object> dict = new Hashtable<String, Object>();
+        Dictionary<String, Object> dict = new Hashtable<>();
         dict.put(EventConstants.EVENT_TOPIC, topics);
         context.registerService(EventHandler.class.getName(), m_listener, dict);
 

Modified: ace/trunk/org.apache.ace.log/src/org/apache/ace/log/listener/ListenerImpl.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.log/src/org/apache/ace/log/listener/ListenerImpl.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.log/src/org/apache/ace/log/listener/ListenerImpl.java (original)
+++ ace/trunk/org.apache.ace.log/src/org/apache/ace/log/listener/ListenerImpl.java Fri Jan 29 08:59:31 2016
@@ -55,7 +55,7 @@ public class ListenerImpl implements Bun
     volatile BundleContext m_context;
     volatile Log m_auditLog;
 
-    private final List<Runnable> m_queue = new ArrayList<Runnable>();
+    private final List<Runnable> m_queue = new ArrayList<>();
 
     public ListenerImpl(BundleContext context, Log log) {
         m_context = context;
@@ -202,7 +202,7 @@ public class ListenerImpl implements Bun
             m_queue.add(new Runnable() {
                 public void run() {
                     int eventType = AuditEvent.DEPLOYMENTADMIN_BASE;
-                    Dictionary<String, Object> props = new Hashtable<String, Object>();
+                    Dictionary<String, Object> props = new Hashtable<>();
 
                     String topic = event.getTopic();
 

Modified: ace/trunk/org.apache.ace.log/src/org/apache/ace/log/listener/LogCache.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.log/src/org/apache/ace/log/listener/LogCache.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.log/src/org/apache/ace/log/listener/LogCache.java (original)
+++ ace/trunk/org.apache.ace.log/src/org/apache/ace/log/listener/LogCache.java Fri Jan 29 08:59:31 2016
@@ -31,7 +31,7 @@ import org.apache.ace.log.Log;
  */
 public class LogCache implements Log {
 
-    private final List<LogEntry> m_logEntries = new ArrayList<LogEntry>();
+    private final List<LogEntry> m_logEntries = new ArrayList<>();
 
     /**
      * Log the entry in the cache for flushing to the real log service later on.

Modified: ace/trunk/org.apache.ace.log/src/org/apache/ace/log/server/servlet/Activator.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.log/src/org/apache/ace/log/server/servlet/Activator.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.log/src/org/apache/ace/log/server/servlet/Activator.java (original)
+++ ace/trunk/org.apache.ace.log/src/org/apache/ace/log/server/servlet/Activator.java Fri Jan 29 08:59:31 2016
@@ -43,7 +43,7 @@ public class Activator extends Dependenc
     /** A boolean denoting whether or not authentication is enabled. */
     private static final String KEY_USE_AUTHENTICATION = "authentication.enabled";
 
-    private final Map<String, Component> m_instances = new HashMap<String, Component>(); // String -> Service
+    private final Map<String, Component> m_instances = new HashMap<>(); // String -> Service
     private DependencyManager m_manager;
     private volatile LogService m_log;
 

Modified: ace/trunk/org.apache.ace.log/src/org/apache/ace/log/server/servlet/LogServlet.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.log/src/org/apache/ace/log/server/servlet/LogServlet.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.log/src/org/apache/ace/log/server/servlet/LogServlet.java (original)
+++ ace/trunk/org.apache.ace.log/src/org/apache/ace/log/server/servlet/LogServlet.java Fri Jan 29 08:59:31 2016
@@ -244,7 +244,7 @@ public class LogServlet extends HttpServ
 
     // Handle a call to the send 'command'
     protected boolean handleSend(ServletInputStream input) throws IOException {
-        List<Event> events = new ArrayList<Event>();
+        List<Event> events = new ArrayList<>();
         boolean success = true;
 
         BufferedReader reader = null;

Modified: ace/trunk/org.apache.ace.log/src/org/apache/ace/log/server/store/impl/Activator.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.log/src/org/apache/ace/log/server/store/impl/Activator.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.log/src/org/apache/ace/log/server/store/impl/Activator.java (original)
+++ ace/trunk/org.apache.ace.log/src/org/apache/ace/log/server/store/impl/Activator.java Fri Jan 29 08:59:31 2016
@@ -40,7 +40,7 @@ public class Activator extends Dependenc
 
     private static final String LOG_NAME = "name";
     private DependencyManager m_manager;
-    private final Map<String, Component> m_instances = new HashMap<String, Component>();
+    private final Map<String, Component> m_instances = new HashMap<>();
     private BundleContext m_context;
     private volatile LogService m_log;
 

Modified: ace/trunk/org.apache.ace.log/src/org/apache/ace/log/server/store/impl/LogStoreImpl.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.log/src/org/apache/ace/log/server/store/impl/LogStoreImpl.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.log/src/org/apache/ace/log/server/store/impl/LogStoreImpl.java (original)
+++ ace/trunk/org.apache.ace.log/src/org/apache/ace/log/server/store/impl/LogStoreImpl.java Fri Jan 29 08:59:31 2016
@@ -62,9 +62,9 @@ public class LogStoreImpl implements Log
     private final String m_name;
     private int m_maxEvents = 0;
 
-    private final ConcurrentMap<String, Set<Long>> m_locks = new ConcurrentHashMap<String, Set<Long>>();
-    private final Map<String, Long> m_fileToHighestID = new HashMap<String, Long>();
-    private final Map<String, Long> m_fileToLowestID = new HashMap<String, Long>();
+    private final ConcurrentMap<String, Set<Long>> m_locks = new ConcurrentHashMap<>();
+    private final Map<String, Long> m_fileToHighestID = new HashMap<>();
+    private final Map<String, Long> m_fileToLowestID = new HashMap<>();
 
     public LogStoreImpl(File baseDir, String name) {
         m_name = name;
@@ -101,7 +101,7 @@ public class LogStoreImpl implements Log
      *             if anything goes wrong
      */
     private List<Event> getInternal(Descriptor descriptor) throws IOException {
-        final List<Event> result = new ArrayList<Event>();
+        final List<Event> result = new ArrayList<>();
         final SortedRangeSet set = descriptor.getRangeSet();
         BufferedReader in = null;
         try {
@@ -183,7 +183,7 @@ public class LogStoreImpl implements Log
 
     public List<Descriptor> getDescriptors(String targetID) throws IOException {
         File dir = getTargetDirectory(targetID);
-        List<Descriptor> result = new ArrayList<Descriptor>();
+        List<Descriptor> result = new ArrayList<>();
         if (!dir.isDirectory()) {
             return result;
         }
@@ -196,7 +196,7 @@ public class LogStoreImpl implements Log
     }
 
 	public List<Descriptor> getDescriptors() throws IOException {
-        List<Descriptor> result = new ArrayList<Descriptor>();
+        List<Descriptor> result = new ArrayList<>();
         for (String name : notNull(m_dir.list())) {
             result.addAll(getDescriptors(filenameToTargetID(name)));
         }
@@ -231,7 +231,6 @@ public class LogStoreImpl implements Log
      * @throws java.io.IOException
      *             in case of any error.
      */
-    @SuppressWarnings("unchecked")
     protected void put(String targetID, Long logID, List<Event> list) throws IOException {
         if ((list == null) || list.isEmpty()) {
             // nothing to add, so return
@@ -301,7 +300,7 @@ public class LogStoreImpl implements Log
                     high = Long.MAX_VALUE;
                 }
                 // send (eventadmin)event about a new (log)event being stored
-                Dictionary<String, Object> props = new Hashtable<String, Object>();
+                Dictionary<String, Object> props = new Hashtable<>();
                 props.put(LogStore.EVENT_PROP_LOGNAME, m_name);
                 props.put(LogStore.EVENT_PROP_LOG_EVENT, event);
                 m_eventAdmin.postEvent(new org.osgi.service.event.Event(LogStore.EVENT_TOPIC, props));
@@ -353,18 +352,18 @@ public class LogStoreImpl implements Log
      */
     @SuppressWarnings("boxing")
     protected Map<String, Map<Long, List<Event>>> sort(List<Event> events) {
-        Map<String, Map<Long, List<Event>>> result = new HashMap<String, Map<Long, List<Event>>>();
+        Map<String, Map<Long, List<Event>>> result = new HashMap<>();
         for (Event event : events) {
             Map<Long, List<Event>> target = result.get(event.getTargetID());
 
             if (target == null) {
-                target = new HashMap<Long, List<Event>>();
+                target = new HashMap<>();
                 result.put(event.getTargetID(), target);
             }
 
             List<Event> list = target.get(event.getStoreID());
             if (list == null) {
-                list = new ArrayList<Event>();
+                list = new ArrayList<>();
                 target.put(event.getStoreID(), list);
             }
 
@@ -444,11 +443,11 @@ public class LogStoreImpl implements Log
             return;
         }
         // create a list of unique targets and their logs
-        Map<String, Set<Long>> allTargetsAndLogs = new HashMap<String, Set<Long>>();
+        Map<String, Set<Long>> allTargetsAndLogs = new HashMap<>();
         for (Descriptor descriptor : getDescriptors()) {
             Set<Long> logs = allTargetsAndLogs.get(descriptor.getTargetID());
             if (logs == null) {
-                logs = new HashSet<Long>();
+                logs = new HashSet<>();
                 allTargetsAndLogs.put(descriptor.getTargetID(), logs);
             }
             logs.add(descriptor.getStoreID());
@@ -477,7 +476,7 @@ public class LogStoreImpl implements Log
     }
 
     private void obtainLock(String targetID, long logID) throws IOException {
-        Set<Long> newLockedLogs = new HashSet<Long>();
+        Set<Long> newLockedLogs = new HashSet<>();
         Set<Long> lockedLogs = m_locks.putIfAbsent(targetID, newLockedLogs);
         if (lockedLogs == null) {
             lockedLogs = newLockedLogs;
@@ -529,7 +528,7 @@ public class LogStoreImpl implements Log
     
     @Override
     public Event put(String targetID, int type, Dictionary dict) throws IOException {
-        Map<String, String> props = new HashMap<String, String>();
+        Map<String, String> props = new HashMap<>();
         Enumeration keys = dict.keys();
         while (keys.hasMoreElements()) {
             String key = (String) keys.nextElement();

Modified: ace/trunk/org.apache.ace.log/src/org/apache/ace/log/server/task/Activator.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.log/src/org/apache/ace/log/server/task/Activator.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.log/src/org/apache/ace/log/server/task/Activator.java (original)
+++ ace/trunk/org.apache.ace.log/src/org/apache/ace/log/server/task/Activator.java Fri Jan 29 08:59:31 2016
@@ -43,7 +43,7 @@ public class Activator extends Dependenc
     private static final String KEY_MODE_LOWEST_IDS = "mode-lowest-ids";
     private static final String KEY_TARGETID = "tid";
     
-    private final Map<String, Component> m_instances = new HashMap<String, Component>();
+    private final Map<String, Component> m_instances = new HashMap<>();
     private volatile DependencyManager m_manager;
 
     @Override

Modified: ace/trunk/org.apache.ace.log/src/org/apache/ace/log/server/task/LogSyncTask.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.log/src/org/apache/ace/log/server/task/LogSyncTask.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.log/src/org/apache/ace/log/server/task/LogSyncTask.java (original)
+++ ace/trunk/org.apache.ace.log/src/org/apache/ace/log/server/task/LogSyncTask.java Fri Jan 29 08:59:31 2016
@@ -177,7 +177,7 @@ public class LogSyncTask implements Runn
          * For each local descriptor, we try to find a matching remote one. If so, we will synchronize all events that
          * the remote does not have. If we do not find a matching one at all, we send the complete local log.
          */
-        List<Descriptor> result = new ArrayList<Descriptor>();
+        List<Descriptor> result = new ArrayList<>();
         for (Descriptor s : source) {
             Descriptor diffs = s;
             for (Descriptor d : destination) {
@@ -301,7 +301,7 @@ public class LogSyncTask implements Runn
     }
 
     protected List<Descriptor> getRanges(URL host) throws IOException {
-        List<Descriptor> result = new ArrayList<Descriptor>();
+        List<Descriptor> result = new ArrayList<>();
 
         URLConnection queryConnection = null;
         InputStream queryInput = null;
@@ -332,7 +332,7 @@ public class LogSyncTask implements Runn
 
     protected void readLogs(BufferedReader reader) {
         try {
-            List<Event> events = new ArrayList<Event>();
+            List<Event> events = new ArrayList<>();
 
             String eventString = null;
             while ((eventString = reader.readLine()) != null) {

Modified: ace/trunk/org.apache.ace.log/src/org/apache/ace/log/target/LogConfigurator.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.log/src/org/apache/ace/log/target/LogConfigurator.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.log/src/org/apache/ace/log/target/LogConfigurator.java (original)
+++ ace/trunk/org.apache.ace.log/src/org/apache/ace/log/target/LogConfigurator.java Fri Jan 29 08:59:31 2016
@@ -36,7 +36,7 @@ public class LogConfigurator implements
     private static final String LOG_NAME = "name";
 
     private DependencyManager m_manager;
-    private final Map<String, Component> m_logInstances = new HashMap<String, Component>();
+    private final Map<String, Component> m_logInstances = new HashMap<>();
     private volatile LogService m_log;
     
     public String getName() {

Modified: ace/trunk/org.apache.ace.log/src/org/apache/ace/log/target/LogSyncConfigurator.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.log/src/org/apache/ace/log/target/LogSyncConfigurator.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.log/src/org/apache/ace/log/target/LogSyncConfigurator.java (original)
+++ ace/trunk/org.apache.ace.log/src/org/apache/ace/log/target/LogSyncConfigurator.java Fri Jan 29 08:59:31 2016
@@ -41,7 +41,7 @@ public class LogSyncConfigurator impleme
     private static final String LOG_NAME = "name";
 
     private DependencyManager m_manager;
-    private final Map<String, Component> m_syncInstances = new HashMap<String, Component>();
+    private final Map<String, Component> m_syncInstances = new HashMap<>();
     private volatile LogService m_log;
     
     public String getName() {
@@ -65,7 +65,7 @@ public class LogSyncConfigurator impleme
         Component service = (Component) m_syncInstances.get(pid);
         if (service == null) {
             // publish log sync task service
-            Dictionary<String, Object> properties = new Hashtable<String, Object>();
+            Dictionary<String, Object> properties = new Hashtable<>();
             String filterString;
             String filterForDiscovery;
             String filterForIdentification;

Modified: ace/trunk/org.apache.ace.log/src/org/apache/ace/log/target/store/impl/Activator.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.log/src/org/apache/ace/log/target/store/impl/Activator.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.log/src/org/apache/ace/log/target/store/impl/Activator.java (original)
+++ ace/trunk/org.apache.ace.log/src/org/apache/ace/log/target/store/impl/Activator.java Fri Jan 29 08:59:31 2016
@@ -41,7 +41,7 @@ public class Activator extends Dependenc
 
     private DependencyManager m_manager;
     private BundleContext m_context;
-    private final Map<String, Component> m_instances = new HashMap<String, Component>();
+    private final Map<String, Component> m_instances = new HashMap<>();
     private volatile LogService m_log;
 
     public void init(BundleContext context, DependencyManager manager) throws Exception {

Modified: ace/trunk/org.apache.ace.log/src/org/apache/ace/log/target/store/impl/LogStoreImpl.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.log/src/org/apache/ace/log/target/store/impl/LogStoreImpl.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.log/src/org/apache/ace/log/target/store/impl/LogStoreImpl.java (original)
+++ ace/trunk/org.apache.ace.log/src/org/apache/ace/log/target/store/impl/LogStoreImpl.java Fri Jan 29 08:59:31 2016
@@ -152,7 +152,7 @@ public class LogStoreImpl implements Log
     public synchronized List get(long logID, long from, long to)
             throws IOException {
         Store store = getLog(logID);
-        List<Event> result = new ArrayList<Event>();
+        List<Event> result = new ArrayList<>();
         try {
             if (store.getCurrent() > from) {
                 store.reset();
@@ -256,7 +256,7 @@ public class LogStoreImpl implements Log
      */
     public synchronized Event put(int type, Dictionary dict) throws IOException {
         try {
-            Map<String, String> props = new HashMap<String, String>();
+            Map<String, String> props = new HashMap<>();
             Enumeration keys = dict.keys();
             while (keys.hasMoreElements()) {
                 String key = (String) keys.nextElement();

Modified: ace/trunk/org.apache.ace.log/test/org/apache/ace/log/LogEventTest.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.log/test/org/apache/ace/log/LogEventTest.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.log/test/org/apache/ace/log/LogEventTest.java (original)
+++ ace/trunk/org.apache.ace.log/test/org/apache/ace/log/LogEventTest.java Fri Jan 29 08:59:31 2016
@@ -32,7 +32,7 @@ public class LogEventTest {
     public void serializeLogEvent() {
         Event e = new Event("gwid", 1, 2, 3, AuditEvent.FRAMEWORK_STARTED);
         assert e.toRepresentation().equals("gwid,1,2,3," + AuditEvent.FRAMEWORK_STARTED);
-        Map<String, String> p = new HashMap<String, String>();
+        Map<String, String> p = new HashMap<>();
         p.put(AuditEvent.KEY_ID, "my first value");
         e = new Event("gwid", 1, 2, 3, AuditEvent.BUNDLE_INSTALLED, p);
         assert e.toRepresentation().equals("gwid,1,2,3," + AuditEvent.BUNDLE_INSTALLED + "," + AuditEvent.KEY_ID + ",my first value");

Modified: ace/trunk/org.apache.ace.log/test/org/apache/ace/log/server/servlet/LogServletTest.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.log/test/org/apache/ace/log/server/servlet/LogServletTest.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.log/test/org/apache/ace/log/server/servlet/LogServletTest.java (original)
+++ ace/trunk/org.apache.ace.log/test/org/apache/ace/log/server/servlet/LogServletTest.java Fri Jan 29 08:59:31 2016
@@ -190,10 +190,10 @@ public class LogServletTest {
     }
 
     private class MockLogStore implements LogStore {
-        public List<Event> m_events = new ArrayList<Event>();
+        public List<Event> m_events = new ArrayList<>();
 
         public List<Event> get(Descriptor range) {
-            List<Event> events = new ArrayList<Event>();
+            List<Event> events = new ArrayList<>();
             if (range.getRangeSet().contains(1)) {
                 events.add(m_event1);
             }
@@ -203,12 +203,12 @@ public class LogServletTest {
             return events;
         }
         public List<Descriptor> getDescriptors(String targetID) {
-        	List<Descriptor> ranges = new ArrayList<Descriptor>();
+        	List<Descriptor> ranges = new ArrayList<>();
             ranges.add(m_range);
             return ranges;
         }
         public List<Descriptor> getDescriptors() {
-            List<Descriptor> ranges = new ArrayList<Descriptor>();
+            List<Descriptor> ranges = new ArrayList<>();
             ranges.add(m_range);
             return ranges;
         }

Modified: ace/trunk/org.apache.ace.log/test/org/apache/ace/log/server/store/impl/LogStoreImplConcurrencyTest.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.log/test/org/apache/ace/log/server/store/impl/LogStoreImplConcurrencyTest.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.log/test/org/apache/ace/log/server/store/impl/LogStoreImplConcurrencyTest.java (original)
+++ ace/trunk/org.apache.ace.log/test/org/apache/ace/log/server/store/impl/LogStoreImplConcurrencyTest.java Fri Jan 29 08:59:31 2016
@@ -59,7 +59,7 @@ public class LogStoreImplConcurrencyTest
         private final CountDownLatch m_start;
         private final CountDownLatch m_stop;
         private final LogStoreImpl m_store;
-        private final ConcurrentMap<Long, Boolean> m_seen = new ConcurrentHashMap<Long, Boolean>();
+        private final ConcurrentMap<Long, Boolean> m_seen = new ConcurrentHashMap<>();
         private final int m_count;
 
         public Reader(LogStoreImpl store, CountDownLatch start, CountDownLatch stop, int count) {
@@ -121,7 +121,7 @@ public class LogStoreImplConcurrencyTest
         private final CountDownLatch m_start;
         private final CountDownLatch m_stop;
         private final LogStoreImpl m_store;
-        private final ConcurrentMap<Long, Event> m_written = new ConcurrentHashMap<Long, Event>();
+        private final ConcurrentMap<Long, Event> m_written = new ConcurrentHashMap<>();
         private final int m_count;
         private final int m_initValue;
         private final int m_stepSize;
@@ -373,7 +373,7 @@ public class LogStoreImplConcurrencyTest
         m_baseDir.mkdirs();
         
         m_executor = Executors.newCachedThreadPool();
-        m_completionService = new ExecutorCompletionService<Boolean>(m_executor);
+        m_completionService = new ExecutorCompletionService<>(m_executor);
     }
     
     @AfterMethod(alwaysRun = true)

Modified: ace/trunk/org.apache.ace.log/test/org/apache/ace/log/server/store/impl/ServerLogStoreTester.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.log/test/org/apache/ace/log/server/store/impl/ServerLogStoreTester.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.log/test/org/apache/ace/log/server/store/impl/ServerLogStoreTester.java (original)
+++ ace/trunk/org.apache.ace.log/test/org/apache/ace/log/server/store/impl/ServerLogStoreTester.java Fri Jan 29 08:59:31 2016
@@ -68,12 +68,12 @@ public class ServerLogStoreTester {
     @SuppressWarnings("serial")
     @Test(groups = { UNIT })
     public void testLog() throws IOException {
-        Map<String, String> props = new HashMap<String, String>();
+        Map<String, String> props = new HashMap<>();
         props.put("test", "bar");
 
         List<Descriptor> ranges = m_logStore.getDescriptors();
         assert ranges.isEmpty() : "New store should have no ranges.";
-        List<Event> events = new ArrayList<Event>();
+        List<Event> events = new ArrayList<>();
         for (String target : new String[] { "g1", "g2", "g3" }) {
             for (long log : new long[] { 1, 2, 3, 5 }) {
                 for (long id : new long[] { 1, 2, 3, 20 }) {
@@ -85,11 +85,11 @@ public class ServerLogStoreTester {
         assert m_logStore.getDescriptors().size() == 3 * 4 : "Incorrect amount of ranges returned from store";
         List<Event> stored = getStoredEvents();
 
-        Set<String> in = new HashSet<String>();
+        Set<String> in = new HashSet<>();
         for (Event event : events) {
             in.add(event.toRepresentation());
         }
-        Set<String> out = new HashSet<String>();
+        Set<String> out = new HashSet<>();
         for (Event event : stored) {
             out.add(event.toRepresentation());
         }
@@ -99,13 +99,13 @@ public class ServerLogStoreTester {
     @SuppressWarnings("serial")
     @Test(groups = { UNIT })
     public void testLogOutOfOrder() throws IOException {
-        Map<String, String> props = new HashMap<String, String>();
+        Map<String, String> props = new HashMap<>();
         props.put("test", "bar");
 
         List<Descriptor> ranges = m_logStore.getDescriptors();
         assert ranges.isEmpty() : "New store should have no ranges.";
 
-        List<Event> events = new ArrayList<Event>();
+        List<Event> events = new ArrayList<>();
         events.add(new Event("t1", 1, 2, 2, AuditEvent.FRAMEWORK_STARTED, props));
         events.add(new Event("t1", 1, 3, 3, AuditEvent.FRAMEWORK_STARTED, props));
         events.add(new Event("t1", 1, 1, 1, AuditEvent.FRAMEWORK_STARTED, props));
@@ -113,7 +113,7 @@ public class ServerLogStoreTester {
         assert m_logStore.getDescriptors().size() == 1 : "Incorrect amount of ranges returned from store";
         List<Event> stored = getStoredEvents();
 
-        Set<String> out = new HashSet<String>();
+        Set<String> out = new HashSet<>();
         for (Event event : stored) {
             out.add(event.toRepresentation());
         }
@@ -123,13 +123,13 @@ public class ServerLogStoreTester {
     @SuppressWarnings("serial")
     @Test(groups = { UNIT })
     public void testLogOutOfOrderOneByOne() throws IOException {
-        Map<String, String> props = new HashMap<String, String>();
+        Map<String, String> props = new HashMap<>();
         props.put("test", "bar");
 
         List<Descriptor> ranges = m_logStore.getDescriptors();
         assert ranges.isEmpty() : "New store should have no ranges.";
 
-        List<Event> events = new ArrayList<Event>();
+        List<Event> events = new ArrayList<>();
         events.add(new Event("t1", 1, 2, 2, AuditEvent.FRAMEWORK_STARTED, props));
         m_logStore.put(events);
         events.clear();
@@ -141,7 +141,7 @@ public class ServerLogStoreTester {
         assert m_logStore.getDescriptors().size() == 1 : "Incorrect amount of ranges returned from store";
         List<Event> stored = getStoredEvents();
 
-        Set<String> out = new HashSet<String>();
+        Set<String> out = new HashSet<>();
         for (Event event : stored) {
             out.add(event.toRepresentation());
         }
@@ -152,12 +152,12 @@ public class ServerLogStoreTester {
     @SuppressWarnings("serial")
     @Test(groups = { UNIT })
     public void testLogLowestID() throws IOException {
-        Map<String, String> props = new HashMap<String, String>();
+        Map<String, String> props = new HashMap<>();
         props.put("test", "bar");
 
         List<Descriptor> ranges = m_logStore.getDescriptors();
         assert ranges.isEmpty() : "New store should have no ranges.";
-        List<Event> events = new ArrayList<Event>();
+        List<Event> events = new ArrayList<>();
 
         assert 0 == m_logStore.getLowestID("target", 1) : "Lowest ID should be 0 by default, not: " + m_logStore.getLowestID("target", 1);
         m_logStore.setLowestID("target", 1, 10);
@@ -245,7 +245,7 @@ public class ServerLogStoreTester {
     }
     
     private List<Event> getStoredEvents() throws IOException {
-		List<Event> stored = new ArrayList<Event>();
+		List<Event> stored = new ArrayList<>();
         for (Descriptor range : m_logStore.getDescriptors()) {
             System.out.println("TID: " + range.getTargetID());
             for (Descriptor range2 : m_logStore.getDescriptors(range.getTargetID())) {
@@ -289,7 +289,7 @@ public class ServerLogStoreTester {
     public void testLogWithSpecialCharacters() throws IOException {
         String targetID = "myta\0rget";
         Event event = new Event(targetID, 1, 1, System.currentTimeMillis(), AuditEvent.FRAMEWORK_STARTED);
-        List<Event> events = new ArrayList<Event>();
+        List<Event> events = new ArrayList<>();
         events.add(event);
         m_logStore.put(events);
         assert m_logStore.getDescriptors().size() == 1 : "Incorrect amount of ranges returned from store: expected 1, found " + m_logStore.getDescriptors().size();
@@ -303,7 +303,7 @@ public class ServerLogStoreTester {
         settings.put(MAXIMUM_NUMBER_OF_EVENTS, "1");
         m_logStore.updated(settings);
         
-        List<Event> events = new ArrayList<Event>();
+        List<Event> events = new ArrayList<>();
         for (String target : new String[] { "target"}) {
             for (long log : new long[] { 1 }) {
                 for (long id : new long[] { 1, 2 }) {
@@ -332,7 +332,7 @@ public class ServerLogStoreTester {
         settings.put(MAXIMUM_NUMBER_OF_EVENTS, "1");
         m_logStore.updated(settings);
         
-        List<Event> events = new ArrayList<Event>();
+        List<Event> events = new ArrayList<>();
         for (String target : new String[] { "target"}) {
             for (long log : new long[] { 1,2 }) {
                 for (long id : new long[] { 1, 2 }) {
@@ -356,7 +356,7 @@ public class ServerLogStoreTester {
     @SuppressWarnings({ "rawtypes", "unchecked" })
     @Test(groups = { TestUtils.UNIT })
     public void testClean() throws Exception {
-        List<Event> events = new ArrayList<Event>();
+        List<Event> events = new ArrayList<>();
         for (String target : new String[] { "target"}) {
             for (long log : new long[] { 1, 2 }) {
                 for (long id : new long[] { 1, 2, 3, 4 }) {
@@ -389,7 +389,7 @@ public class ServerLogStoreTester {
     @Test(groups = { UNIT })
     public void testConcurrentLog() throws IOException, InterruptedException {
         ExecutorService es = Executors.newFixedThreadPool(8);
-        final Map<String, String> props = new HashMap<String, String>();
+        final Map<String, String> props = new HashMap<>();
         props.put("test", "bar");
 
         List<Descriptor> ranges = m_logStore.getDescriptors();
@@ -403,7 +403,7 @@ public class ServerLogStoreTester {
                     es.execute(new Runnable() {
                         @Override
                         public void run() {
-                            List<Event> list = new ArrayList<Event>();
+                            List<Event> list = new ArrayList<>();
                             list.add(new Event(t, l, i, System.currentTimeMillis(), AuditEvent.FRAMEWORK_STARTED, props));
                             try {
                                 m_logStore.put(list);
@@ -424,7 +424,7 @@ public class ServerLogStoreTester {
         assert size == 3 * 4 : "Incorrect amount of ranges returned from store: " + size;
         List<Event> stored = getStoredEvents();
 
-        Set<String> out = new HashSet<String>();
+        Set<String> out = new HashSet<>();
         for (Event event : stored) {
             out.add(event.toRepresentation());
         }

Modified: ace/trunk/org.apache.ace.log/test/org/apache/ace/log/server/task/LogTaskTest.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.log/test/org/apache/ace/log/server/task/LogTaskTest.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.log/test/org/apache/ace/log/server/task/LogTaskTest.java (original)
+++ ace/trunk/org.apache.ace.log/test/org/apache/ace/log/server/task/LogTaskTest.java Fri Jan 29 08:59:31 2016
@@ -36,7 +36,7 @@ import org.testng.annotations.Test;
 public class LogTaskTest {
 
     private static class MockLogSyncTask extends LogSyncTask {
-        public List<Descriptor> m_calledWith = new ArrayList<Descriptor>();
+        public List<Descriptor> m_calledWith = new ArrayList<>();
 
         public MockLogSyncTask(String endpoint, String name) {
             super(endpoint, name, LogSyncTask.Mode.PUSH, LogSyncTask.Mode.NONE);
@@ -62,8 +62,8 @@ public class LogTaskTest {
     @Test(groups = { UNIT })
     public void testDeltaComputation() throws IOException {
         // TODO: Test the new LogDescriptor.
-        List<Descriptor> src = new ArrayList<Descriptor>();
-        List<Descriptor> dest = new ArrayList<Descriptor>();
+        List<Descriptor> src = new ArrayList<>();
+        List<Descriptor> dest = new ArrayList<>();
 
         String targetID = "targetID";
         MockLogSyncTask task = new MockLogSyncTask("mocklog", "mocklog");

Modified: ace/trunk/org.apache.ace.log/test/org/apache/ace/log/target/store/impl/GatewayLogStoreTest.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.log/test/org/apache/ace/log/target/store/impl/GatewayLogStoreTest.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.log/test/org/apache/ace/log/target/store/impl/GatewayLogStoreTest.java (original)
+++ ace/trunk/org.apache.ace.log/test/org/apache/ace/log/target/store/impl/GatewayLogStoreTest.java Fri Jan 29 08:59:31 2016
@@ -68,7 +68,7 @@ public class GatewayLogStoreTest {
     public void testLog() throws IOException {
         long[] ids = m_logStore.getLogIDs();
         assert ids.length == 1 : "New store should have only one id";
-        List<String> events = new ArrayList<String>();
+        List<String> events = new ArrayList<>();
         events.add(m_logStore.put(AuditEvent.FRAMEWORK_STARTED, new Properties() {{put("test", "test");}}).toRepresentation());
         events.add(m_logStore.put(AuditEvent.BUNDLE_INSTALLED, new Properties() {{put("test", "test");}}).toRepresentation());
         events.add(m_logStore.put(AuditEvent.DEPLOYMENTADMIN_COMPLETE, new Properties() {{put("test", "test");}}).toRepresentation());
@@ -76,12 +76,12 @@ public class GatewayLogStoreTest {
         assert ids.length == 1 : "Error free store should have only one id";
         long highest = m_logStore.getHighestID(ids[0]);
         assert  highest == 3 : "Store with 3 entries should have 3 as highest id but was: " + highest;
-        List<String> result = new ArrayList<String>();
+        List<String> result = new ArrayList<>();
         for (Event event : (List<Event>) m_logStore.get(ids[0])) {
             result.add(event.toRepresentation());
         }
         assert result.equals(events) : "Events " + events + " should equal full log " + result;
-        result = new ArrayList<String>();
+        result = new ArrayList<>();
         for (Event event : (List<Event>) m_logStore.get(ids[0], 1, highest)) {
             result.add(event.toRepresentation());
         }

Modified: ace/trunk/org.apache.ace.log/test/org/apache/ace/log/target/task/LogSyncTaskTest.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.log/test/org/apache/ace/log/target/task/LogSyncTaskTest.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.log/test/org/apache/ace/log/target/task/LogSyncTaskTest.java (original)
+++ ace/trunk/org.apache.ace.log/test/org/apache/ace/log/target/task/LogSyncTaskTest.java Fri Jan 29 08:59:31 2016
@@ -81,7 +81,7 @@ public class LogSyncTaskTest {
     public synchronized void synchronizeLog() throws Exception {
         final Descriptor range = new Descriptor(TARGET_ID, 1, new SortedRangeSet(new long[] {0}));
         final Event event = new Event(TARGET_ID, 1, 1, 1, 1);
-        final List<Event> events = new ArrayList<Event>();
+        final List<Event> events = new ArrayList<>();
         events.add(event);
 
         InputStream input = new InputStream() {

Modified: ace/trunk/org.apache.ace.obr/src/org/apache/ace/obr/storage/file/BundleFileStore.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.obr/src/org/apache/ace/obr/storage/file/BundleFileStore.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.obr/src/org/apache/ace/obr/storage/file/BundleFileStore.java (original)
+++ ace/trunk/org.apache.ace.obr/src/org/apache/ace/obr/storage/file/BundleFileStore.java Fri Jan 29 08:59:31 2016
@@ -246,7 +246,7 @@ public class BundleFileStore implements
             return "" + (System.currentTimeMillis() / 600000);
         }
 
-        Stack<File> dirs = new Stack<File>();
+        Stack<File> dirs = new Stack<>();
         dirs.push(dir);
         while (!dirs.isEmpty()) {
             File pwd = dirs.pop();
@@ -334,7 +334,7 @@ public class BundleFileStore implements
      * @return an array of parts
      */
     public static String[] split(String name) {
-        List<String> result = new ArrayList<String>();
+        List<String> result = new ArrayList<>();
         int startPos = 0;
         for (int i = 0; i < (name.length() - 1); i++) {
             if (name.charAt(i) == '.') {

Modified: ace/trunk/org.apache.ace.obr/src/org/osgi/impl/bundle/bindex/Index.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.obr/src/org/osgi/impl/bundle/bindex/Index.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.obr/src/org/osgi/impl/bundle/bindex/Index.java (original)
+++ ace/trunk/org.apache.ace.obr/src/org/osgi/impl/bundle/bindex/Index.java Fri Jan 29 08:59:31 2016
@@ -96,7 +96,7 @@ public class Index
      * @throws Exception
      */
     public static void main(String args[]) throws Exception {
-        Set<ResourceImpl> resources = new HashSet<ResourceImpl>();
+        Set<ResourceImpl> resources = new HashSet<>();
         root = rootFile.toURI().toURL().toString();
         repository = new RepositoryImpl(rootFile.toURI().toURL());
 
@@ -135,7 +135,7 @@ public class Index
             }
         }
 
-        List<ResourceImpl> sorted = new ArrayList<ResourceImpl>(resources);
+        List<ResourceImpl> sorted = new ArrayList<>(resources);
         Collections.sort(sorted, new Comparator<ResourceImpl>() {
             public int compare(ResourceImpl r1, ResourceImpl r2) {
                 String s1 = getName(r1);

Modified: ace/trunk/org.apache.ace.obr/src/org/osgi/impl/bundle/obr/resource/BundleInfo.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.obr/src/org/osgi/impl/bundle/obr/resource/BundleInfo.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.obr/src/org/osgi/impl/bundle/obr/resource/BundleInfo.java (original)
+++ ace/trunk/org.apache.ace.obr/src/org/osgi/impl/bundle/obr/resource/BundleInfo.java Fri Jan 29 08:59:31 2016
@@ -325,7 +325,7 @@ public class BundleInfo {
 	}
 
 	void doImports(ResourceImpl resource) {
-		List<RequirementImpl> requirements = new ArrayList<RequirementImpl>();
+		List<RequirementImpl> requirements = new ArrayList<>();
 		List packages = manifest.getImports();
 		if (packages == null)
 			return;
@@ -398,7 +398,7 @@ public class BundleInfo {
 
 	Set doImportPackageAttributes(RequirementImpl req, StringBuffer filter,
 			Map attributes) {
-		HashSet<String> set = new HashSet<String>();
+		HashSet<String> set = new HashSet<>();
 
 		if (attributes != null)
 			for (Iterator i = attributes.keySet().iterator(); i.hasNext();) {
@@ -449,7 +449,7 @@ public class BundleInfo {
 	}
 
 	void doExports(ResourceImpl resource) {
-		List<CapabilityImpl> capabilities = new ArrayList<CapabilityImpl>();
+		List<CapabilityImpl> capabilities = new ArrayList<>();
 		List packages = manifest.getExports();
 		if (packages != null) {
 			for (Iterator i = packages.iterator(); i.hasNext();) {

Modified: ace/trunk/org.apache.ace.range.api/src/org/apache/ace/range/SortedRangeSet.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.range.api/src/org/apache/ace/range/SortedRangeSet.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.range.api/src/org/apache/ace/range/SortedRangeSet.java (original)
+++ ace/trunk/org.apache.ace.range.api/src/org/apache/ace/range/SortedRangeSet.java Fri Jan 29 08:59:31 2016
@@ -42,7 +42,7 @@ public class SortedRangeSet {
         }
     };
 
-    private List<Range> m_ranges = new ArrayList<Range>();
+    private List<Range> m_ranges = new ArrayList<>();
 
     /**
      * Creates a new instance from a string representation.

Modified: ace/trunk/org.apache.ace.repository/src/org/apache/ace/repository/impl/RepositoryFactory.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.repository/src/org/apache/ace/repository/impl/RepositoryFactory.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.repository/src/org/apache/ace/repository/impl/RepositoryFactory.java (original)
+++ ace/trunk/org.apache.ace.repository/src/org/apache/ace/repository/impl/RepositoryFactory.java Fri Jan 29 08:59:31 2016
@@ -92,7 +92,7 @@ public class RepositoryFactory implement
         }
     }
 
-    private final ConcurrentMap<String, Component> m_instances = new ConcurrentHashMap<String, Component>();
+    private final ConcurrentMap<String, Component> m_instances = new ConcurrentHashMap<>();
     private final ConcurrentMap<Entry, String> m_index = new ConcurrentHashMap<>();
     private final DependencyManager m_manager;
 

Modified: ace/trunk/org.apache.ace.repository/src/org/apache/ace/repository/task/RepositoryReplicationTask.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.repository/src/org/apache/ace/repository/task/RepositoryReplicationTask.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.repository/src/org/apache/ace/repository/task/RepositoryReplicationTask.java (original)
+++ ace/trunk/org.apache.ace.repository/src/org/apache/ace/repository/task/RepositoryReplicationTask.java Fri Jan 29 08:59:31 2016
@@ -46,7 +46,7 @@ import org.osgi.service.log.LogService;
  * stuff out.
  */
 public class RepositoryReplicationTask implements Runnable {
-    private final ConcurrentMap<ServiceReference, RepositoryReplication> m_replicators = new ConcurrentHashMap<ServiceReference, RepositoryReplication>();
+    private final ConcurrentMap<ServiceReference, RepositoryReplication> m_replicators = new ConcurrentHashMap<>();
 
     private volatile Discovery m_discovery;
     private volatile ConnectionFactory m_connectionFactory;
@@ -75,7 +75,7 @@ public class RepositoryReplicationTask i
      */
     public void run() {
         // Take a snapshot of the current available replicators...
-        Map<ServiceReference, RepositoryReplication> replicators = new HashMap<ServiceReference, RepositoryReplication>(m_replicators);
+        Map<ServiceReference, RepositoryReplication> replicators = new HashMap<>(m_replicators);
 
         // The URL to the server to replicate...
         URL master = m_discovery.discover();

Modified: ace/trunk/org.apache.ace.resourceprocessor.useradmin/src/org/apache/ace/resourceprocessor/useradmin/impl/Processor.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.resourceprocessor.useradmin/src/org/apache/ace/resourceprocessor/useradmin/impl/Processor.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.resourceprocessor.useradmin/src/org/apache/ace/resourceprocessor/useradmin/impl/Processor.java (original)
+++ ace/trunk/org.apache.ace.resourceprocessor.useradmin/src/org/apache/ace/resourceprocessor/useradmin/impl/Processor.java Fri Jan 29 08:59:31 2016
@@ -54,8 +54,8 @@ public class Processor implements Resour
             throw new IllegalArgumentException("This resource processor is currently processing another deployment session, installing deploymentpackage" + m_session.getTargetDeploymentPackage().getName());
         }
         m_session = session;
-        m_toInstall = new ArrayList<String>();
-        m_toRemove = new ArrayList<String>();
+        m_toInstall = new ArrayList<>();
+        m_toRemove = new ArrayList<>();
 
         String fromSource = session.getSourceDeploymentPackage().getName();
         String fromTarget = session.getTargetDeploymentPackage().getName();

Modified: ace/trunk/org.apache.ace.resourceprocessor.useradmin/src/org/apache/ace/resourceprocessor/useradmin/impl/ResourceStore.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.resourceprocessor.useradmin/src/org/apache/ace/resourceprocessor/useradmin/impl/ResourceStore.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.resourceprocessor.useradmin/src/org/apache/ace/resourceprocessor/useradmin/impl/ResourceStore.java (original)
+++ ace/trunk/org.apache.ace.resourceprocessor.useradmin/src/org/apache/ace/resourceprocessor/useradmin/impl/ResourceStore.java Fri Jan 29 08:59:31 2016
@@ -50,7 +50,7 @@ abstract class ResourceStore
 
         File baseDir = m_context.getDataFile(TEMP_DIR);
 
-        m_resources = new HashMap<String, String>();
+        m_resources = new HashMap<>();
 
         // Fill our resources overview with the data that is available on disk.
         File[] deploymentPackageList = baseDir.listFiles();
@@ -168,7 +168,7 @@ abstract class ResourceStore
      */
     public List<String> getResources(String deploymentPackageName) {
         synchronized (m_resources) {
-            List<String> result = new ArrayList<String>();
+            List<String> result = new ArrayList<>();
             for (Map.Entry<String, String> entry : m_resources.entrySet()) {
                 if (entry.getValue().equals(deploymentPackageName)) {
                     result.add(entry.getKey());

Modified: ace/trunk/org.apache.ace.resourceprocessor.useradmin/src/org/apache/ace/resourceprocessor/useradmin/impl/UserAdminStore.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.resourceprocessor.useradmin/src/org/apache/ace/resourceprocessor/useradmin/impl/UserAdminStore.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.resourceprocessor.useradmin/src/org/apache/ace/resourceprocessor/useradmin/impl/UserAdminStore.java (original)
+++ ace/trunk/org.apache.ace.resourceprocessor.useradmin/src/org/apache/ace/resourceprocessor/useradmin/impl/UserAdminStore.java Fri Jan 29 08:59:31 2016
@@ -53,9 +53,9 @@ public class UserAdminStore extends Reso
     private class ProcessRole {
         private final int m_type;
         private final String m_name;
-        private final Map<String, Object> m_properties = new HashMap<String, Object>();
-        private final Map<String, Object> m_credentials = new HashMap<String, Object>();
-        private final List<String> m_memberOf = new ArrayList<String>();
+        private final Map<String, Object> m_properties = new HashMap<>();
+        private final Map<String, Object> m_credentials = new HashMap<>();
+        private final List<String> m_memberOf = new ArrayList<>();
 
         ProcessRole(String name, int type) {
             m_name = name;
@@ -90,8 +90,8 @@ public class UserAdminStore extends Reso
     private volatile LogService m_log;
     private volatile List<String> m_installedUsers;
 
-    private List<ProcessRole> m_toInstall = new ArrayList<ProcessRole>();
-    private List<ProcessRole> m_toRemove = new ArrayList<ProcessRole>();
+    private List<ProcessRole> m_toInstall = new ArrayList<>();
+    private List<ProcessRole> m_toRemove = new ArrayList<>();
     private boolean m_clear;
 
 
@@ -101,7 +101,7 @@ public class UserAdminStore extends Reso
 
     @Override
     public void begin() {
-        m_installedUsers = new ArrayList<String>();
+        m_installedUsers = new ArrayList<>();
     }
 
     @Override
@@ -257,7 +257,7 @@ public class UserAdminStore extends Reso
      * @return A list of ProcessRoles.
      */
     private List<ProcessRole> getRoles(Document doc) {
-        List<ProcessRole> result = new ArrayList<ProcessRole>();
+        List<ProcessRole> result = new ArrayList<>();
         for (Node node = doc.getFirstChild().getFirstChild(); node != null; node = node.getNextSibling()) {
             if (!node.getNodeName().equals("#text")) {
                 result.add(getRole(node));
@@ -279,7 +279,7 @@ public class UserAdminStore extends Reso
      * Helper that finds all groups this role is a member of.
      */
     private Group[] memberOf(Role r) {
-        List<Group> result = new ArrayList<Group>();
+        List<Group> result = new ArrayList<>();
         Role[] roles = null;
         try {
             roles = m_userAdmin.getRoles(null);

Modified: ace/trunk/org.apache.ace.scheduler/src/org/apache/ace/scheduler/Scheduler.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.scheduler/src/org/apache/ace/scheduler/Scheduler.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.scheduler/src/org/apache/ace/scheduler/Scheduler.java (original)
+++ ace/trunk/org.apache.ace.scheduler/src/org/apache/ace/scheduler/Scheduler.java Fri Jan 29 08:59:31 2016
@@ -39,7 +39,7 @@ import org.osgi.service.log.LogService;
  * for it.
  */
 public class Scheduler implements ManagedService {
-    protected final Map<String, SchedulerTask> m_tasks = new HashMap<String, SchedulerTask>();
+    protected final Map<String, SchedulerTask> m_tasks = new HashMap<>();
     private volatile LogService m_log;
 
     /**

Modified: ace/trunk/org.apache.ace.tageditor/src/org/apache/ace/tageditor/ACETagEditorExtension.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.tageditor/src/org/apache/ace/tageditor/ACETagEditorExtension.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.tageditor/src/org/apache/ace/tageditor/ACETagEditorExtension.java (original)
+++ ace/trunk/org.apache.ace.tageditor/src/org/apache/ace/tageditor/ACETagEditorExtension.java Fri Jan 29 08:59:31 2016
@@ -91,7 +91,7 @@ public class ACETagEditorExtension imple
         table.setColumnExpandRatio("Value", 1.0f);
         table.setColumnExpandRatio("Remove", 0.2f);
 
-        final Map<Object, TagTableEntry> idToKey = new HashMap<Object, TagTableEntry>();
+        final Map<Object, TagTableEntry> idToKey = new HashMap<>();
         Enumeration<String> keys = object.getTagKeys();
         while (keys.hasMoreElements()) {
             String keyString = keys.nextElement();

Modified: ace/trunk/org.apache.ace.test/src/org/apache/ace/it/IntegrationTestBase.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.test/src/org/apache/ace/it/IntegrationTestBase.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.test/src/org/apache/ace/it/IntegrationTestBase.java (original)
+++ ace/trunk/org.apache.ace.test/src/org/apache/ace/it/IntegrationTestBase.java Fri Jan 29 08:59:31 2016
@@ -66,7 +66,7 @@ import junit.framework.TestCase;
  */
 public class IntegrationTestBase extends TestCase {
     private static class ComponentCounter implements ComponentStateListener {
-        private final List<Component> m_components = new ArrayList<Component>();
+        private final List<Component> m_components = new ArrayList<>();
         private final CountDownLatch m_latch;
 
         public ComponentCounter(Component[] components) {
@@ -107,8 +107,8 @@ public class IntegrationTestBase extends
      */
     private static final int SERVICE_TIMEOUT = 15;
 
-    private final Map<String, ServiceTracker> m_trackedServices = new HashMap<String, ServiceTracker>();
-    private final List<Configuration> m_trackedConfigurations = new ArrayList<Configuration>();
+    private final Map<String, ServiceTracker<?, ?>> m_trackedServices = new HashMap<>();
+    private final List<Configuration> m_trackedConfigurations = new ArrayList<>();
 
     private boolean m_cleanConfigurations = true;
     private boolean m_closeServiceTrackers = true;
@@ -429,7 +429,7 @@ public class IntegrationTestBase extends
      *             in case accessing the requested URL failed.
      */
     protected List<String> getResponse(URL requestURL) throws IOException {
-        List<String> result = new ArrayList<String>();
+        List<String> result = new ArrayList<>();
         InputStream in = null;
         try {
             in = requestURL.openConnection().getInputStream();
@@ -498,9 +498,9 @@ public class IntegrationTestBase extends
             filterString = String.format("(%s=%s)", Constants.OBJECTCLASS, serviceClass.getName());
         }
 
-        ServiceTracker serviceTracker = m_trackedServices.get(filterString);
+        ServiceTracker<?, ?> serviceTracker = m_trackedServices.get(filterString);
         if (serviceTracker == null) {
-            serviceTracker = new ServiceTracker(m_bundleContext, FrameworkUtil.createFilter(filterString), null);
+            serviceTracker = new ServiceTracker<>(m_bundleContext, FrameworkUtil.createFilter(filterString), null);
             serviceTracker.open();
 
             m_trackedServices.put(filterString, serviceTracker);
@@ -655,7 +655,7 @@ public class IntegrationTestBase extends
                 m_trackedConfigurations.clear();
             }
             if (m_closeServiceTrackers) {
-                for (ServiceTracker st : m_trackedServices.values()) {
+                for (ServiceTracker<?, ?> st : m_trackedServices.values()) {
                     try {
                         st.close();
                     }

Modified: ace/trunk/org.apache.ace.test/src/org/apache/ace/test/utils/TestUtils.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.test/src/org/apache/ace/test/utils/TestUtils.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.test/src/org/apache/ace/test/utils/TestUtils.java (original)
+++ ace/trunk/org.apache.ace.test/src/org/apache/ace/test/utils/TestUtils.java Fri Jan 29 08:59:31 2016
@@ -92,8 +92,8 @@ public class TestUtils {
      * @param iface the service interface
      * @param instance the implementation
      */
-    public static void configureObject(Object object, Class iface, Object instance) {
-        Class serviceClazz = object.getClass();
+    public static void configureObject(Object object, @SuppressWarnings("rawtypes") Class iface, Object instance) {
+        Class<?> serviceClazz = object.getClass();
 
         while (serviceClazz != null) {
             Field[] fields = serviceClazz.getDeclaredFields();
@@ -117,24 +117,18 @@ public class TestUtils {
 
     static class NullObject implements InvocationHandler {
         private static final Boolean DEFAULT_BOOLEAN = Boolean.FALSE;
-
         private static final Byte DEFAULT_BYTE = new Byte((byte) 0);
-
         private static final Short DEFAULT_SHORT = new Short((short) 0);
-
         private static final Integer DEFAULT_INT = new Integer(0);
-
         private static final Long DEFAULT_LONG = new Long(0);
-
         private static final Float DEFAULT_FLOAT = new Float(0.0f);
-
         private static final Double DEFAULT_DOUBLE = new Double(0.0);
 
         /**
          * Invokes a method on this null object. The method will return a default value without doing anything.
          */
         public Object invoke(Object proxy, Method method, Object[] args) throws Throwable {
-            Class returnType = method.getReturnType();
+            Class<?> returnType = method.getReturnType();
             if (returnType.equals(Boolean.class) || returnType.equals(Boolean.TYPE)) {
                 return DEFAULT_BOOLEAN;
             }

Modified: ace/trunk/org.apache.ace.useradmin.ui/src/org/apache/ace/useradmin/ui/editor/impl/UserEditorImpl.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.useradmin.ui/src/org/apache/ace/useradmin/ui/editor/impl/UserEditorImpl.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.useradmin.ui/src/org/apache/ace/useradmin/ui/editor/impl/UserEditorImpl.java (original)
+++ ace/trunk/org.apache.ace.useradmin.ui/src/org/apache/ace/useradmin/ui/editor/impl/UserEditorImpl.java Fri Jan 29 08:59:31 2016
@@ -147,7 +147,7 @@ public class UserEditorImpl implements U
 
     @Override
     public List<UserDTO> getData() {
-        List<UserDTO> tempData = new ArrayList<UserDTO>();
+        List<UserDTO> tempData = new ArrayList<>();
         try {
             Role[] roles = m_useradmin.getRoles(null);
             if (roles != null) {
@@ -190,7 +190,7 @@ public class UserEditorImpl implements U
 
     @Override
     public List<Group> getGroups() {
-        List<Group> tempGroups = new ArrayList<Group>();
+        List<Group> tempGroups = new ArrayList<>();
         try {
             Role[] roles = m_useradmin.getRoles("(type=userGroup)");
             if (roles != null) {
@@ -214,7 +214,7 @@ public class UserEditorImpl implements U
 
     @Override
     public List<User> getUsers() {
-        List<User> tempUsers = new ArrayList<User>();
+        List<User> tempUsers = new ArrayList<>();
         try {
             Role[] roles = m_useradmin.getRoles(null);
             if (roles != null) {

Modified: ace/trunk/org.apache.ace.verifier/src/org/apache/ace/deployment/verifier/impl/VerifierBundleRevision.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.verifier/src/org/apache/ace/deployment/verifier/impl/VerifierBundleRevision.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.verifier/src/org/apache/ace/deployment/verifier/impl/VerifierBundleRevision.java (original)
+++ ace/trunk/org.apache.ace.verifier/src/org/apache/ace/deployment/verifier/impl/VerifierBundleRevision.java Fri Jan 29 08:59:31 2016
@@ -86,7 +86,7 @@ public class VerifierBundleRevision impl
             return Collections.emptyList();
         }
 
-        List<BundleCapability> aliasCaps = new ArrayList<BundleCapability>(capabilities);
+        List<BundleCapability> aliasCaps = new ArrayList<>(capabilities);
 
         for (int capIdx = 0; capIdx < aliasCaps.size(); capIdx++)
         {
@@ -102,7 +102,7 @@ public class VerifierBundleRevision impl
                 if (Constants.BUNDLE_SYMBOLICNAME_ATTRIBUTE.equalsIgnoreCase(entry.getKey()))
                 {
                     // Make a copy of the attribute array.
-                    Map<String, Object> aliasAttrs = new HashMap<String, Object>(attributes);
+                    Map<String, Object> aliasAttrs = new HashMap<>(attributes);
                     // Add the aliased value.
                     aliasAttrs.put(Constants.BUNDLE_SYMBOLICNAME_ATTRIBUTE, new String[] { (String) entry.getValue(), Constants.SYSTEM_BUNDLE_SYMBOLICNAME });
                     // Create the aliased capability to replace the old capability.

Modified: ace/trunk/org.apache.ace.verifier/src/org/apache/ace/deployment/verifier/impl/VerifierResolverState.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.verifier/src/org/apache/ace/deployment/verifier/impl/VerifierResolverState.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.verifier/src/org/apache/ace/deployment/verifier/impl/VerifierResolverState.java (original)
+++ ace/trunk/org.apache.ace.verifier/src/org/apache/ace/deployment/verifier/impl/VerifierResolverState.java Fri Jan 29 08:59:31 2016
@@ -64,28 +64,28 @@ public class VerifierResolverState imple
 	 * @param fwkExecEnvStr the framework execution environment, can be <code>null</code>.
 	 */
 	public VerifierResolverState(String fwkExecEnvStr) {
-		m_revisions = new HashSet<BundleRevision>();
-		m_fragments = new HashSet<BundleRevision>();
-		m_capSets = new HashMap<String, CapabilitySet>();
+		m_revisions = new HashSet<>();
+		m_fragments = new HashSet<>();
+		m_capSets = new HashMap<>();
 
 		m_fwkExecEnvStr = (fwkExecEnvStr != null) ? fwkExecEnvStr.trim() : null;
 		m_fwkExecEnvSet = parseExecutionEnvironments(fwkExecEnvStr);
 
-		List<String> indices = new ArrayList<String>();
+		List<String> indices = new ArrayList<>();
 		indices.add(BundleRevision.BUNDLE_NAMESPACE);
 		m_capSets.put(BundleRevision.BUNDLE_NAMESPACE, new CapabilitySet(indices, true));
 
-		indices = new ArrayList<String>();
+		indices = new ArrayList<>();
 		indices.add(BundleRevision.PACKAGE_NAMESPACE);
 		m_capSets.put(BundleRevision.PACKAGE_NAMESPACE, new CapabilitySet(indices, true));
 
-		indices = new ArrayList<String>();
+		indices = new ArrayList<>();
 		indices.add(BundleRevision.HOST_NAMESPACE);
 		m_capSets.put(BundleRevision.HOST_NAMESPACE, new CapabilitySet(indices, true));
 	}
 
 	synchronized Set<BundleRevision> getUnresolvedRevisions() {
-		Set<BundleRevision> unresolved = new HashSet<BundleRevision>();
+		Set<BundleRevision> unresolved = new HashSet<>();
 		for (BundleRevision revision : m_revisions) {
 			if (revision.getWiring() == null) {
 				unresolved.add(revision);
@@ -149,7 +149,7 @@ public class VerifierResolverState imple
 	}
 
 	synchronized Set<BundleRevision> getFragments() {
-		return new HashSet<BundleRevision>(m_fragments);
+		return new HashSet<>(m_fragments);
 	}
 
 	/**
@@ -165,7 +165,7 @@ public class VerifierResolverState imple
      */
 	public synchronized SortedSet<BundleCapability> getCandidates(BundleRequirement req, boolean obeyMandatory) {
 //		BundleRevision reqRevision = req.getRevision();
-		SortedSet<BundleCapability> result = new TreeSet<BundleCapability>(new CandidateComparator());
+		SortedSet<BundleCapability> result = new TreeSet<>(new CandidateComparator());
 
 		CapabilitySet capSet = m_capSets.get(req.getNamespace());
 		if (capSet != null) {
@@ -329,7 +329,7 @@ public class VerifierResolverState imple
 	 * @return the parsed set of execution environments
 	 **/
 	private static Set<String> parseExecutionEnvironments(String fwkExecEnvStr) {
-		Set<String> newSet = new HashSet<String>();
+		Set<String> newSet = new HashSet<>();
 		if (fwkExecEnvStr != null) {
 			StringTokenizer tokens = new StringTokenizer(fwkExecEnvStr, ",");
 			while (tokens.hasMoreTokens()) {

Modified: ace/trunk/org.apache.ace.verifier/src/org/apache/ace/deployment/verifier/impl/VerifyEnvironmentImpl.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.verifier/src/org/apache/ace/deployment/verifier/impl/VerifyEnvironmentImpl.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.verifier/src/org/apache/ace/deployment/verifier/impl/VerifyEnvironmentImpl.java (original)
+++ ace/trunk/org.apache.ace.verifier/src/org/apache/ace/deployment/verifier/impl/VerifyEnvironmentImpl.java Fri Jan 29 08:59:31 2016
@@ -272,7 +272,7 @@ public class VerifyEnvironmentImpl imple
 
         m_config = config;
         m_reporter = (reporter == null) ? new DummyReporter() : reporter;
-        m_bundles = new ConcurrentHashMap<Long, VerifierBundleRevision>();
+        m_bundles = new ConcurrentHashMap<>();
         
         m_log = new Logger();
         m_log.setLogger(new FrameworkLogger(m_reporter));

Modified: ace/trunk/org.apache.ace.verifier/src/org/apache/ace/deployment/verifier/ui/ACEVerifierExtension.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.verifier/src/org/apache/ace/deployment/verifier/ui/ACEVerifierExtension.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.verifier/src/org/apache/ace/deployment/verifier/ui/ACEVerifierExtension.java (original)
+++ ace/trunk/org.apache.ace.verifier/src/org/apache/ace/deployment/verifier/ui/ACEVerifierExtension.java Fri Jan 29 08:59:31 2016
@@ -311,7 +311,7 @@ public class ACEVerifierExtension implem
     private Map<String, String> getManifestEntries(final Manifest manifest) {
         Attributes attributes = manifest.getMainAttributes();
 
-        Map<String, String> entries = new HashMap<String, String>();
+        Map<String, String> entries = new HashMap<>();
         for (Map.Entry<Object, Object> entry : attributes.entrySet()) {
             entries.put(entry.getKey().toString(), entry.getValue().toString());
         }
@@ -325,7 +325,7 @@ public class ACEVerifierExtension implem
     private Map<String, String> getManifestEntries(String manifestText) {
         StringTokenizer tok = new StringTokenizer(manifestText, ":\n");
 
-        Map<String, String> manMap = new HashMap<String, String>();
+        Map<String, String> manMap = new HashMap<>();
         while (tok.hasMoreTokens()) {
             manMap.put(tok.nextToken(), tok.nextToken());
         }

Modified: ace/trunk/org.apache.ace.verifier/src/org/apache/ace/deployment/verifier/ui/VerificationResult.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.verifier/src/org/apache/ace/deployment/verifier/ui/VerificationResult.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.verifier/src/org/apache/ace/deployment/verifier/ui/VerificationResult.java (original)
+++ ace/trunk/org.apache.ace.verifier/src/org/apache/ace/deployment/verifier/ui/VerificationResult.java Fri Jan 29 08:59:31 2016
@@ -33,9 +33,9 @@ import org.osgi.framework.wiring.BundleR
  * Provides the results of a verification.
  */
 final class VerificationResult {
-    private final Set<String> m_customizers = new HashSet<String>();
-    private final Set<String> m_processors = new HashSet<String>();
-    private final Set<BundleRevision> m_bundles = new HashSet<BundleRevision>();
+    private final Set<String> m_customizers = new HashSet<>();
+    private final Set<String> m_processors = new HashSet<>();
+    private final Set<BundleRevision> m_bundles = new HashSet<>();
     private final ByteArrayOutputStream m_output = new ByteArrayOutputStream();
     
     final PrintStream m_out = new PrintStream(m_output);

Modified: ace/trunk/org.apache.ace.verifier/src/org/apache/felix/framework/capabilityset/CapabilitySet.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.verifier/src/org/apache/felix/framework/capabilityset/CapabilitySet.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.verifier/src/org/apache/felix/framework/capabilityset/CapabilitySet.java (original)
+++ ace/trunk/org.apache.ace.verifier/src/org/apache/felix/framework/capabilityset/CapabilitySet.java Fri Jan 29 08:59:31 2016
@@ -40,7 +40,7 @@ import org.osgi.framework.wiring.BundleC
 public class CapabilitySet
 {
     private final Map<String, Map<Object, Set<BundleCapability>>> m_indices;
-    private final Set<BundleCapability> m_capSet = new HashSet<BundleCapability>();
+    private final Set<BundleCapability> m_capSet = new HashSet<>();
     private final static SecureAction m_secureAction = new SecureAction();
 
 public void dump()
@@ -124,7 +124,7 @@ public void dump()
         Set<BundleCapability> caps = index.get(capValue);
         if (caps == null)
         {
-            caps = new HashSet<BundleCapability>();
+            caps = new HashSet<>();
             index.put(capValue, caps);
         }
         caps.add(cap);
@@ -187,7 +187,7 @@ public void dump()
 
     private Set<BundleCapability> match(Set<BundleCapability> caps, SimpleFilter sf)
     {
-        Set<BundleCapability> matches = new HashSet<BundleCapability>();
+        Set<BundleCapability> matches = new HashSet<>();
 
         if (sf.getOperation() == SimpleFilter.MATCH_ALL)
         {

Modified: ace/trunk/org.apache.ace.verifier/src/org/apache/felix/framework/capabilityset/SimpleFilter.java
URL: http://svn.apache.org/viewvc/ace/trunk/org.apache.ace.verifier/src/org/apache/felix/framework/capabilityset/SimpleFilter.java?rev=1727499&r1=1727498&r2=1727499&view=diff
==============================================================================
--- ace/trunk/org.apache.ace.verifier/src/org/apache/felix/framework/capabilityset/SimpleFilter.java (original)
+++ ace/trunk/org.apache.ace.verifier/src/org/apache/felix/framework/capabilityset/SimpleFilter.java Fri Jan 29 08:59:31 2016
@@ -561,7 +561,7 @@ loop:   for (int i = 0; i < len; i++)
         // Rather than building a filter string to be parsed into a SimpleFilter,
         // we will just create the parsed SimpleFilter directly.
 
-        List<SimpleFilter> filters = new ArrayList<SimpleFilter>();
+        List<SimpleFilter> filters = new ArrayList<>();
 
         for (Entry<String, Object> entry : attrs.entrySet())
         {