You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@tomee.apache.org by an...@apache.org on 2015/11/24 19:13:09 UTC

[1/2] tomee git commit: Saving files before refreshing line endings

Repository: tomee
Updated Branches:
  refs/heads/tomee-1.7.3-prepare ba185f5e4 -> 81d3cd3ac


http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/server/openejb-multicast/src/test/java/org/apache/openejb/server/discovery/MulticastPulseAgentTest.java
----------------------------------------------------------------------
diff --git a/server/openejb-multicast/src/test/java/org/apache/openejb/server/discovery/MulticastPulseAgentTest.java b/server/openejb-multicast/src/test/java/org/apache/openejb/server/discovery/MulticastPulseAgentTest.java
index 223a768..92147ed 100644
--- a/server/openejb-multicast/src/test/java/org/apache/openejb/server/discovery/MulticastPulseAgentTest.java
+++ b/server/openejb-multicast/src/test/java/org/apache/openejb/server/discovery/MulticastPulseAgentTest.java
@@ -1,513 +1,513 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.openejb.server.discovery;
-
-import org.apache.openejb.server.DiscoveryListener;
-import org.apache.openejb.util.NetworkUtil;
-import org.junit.AfterClass;
-import org.junit.BeforeClass;
-import org.junit.Test;
-import sun.net.util.IPAddressUtil;
-
-import java.net.DatagramPacket;
-import java.net.Inet6Address;
-import java.net.InetAddress;
-import java.net.InetSocketAddress;
-import java.net.MulticastSocket;
-import java.net.SocketAddress;
-import java.net.URI;
-import java.net.UnknownHostException;
-import java.nio.charset.Charset;
-import java.util.ArrayList;
-import java.util.Arrays;
-import java.util.Comparator;
-import java.util.HashSet;
-import java.util.Properties;
-import java.util.Set;
-import java.util.Timer;
-import java.util.TimerTask;
-import java.util.TreeSet;
-import java.util.concurrent.CountDownLatch;
-import java.util.concurrent.ExecutorService;
-import java.util.concurrent.Executors;
-import java.util.concurrent.Future;
-import java.util.concurrent.TimeUnit;
-import java.util.concurrent.atomic.AtomicBoolean;
-import java.util.concurrent.locks.ReentrantLock;
-import java.util.logging.Logger;
-
-@SuppressWarnings("UseOfSystemOutOrSystemErr")
-public class MulticastPulseAgentTest {
-
-    private static final Set<String> schemes = new HashSet<String>(Arrays.asList("ejbd", "ejbds", "http"));
-    private static ExecutorService executor;
-    private static final Charset utf8 = Charset.forName("UTF-8");
-    private static final String forGroup = "*";
-    private static final String host = "239.255.3.2";
-    private static final int port = NetworkUtil.getNextAvailablePort();
-    private static MulticastPulseAgent agent;
-
-    @BeforeClass
-    public static void beforeClass() throws Exception {
-
-        executor = Executors.newFixedThreadPool(10);
-
-        final Properties p = new Properties();
-        p.setProperty("bind", host);
-        p.setProperty("port", "" + port);
-
-        agent = new MulticastPulseAgent();
-        agent.init(p);
-        agent.setDiscoveryListener(new MyDiscoveryListener("MulticastPulseAgentTest"));
-        agent.registerService(new URI("ejb:ejbd://[::]:4201"));
-        agent.registerService(new URI("ejb:ejbd://0.0.0.0:4201"));
-        agent.registerService(new URI("ejb:http://127.0.0.1:4201"));
-        agent.registerService(new URI("ejb:https://0.0.0.1:4201"));
-        agent.start();
-
-        System.out.println();
-    }
-
-    @AfterClass
-    public static void afterClass() throws Exception {
-        agent.stop();
-        executor.shutdownNow();
-    }
-
-    /**
-     * Most of this code is identical to org.apache.openejb.client.MulticastPulseClient#discoverURIs
-     * <p/>
-     * The MulticastPulseClient class is not shared or available here so the test has to emulate it.
-     *
-     * @throws Exception On error
-     */
-    @Test
-    public void test() throws Exception {
-        if ("true".equals(System.getProperty("skipMulticastTests"))) {
-            Logger.getLogger(this.getClass().getName()).warning("Skipping MulticastTest " + this.getClass().getName());
-            return;
-        }
-
-        final InetAddress ia;
-
-        try {
-            ia = InetAddress.getByName(host);
-        } catch (final UnknownHostException e) {
-            throw new Exception(host + " is not a valid address", e);
-        }
-
-        if (null == ia || !ia.isMulticastAddress()) {
-            throw new Exception(host + " is not a valid multicast address");
-        }
-
-        //Returns at least one socket per valid network interface
-        final MulticastSocket[] clientSockets = MulticastPulseAgent.getSockets(host, port);
-
-        //No point going on if we don't have sockets...
-        if (clientSockets.length < 1) {
-            System.out.println("Cannnot perform multipulse test without a valid interface");
-            return;
-        }
-
-        final byte[] bytes = (MulticastPulseAgent.CLIENT + forGroup).getBytes(utf8);
-        final DatagramPacket request = new DatagramPacket(bytes, bytes.length, new InetSocketAddress(ia, port));
-        final AtomicBoolean running = new AtomicBoolean(true);
-        final Timer timer = new Timer(true);
-
-        final Set<URI> set = new TreeSet<URI>(new Comparator<URI>() {
-            @Override
-            public int compare(final URI uri1, final URI uri2) {
-
-                //Ignore server hostname
-                URI u1 = URI.create(uri1.getSchemeSpecificPart());
-                URI u2 = URI.create(uri2.getSchemeSpecificPart());
-
-                //Ignore scheme (ejb,ejbs,etc.)
-                u1 = URI.create(u1.getSchemeSpecificPart());
-                u2 = URI.create(u2.getSchemeSpecificPart());
-
-                //Compare URI hosts
-                int i = compare(u1.getHost(), u2.getHost());
-                if (i != 0) {
-                    i = uri1.compareTo(uri2);
-                }
-
-                return i;
-            }
-
-            private int compare(final String h1, final String h2) {
-
-                //Sort by hostname, IPv4, IPv6
-
-                try {
-                    if (IPAddressUtil.isIPv4LiteralAddress(h1)) {
-                        if (IPAddressUtil.isIPv6LiteralAddress(h2.replace("[", "").replace("]", ""))) {
-                            return -1;
-                        }
-                    } else if (IPAddressUtil.isIPv6LiteralAddress(h1.replace("[", "").replace("]", ""))) {
-                        if (IPAddressUtil.isIPv4LiteralAddress(h2)) {
-                            return 1;
-                        }
-                    } else if (0 != h1.compareTo(h2)) {
-                        return -1;
-                    }
-                } catch (final Throwable e) {
-                    //Ignore
-                }
-
-                return h1.compareTo(h2);
-            }
-        });
-
-        final ReentrantLock setLock = new ReentrantLock();
-
-        //Start threads that listen for multicast packets on our channel.
-        //These need to start 'before' we pulse a request.
-        final ArrayList<Future> futures = new ArrayList<Future>();
-        final CountDownLatch latch = new CountDownLatch(clientSockets.length);
-
-        for (final MulticastSocket socket : clientSockets) {
-
-            futures.add(executor.submit(new Runnable() {
-                @Override
-                public void run() {
-
-                    String name = "Unknown interface";
-                    try {
-                        name = socket.getNetworkInterface().getDisplayName();
-                    } catch (final Throwable e) {
-                        //Ignore
-                    }
-                    System.out.println("Entered MulticastPulse client thread on: " + name);
-
-                    final DatagramPacket response = new DatagramPacket(new byte[2048], 2048);
-
-                    latch.countDown();
-
-                    while (running.get()) {
-                        try {
-
-                            socket.receive(response);
-
-                            final SocketAddress sa = response.getSocketAddress();
-
-                            if ((sa instanceof InetSocketAddress)) {
-
-                                int len = response.getLength();
-                                if (len > 2048) {
-                                    len = 2048;
-                                }
-
-                                String s = new String(response.getData(), 0, len);
-
-                                if (s.startsWith(MulticastPulseAgent.SERVER)) {
-
-                                    s = (s.replace(MulticastPulseAgent.SERVER, ""));
-                                    final String group = s.substring(0, s.indexOf(':'));
-                                    s = s.substring(group.length() + 1);
-
-                                    if (!"*".equals(forGroup) && !forGroup.equals(group)) {
-                                        continue;
-                                    }
-
-                                    final String services = s.substring(0, s.lastIndexOf('|'));
-                                    s = s.substring(services.length() + 1);
-
-                                    final String[] serviceList = services.split("\\|");
-                                    final String[] hosts = s.split(",");
-
-                                    System.out.println(String.format("\n" + name + " received Server pulse:\n\tGroup: %1$s\n\tServices: %2$s\n\tServer: %3$s\n",
-                                            group,
-                                            services,
-                                            s));
-
-                                    for (final String svc : serviceList) {
-
-                                        if (MulticastPulseAgent.EMPTY.equals(svc)) {
-                                            continue;
-                                        }
-
-                                        final URI serviceUri;
-                                        try {
-                                            serviceUri = URI.create(svc);
-                                        } catch (final Throwable e) {
-                                            continue;
-                                        }
-
-                                        if (schemes.contains(serviceUri.getScheme())) {
-
-                                            //Just because multicast was received on this host is does not mean the service is on the same
-                                            //We can however use this to identify an individual machine and group
-                                            final String serverHost = ((InetSocketAddress) response.getSocketAddress()).getAddress().getHostAddress();
-
-                                            final String serviceHost = serviceUri.getHost();
-                                            if (MulticastPulseAgent.isLocalAddress(serviceHost, false)) {
-                                                if (!MulticastPulseAgent.isLocalAddress(serverHost, false)) {
-                                                    //A local service is only available to a local client
-                                                    continue;
-                                                }
-                                            }
-
-                                            final String fullsvc = ("mp-" + serverHost + ":" + group + ":" + svc);
-
-                                            setLock.lock();
-
-                                            try {
-                                                if (fullsvc.contains("0.0.0.0")) {
-                                                    for (final String h : hosts) {
-                                                        if (!h.replace("[", "").startsWith("2001:0:")) { //Filter Teredo
-                                                            set.add(URI.create(fullsvc.replace("0.0.0.0", ipFormat(h))));
-                                                        }
-                                                    }
-                                                } else if (fullsvc.contains("[::]")) {
-                                                    for (final String h : hosts) {
-                                                        if (!h.replace("[", "").startsWith("2001:0:")) { //Filter Teredo
-                                                            set.add(URI.create(fullsvc.replace("[::]", ipFormat(h))));
-                                                        }
-                                                    }
-                                                } else {
-                                                    //Just add as is
-                                                    set.add(URI.create(fullsvc));
-                                                }
-                                            } catch (final Throwable e) {
-                                                //Ignore
-                                            } finally {
-                                                setLock.unlock();
-                                            }
-                                        } else {
-                                            System.out.println("Reject service: " + serviceUri.toASCIIString() + " - Not looking for scheme: " + serviceUri.getScheme());
-                                        }
-                                    }
-                                }
-                            }
-
-                        } catch (final Throwable e) {
-                            //Ignore
-                        }
-                    }
-
-                    System.out.println("Exit MulticastPulse client thread on: " + name);
-                    System.out.flush();
-                }
-            }));
-        }
-
-        //Allow slow thread starts
-        System.out.println("Wait for threads to start");
-        int timeout = 5000;
-        try {
-
-            //Give threads a generous amount of time to start
-            if (latch.await(15, TimeUnit.SECONDS)) {
-                System.out.println("Threads have started");
-
-                //Pulse the server - It is thread safe to use same sockets as send/receive synchronization is only on the packet
-                for (final MulticastSocket socket : clientSockets) {
-                    try {
-                        socket.send(request);
-                    } catch (final Throwable e) {
-                        //Ignore
-                    }
-                }
-            } else {
-                timeout = 1;
-                System.out.println("Giving up on threads");
-            }
-
-        } catch (final InterruptedException e) {
-            timeout = 1;
-        }
-
-        //Kill the threads after timeout
-        timer.schedule(new TimerTask() {
-            @Override
-            public void run() {
-
-                running.set(false);
-
-                for (final Future future : futures) {
-                    try {
-                        future.cancel(true);
-                    } catch (final Throwable e) {
-                        //Ignore
-                    }
-                }
-
-                for (final MulticastSocket socket : clientSockets) {
-
-                    try {
-                        socket.leaveGroup(ia);
-                    } catch (final Throwable e) {
-                        //Ignore
-                    }
-                    try {
-                        socket.close();
-                    } catch (final Throwable e) {
-                        //Ignore
-                    }
-                }
-            }
-        }, timeout);
-
-        //Wait for threads to complete
-        for (final Future future : futures) {
-            try {
-                future.get();
-            } catch (final Throwable e) {
-                //Ignore
-            }
-        }
-
-        System.out.println();
-        System.out.flush();
-
-        final ArrayList<String> list = new ArrayList<String>();
-
-        final TreeSet<URI> uris = new TreeSet<URI>(set);
-        for (final URI uri : uris) {
-            final String astr = uri.toASCIIString();
-            System.out.println("MultiPulse discovered: " + astr);
-
-            if (list.contains(astr)) {
-                System.out.println("Duplicate uri: " + uri);
-            }
-
-            org.junit.Assert.assertTrue(!list.contains(astr));
-            list.add(astr);
-        }
-
-        System.out.println("Multipulse complete");
-
-        //If timeout == 1 assume either a cancel or the test took too long (Will not fail)
-        org.junit.Assert.assertTrue(timeout == 1 || set.size() > 0);
-    }
-
-    @Test
-    public void testBroadcastBadUri() throws Exception {
-        if ("true".equals(System.getProperty("skipMulticastTests"))) {
-            Logger.getLogger(this.getClass().getName()).warning("Skipping MulticastTest " + this.getClass().getName());
-            return;
-        }
-
-        final DiscoveryListener original = agent.getDiscoveryListener();
-
-        final CountDownLatch latch = new CountDownLatch(1);
-
-        final DiscoveryListener listener = new DiscoveryListener() {
-            @Override
-            public void serviceAdded(final URI service) {
-                latch.countDown();
-                System.out.println("added = " + service);
-            }
-
-            @Override
-            public void serviceRemoved(final URI service) {
-                latch.countDown();
-                System.out.println("removed = " + service);
-            }
-        };
-
-        agent.setDiscoveryListener(listener);
-
-        final String[] hosts = agent.getHosts().split(",");
-        final String host = hosts[hosts.length - 1];
-
-        boolean removed = agent.removeFromIgnore(host);
-        org.junit.Assert.assertTrue("Host is already ignored", !removed);
-
-        final Future<?> future = executor.submit(new Runnable() {
-            @Override
-            public void run() {
-                try {
-                    final InetAddress ia = getAddress(MulticastPulseAgentTest.host);
-
-                    final byte[] bytes = (MulticastPulseAgent.CLIENT + forGroup + MulticastPulseAgent.BADURI + host).getBytes(Charset.forName("UTF-8"));
-                    final DatagramPacket request = new DatagramPacket(bytes, bytes.length, new InetSocketAddress(ia, port));
-
-                    final MulticastSocket[] multicastSockets = MulticastPulseAgent.getSockets(MulticastPulseAgentTest.host, port);
-
-                    for (int i = 0; i < 5; i++) {
-                        for (final MulticastSocket socket : multicastSockets) {
-
-                            try {
-                                socket.send(request);
-                                Thread.sleep(100);
-                            } catch (final Exception e) {
-                                System.out.println("Failed to broadcast bad URI on: " + socket.getInterface().getHostAddress());
-                                e.printStackTrace();
-                            }
-                        }
-                    }
-                } catch (final Exception e) {
-                    System.out.println("Failed to broadcast bad URI");
-                    e.printStackTrace();
-                }
-            }
-        });
-
-        final boolean await = latch.await(20, TimeUnit.SECONDS);
-        removed = agent.removeFromIgnore(host);
-
-        agent.setDiscoveryListener(original);
-
-        org.junit.Assert.assertTrue("Failed to remove host", removed);
-        org.junit.Assert.assertTrue("Failed to unlatch", await);
-    }
-
-    private String ipFormat(final String h) throws UnknownHostException {
-
-        final InetAddress ia = InetAddress.getByName(h);
-        if (ia instanceof Inet6Address) {
-            return "[" + ia.getHostAddress() + "]";
-        } else {
-            return h;
-        }
-    }
-
-    private static InetAddress getAddress(final String host) throws Exception {
-        final InetAddress ia;
-        try {
-            ia = InetAddress.getByName(host);
-        } catch (final UnknownHostException e) {
-            throw new Exception(host + " is not a valid address", e);
-        }
-
-        if (null == ia || !ia.isMulticastAddress()) {
-            throw new Exception(host + " is not a valid multicast address");
-        }
-        return ia;
-    }
-
-    private static class MyDiscoveryListener implements DiscoveryListener {
-
-        private final String id;
-
-        public MyDiscoveryListener(final String id) {
-            this.id = id;
-        }
-
-        @Override
-        public void serviceAdded(final URI service) {
-            System.out.println(id + ": add : " + service.toString());
-        }
-
-        @Override
-        public void serviceRemoved(final URI service) {
-            System.out.println(id + ": remove : " + service.toString());
-        }
-    }
-}
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.openejb.server.discovery;
+
+import org.apache.openejb.server.DiscoveryListener;
+import org.apache.openejb.util.NetworkUtil;
+import org.junit.AfterClass;
+import org.junit.BeforeClass;
+import org.junit.Test;
+import sun.net.util.IPAddressUtil;
+
+import java.net.DatagramPacket;
+import java.net.Inet6Address;
+import java.net.InetAddress;
+import java.net.InetSocketAddress;
+import java.net.MulticastSocket;
+import java.net.SocketAddress;
+import java.net.URI;
+import java.net.UnknownHostException;
+import java.nio.charset.Charset;
+import java.util.ArrayList;
+import java.util.Arrays;
+import java.util.Comparator;
+import java.util.HashSet;
+import java.util.Properties;
+import java.util.Set;
+import java.util.Timer;
+import java.util.TimerTask;
+import java.util.TreeSet;
+import java.util.concurrent.CountDownLatch;
+import java.util.concurrent.ExecutorService;
+import java.util.concurrent.Executors;
+import java.util.concurrent.Future;
+import java.util.concurrent.TimeUnit;
+import java.util.concurrent.atomic.AtomicBoolean;
+import java.util.concurrent.locks.ReentrantLock;
+import java.util.logging.Logger;
+
+@SuppressWarnings("UseOfSystemOutOrSystemErr")
+public class MulticastPulseAgentTest {
+
+    private static final Set<String> schemes = new HashSet<String>(Arrays.asList("ejbd", "ejbds", "http"));
+    private static ExecutorService executor;
+    private static final Charset utf8 = Charset.forName("UTF-8");
+    private static final String forGroup = "*";
+    private static final String host = "239.255.3.2";
+    private static final int port = NetworkUtil.getNextAvailablePort();
+    private static MulticastPulseAgent agent;
+
+    @BeforeClass
+    public static void beforeClass() throws Exception {
+
+        executor = Executors.newFixedThreadPool(10);
+
+        final Properties p = new Properties();
+        p.setProperty("bind", host);
+        p.setProperty("port", "" + port);
+
+        agent = new MulticastPulseAgent();
+        agent.init(p);
+        agent.setDiscoveryListener(new MyDiscoveryListener("MulticastPulseAgentTest"));
+        agent.registerService(new URI("ejb:ejbd://[::]:4201"));
+        agent.registerService(new URI("ejb:ejbd://0.0.0.0:4201"));
+        agent.registerService(new URI("ejb:http://127.0.0.1:4201"));
+        agent.registerService(new URI("ejb:https://0.0.0.1:4201"));
+        agent.start();
+
+        System.out.println();
+    }
+
+    @AfterClass
+    public static void afterClass() throws Exception {
+        agent.stop();
+        executor.shutdownNow();
+    }
+
+    /**
+     * Most of this code is identical to org.apache.openejb.client.MulticastPulseClient#discoverURIs
+     * <p/>
+     * The MulticastPulseClient class is not shared or available here so the test has to emulate it.
+     *
+     * @throws Exception On error
+     */
+    @Test
+    public void test() throws Exception {
+        if ("true".equals(System.getProperty("skipMulticastTests"))) {
+            Logger.getLogger(this.getClass().getName()).warning("Skipping MulticastTest " + this.getClass().getName());
+            return;
+        }
+
+        final InetAddress ia;
+
+        try {
+            ia = InetAddress.getByName(host);
+        } catch (final UnknownHostException e) {
+            throw new Exception(host + " is not a valid address", e);
+        }
+
+        if (null == ia || !ia.isMulticastAddress()) {
+            throw new Exception(host + " is not a valid multicast address");
+        }
+
+        //Returns at least one socket per valid network interface
+        final MulticastSocket[] clientSockets = MulticastPulseAgent.getSockets(host, port);
+
+        //No point going on if we don't have sockets...
+        if (clientSockets.length < 1) {
+            System.out.println("Cannnot perform multipulse test without a valid interface");
+            return;
+        }
+
+        final byte[] bytes = (MulticastPulseAgent.CLIENT + forGroup).getBytes(utf8);
+        final DatagramPacket request = new DatagramPacket(bytes, bytes.length, new InetSocketAddress(ia, port));
+        final AtomicBoolean running = new AtomicBoolean(true);
+        final Timer timer = new Timer(true);
+
+        final Set<URI> set = new TreeSet<URI>(new Comparator<URI>() {
+            @Override
+            public int compare(final URI uri1, final URI uri2) {
+
+                //Ignore server hostname
+                URI u1 = URI.create(uri1.getSchemeSpecificPart());
+                URI u2 = URI.create(uri2.getSchemeSpecificPart());
+
+                //Ignore scheme (ejb,ejbs,etc.)
+                u1 = URI.create(u1.getSchemeSpecificPart());
+                u2 = URI.create(u2.getSchemeSpecificPart());
+
+                //Compare URI hosts
+                int i = compare(u1.getHost(), u2.getHost());
+                if (i != 0) {
+                    i = uri1.compareTo(uri2);
+                }
+
+                return i;
+            }
+
+            private int compare(final String h1, final String h2) {
+
+                //Sort by hostname, IPv4, IPv6
+
+                try {
+                    if (IPAddressUtil.isIPv4LiteralAddress(h1)) {
+                        if (IPAddressUtil.isIPv6LiteralAddress(h2.replace("[", "").replace("]", ""))) {
+                            return -1;
+                        }
+                    } else if (IPAddressUtil.isIPv6LiteralAddress(h1.replace("[", "").replace("]", ""))) {
+                        if (IPAddressUtil.isIPv4LiteralAddress(h2)) {
+                            return 1;
+                        }
+                    } else if (0 != h1.compareTo(h2)) {
+                        return -1;
+                    }
+                } catch (final Throwable e) {
+                    //Ignore
+                }
+
+                return h1.compareTo(h2);
+            }
+        });
+
+        final ReentrantLock setLock = new ReentrantLock();
+
+        //Start threads that listen for multicast packets on our channel.
+        //These need to start 'before' we pulse a request.
+        final ArrayList<Future> futures = new ArrayList<Future>();
+        final CountDownLatch latch = new CountDownLatch(clientSockets.length);
+
+        for (final MulticastSocket socket : clientSockets) {
+
+            futures.add(executor.submit(new Runnable() {
+                @Override
+                public void run() {
+
+                    String name = "Unknown interface";
+                    try {
+                        name = socket.getNetworkInterface().getDisplayName();
+                    } catch (final Throwable e) {
+                        //Ignore
+                    }
+                    System.out.println("Entered MulticastPulse client thread on: " + name);
+
+                    final DatagramPacket response = new DatagramPacket(new byte[2048], 2048);
+
+                    latch.countDown();
+
+                    while (running.get()) {
+                        try {
+
+                            socket.receive(response);
+
+                            final SocketAddress sa = response.getSocketAddress();
+
+                            if ((sa instanceof InetSocketAddress)) {
+
+                                int len = response.getLength();
+                                if (len > 2048) {
+                                    len = 2048;
+                                }
+
+                                String s = new String(response.getData(), 0, len);
+
+                                if (s.startsWith(MulticastPulseAgent.SERVER)) {
+
+                                    s = (s.replace(MulticastPulseAgent.SERVER, ""));
+                                    final String group = s.substring(0, s.indexOf(':'));
+                                    s = s.substring(group.length() + 1);
+
+                                    if (!"*".equals(forGroup) && !forGroup.equals(group)) {
+                                        continue;
+                                    }
+
+                                    final String services = s.substring(0, s.lastIndexOf('|'));
+                                    s = s.substring(services.length() + 1);
+
+                                    final String[] serviceList = services.split("\\|");
+                                    final String[] hosts = s.split(",");
+
+                                    System.out.println(String.format("\n" + name + " received Server pulse:\n\tGroup: %1$s\n\tServices: %2$s\n\tServer: %3$s\n",
+                                            group,
+                                            services,
+                                            s));
+
+                                    for (final String svc : serviceList) {
+
+                                        if (MulticastPulseAgent.EMPTY.equals(svc)) {
+                                            continue;
+                                        }
+
+                                        final URI serviceUri;
+                                        try {
+                                            serviceUri = URI.create(svc);
+                                        } catch (final Throwable e) {
+                                            continue;
+                                        }
+
+                                        if (schemes.contains(serviceUri.getScheme())) {
+
+                                            //Just because multicast was received on this host is does not mean the service is on the same
+                                            //We can however use this to identify an individual machine and group
+                                            final String serverHost = ((InetSocketAddress) response.getSocketAddress()).getAddress().getHostAddress();
+
+                                            final String serviceHost = serviceUri.getHost();
+                                            if (MulticastPulseAgent.isLocalAddress(serviceHost, false)) {
+                                                if (!MulticastPulseAgent.isLocalAddress(serverHost, false)) {
+                                                    //A local service is only available to a local client
+                                                    continue;
+                                                }
+                                            }
+
+                                            final String fullsvc = ("mp-" + serverHost + ":" + group + ":" + svc);
+
+                                            setLock.lock();
+
+                                            try {
+                                                if (fullsvc.contains("0.0.0.0")) {
+                                                    for (final String h : hosts) {
+                                                        if (!h.replace("[", "").startsWith("2001:0:")) { //Filter Teredo
+                                                            set.add(URI.create(fullsvc.replace("0.0.0.0", ipFormat(h))));
+                                                        }
+                                                    }
+                                                } else if (fullsvc.contains("[::]")) {
+                                                    for (final String h : hosts) {
+                                                        if (!h.replace("[", "").startsWith("2001:0:")) { //Filter Teredo
+                                                            set.add(URI.create(fullsvc.replace("[::]", ipFormat(h))));
+                                                        }
+                                                    }
+                                                } else {
+                                                    //Just add as is
+                                                    set.add(URI.create(fullsvc));
+                                                }
+                                            } catch (final Throwable e) {
+                                                //Ignore
+                                            } finally {
+                                                setLock.unlock();
+                                            }
+                                        } else {
+                                            System.out.println("Reject service: " + serviceUri.toASCIIString() + " - Not looking for scheme: " + serviceUri.getScheme());
+                                        }
+                                    }
+                                }
+                            }
+
+                        } catch (final Throwable e) {
+                            //Ignore
+                        }
+                    }
+
+                    System.out.println("Exit MulticastPulse client thread on: " + name);
+                    System.out.flush();
+                }
+            }));
+        }
+
+        //Allow slow thread starts
+        System.out.println("Wait for threads to start");
+        int timeout = 5000;
+        try {
+
+            //Give threads a generous amount of time to start
+            if (latch.await(15, TimeUnit.SECONDS)) {
+                System.out.println("Threads have started");
+
+                //Pulse the server - It is thread safe to use same sockets as send/receive synchronization is only on the packet
+                for (final MulticastSocket socket : clientSockets) {
+                    try {
+                        socket.send(request);
+                    } catch (final Throwable e) {
+                        //Ignore
+                    }
+                }
+            } else {
+                timeout = 1;
+                System.out.println("Giving up on threads");
+            }
+
+        } catch (final InterruptedException e) {
+            timeout = 1;
+        }
+
+        //Kill the threads after timeout
+        timer.schedule(new TimerTask() {
+            @Override
+            public void run() {
+
+                running.set(false);
+
+                for (final Future future : futures) {
+                    try {
+                        future.cancel(true);
+                    } catch (final Throwable e) {
+                        //Ignore
+                    }
+                }
+
+                for (final MulticastSocket socket : clientSockets) {
+
+                    try {
+                        socket.leaveGroup(ia);
+                    } catch (final Throwable e) {
+                        //Ignore
+                    }
+                    try {
+                        socket.close();
+                    } catch (final Throwable e) {
+                        //Ignore
+                    }
+                }
+            }
+        }, timeout);
+
+        //Wait for threads to complete
+        for (final Future future : futures) {
+            try {
+                future.get();
+            } catch (final Throwable e) {
+                //Ignore
+            }
+        }
+
+        System.out.println();
+        System.out.flush();
+
+        final ArrayList<String> list = new ArrayList<String>();
+
+        final TreeSet<URI> uris = new TreeSet<URI>(set);
+        for (final URI uri : uris) {
+            final String astr = uri.toASCIIString();
+            System.out.println("MultiPulse discovered: " + astr);
+
+            if (list.contains(astr)) {
+                System.out.println("Duplicate uri: " + uri);
+            }
+
+            org.junit.Assert.assertTrue(!list.contains(astr));
+            list.add(astr);
+        }
+
+        System.out.println("Multipulse complete");
+
+        //If timeout == 1 assume either a cancel or the test took too long (Will not fail)
+        org.junit.Assert.assertTrue(timeout == 1 || set.size() > 0);
+    }
+
+    @Test
+    public void testBroadcastBadUri() throws Exception {
+        if ("true".equals(System.getProperty("skipMulticastTests"))) {
+            Logger.getLogger(this.getClass().getName()).warning("Skipping MulticastTest " + this.getClass().getName());
+            return;
+        }
+
+        final DiscoveryListener original = agent.getDiscoveryListener();
+
+        final CountDownLatch latch = new CountDownLatch(1);
+
+        final DiscoveryListener listener = new DiscoveryListener() {
+            @Override
+            public void serviceAdded(final URI service) {
+                latch.countDown();
+                System.out.println("added = " + service);
+            }
+
+            @Override
+            public void serviceRemoved(final URI service) {
+                latch.countDown();
+                System.out.println("removed = " + service);
+            }
+        };
+
+        agent.setDiscoveryListener(listener);
+
+        final String[] hosts = agent.getHosts().split(",");
+        final String host = hosts[hosts.length - 1];
+
+        boolean removed = agent.removeFromIgnore(host);
+        org.junit.Assert.assertTrue("Host is already ignored", !removed);
+
+        final Future<?> future = executor.submit(new Runnable() {
+            @Override
+            public void run() {
+                try {
+                    final InetAddress ia = getAddress(MulticastPulseAgentTest.host);
+
+                    final byte[] bytes = (MulticastPulseAgent.CLIENT + forGroup + MulticastPulseAgent.BADURI + host).getBytes(Charset.forName("UTF-8"));
+                    final DatagramPacket request = new DatagramPacket(bytes, bytes.length, new InetSocketAddress(ia, port));
+
+                    final MulticastSocket[] multicastSockets = MulticastPulseAgent.getSockets(MulticastPulseAgentTest.host, port);
+
+                    for (int i = 0; i < 5; i++) {
+                        for (final MulticastSocket socket : multicastSockets) {
+
+                            try {
+                                socket.send(request);
+                                Thread.sleep(100);
+                            } catch (final Exception e) {
+                                System.out.println("Failed to broadcast bad URI on: " + socket.getInterface().getHostAddress());
+                                e.printStackTrace();
+                            }
+                        }
+                    }
+                } catch (final Exception e) {
+                    System.out.println("Failed to broadcast bad URI");
+                    e.printStackTrace();
+                }
+            }
+        });
+
+        final boolean await = latch.await(20, TimeUnit.SECONDS);
+        removed = agent.removeFromIgnore(host);
+
+        agent.setDiscoveryListener(original);
+
+        org.junit.Assert.assertTrue("Failed to remove host", removed);
+        org.junit.Assert.assertTrue("Failed to unlatch", await);
+    }
+
+    private String ipFormat(final String h) throws UnknownHostException {
+
+        final InetAddress ia = InetAddress.getByName(h);
+        if (ia instanceof Inet6Address) {
+            return "[" + ia.getHostAddress() + "]";
+        } else {
+            return h;
+        }
+    }
+
+    private static InetAddress getAddress(final String host) throws Exception {
+        final InetAddress ia;
+        try {
+            ia = InetAddress.getByName(host);
+        } catch (final UnknownHostException e) {
+            throw new Exception(host + " is not a valid address", e);
+        }
+
+        if (null == ia || !ia.isMulticastAddress()) {
+            throw new Exception(host + " is not a valid multicast address");
+        }
+        return ia;
+    }
+
+    private static class MyDiscoveryListener implements DiscoveryListener {
+
+        private final String id;
+
+        public MyDiscoveryListener(final String id) {
+            this.id = id;
+        }
+
+        @Override
+        public void serviceAdded(final URI service) {
+            System.out.println(id + ": add : " + service.toString());
+        }
+
+        @Override
+        public void serviceRemoved(final URI service) {
+            System.out.println(id + ": remove : " + service.toString());
+        }
+    }
+}

http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/server/openejb-rest/src/main/java/org/apache/openejb/server/rest/InternalApplication.java
----------------------------------------------------------------------
diff --git a/server/openejb-rest/src/main/java/org/apache/openejb/server/rest/InternalApplication.java b/server/openejb-rest/src/main/java/org/apache/openejb/server/rest/InternalApplication.java
index 2035805..cb36fda 100644
--- a/server/openejb-rest/src/main/java/org/apache/openejb/server/rest/InternalApplication.java
+++ b/server/openejb-rest/src/main/java/org/apache/openejb/server/rest/InternalApplication.java
@@ -1,45 +1,45 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- *     contributor license agreements.  See the NOTICE file distributed with
- *     this work for additional information regarding copyright ownership.
- *     The ASF licenses this file to You under the Apache License, Version 2.0
- *     (the "License"); you may not use this file except in compliance with
- *     the License.  You may obtain a copy of the License at
- *
- *        http://www.apache.org/licenses/LICENSE-2.0
- *
- *     Unless required by applicable law or agreed to in writing, software
- *     distributed under the License is distributed on an "AS IS" BASIS,
- *     WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- *     See the License for the specific language governing permissions and
- *     limitations under the License.
- */
-package org.apache.openejb.server.rest;
-
-import javax.ws.rs.core.Application;
-import java.util.HashSet;
-import java.util.Set;
-
-public class InternalApplication extends Application {
-    private final Set<Class<?>> classes = new HashSet<Class<?>>();
-    private final Set<Object> singletons = new HashSet<Object>();
-    private final Application original;
-
-    public InternalApplication(final Application original) {
-        this.original = original;
-    }
-
-    @Override
-    public Set<Class<?>> getClasses() {
-        return classes;
-    }
-
-    @Override
-    public Set<Object> getSingletons() {
-        return singletons;
-    }
-
-    public Application getOriginal() {
-        return original;
-    }
-}
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ *     contributor license agreements.  See the NOTICE file distributed with
+ *     this work for additional information regarding copyright ownership.
+ *     The ASF licenses this file to You under the Apache License, Version 2.0
+ *     (the "License"); you may not use this file except in compliance with
+ *     the License.  You may obtain a copy of the License at
+ *
+ *        http://www.apache.org/licenses/LICENSE-2.0
+ *
+ *     Unless required by applicable law or agreed to in writing, software
+ *     distributed under the License is distributed on an "AS IS" BASIS,
+ *     WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ *     See the License for the specific language governing permissions and
+ *     limitations under the License.
+ */
+package org.apache.openejb.server.rest;
+
+import javax.ws.rs.core.Application;
+import java.util.HashSet;
+import java.util.Set;
+
+public class InternalApplication extends Application {
+    private final Set<Class<?>> classes = new HashSet<Class<?>>();
+    private final Set<Object> singletons = new HashSet<Object>();
+    private final Application original;
+
+    public InternalApplication(final Application original) {
+        this.original = original;
+    }
+
+    @Override
+    public Set<Class<?>> getClasses() {
+        return classes;
+    }
+
+    @Override
+    public Set<Object> getSingletons() {
+        return singletons;
+    }
+
+    public Application getOriginal() {
+        return original;
+    }
+}

http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/server/openejb-server/src/main/resources/META-INF/openejb-server.xml
----------------------------------------------------------------------
diff --git a/server/openejb-server/src/main/resources/META-INF/openejb-server.xml b/server/openejb-server/src/main/resources/META-INF/openejb-server.xml
index 42cd306..05473d9 100644
--- a/server/openejb-server/src/main/resources/META-INF/openejb-server.xml
+++ b/server/openejb-server/src/main/resources/META-INF/openejb-server.xml
@@ -1,36 +1,36 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-    
-    Licensed to the Apache Software Foundation (ASF) under one or more
-    contributor license agreements.  See the NOTICE file distributed with
-    this work for additional information regarding copyright ownership.
-    The ASF licenses this file to You under the Apache License, Version 2.0
-    (the "License"); you may not use this file except in compliance with
-    the License.  You may obtain a copy of the License at
-    
-        http://www.apache.org/licenses/LICENSE-2.0
-    
-    Unless required by applicable law or agreed to in writing, software
-    distributed under the License is distributed on an "AS IS" BASIS,
-    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-    See the License for the specific language governing permissions and
-    limitations under the License.
-    
--->
-
-<!-- $Rev$ $Date$ -->
-
-<beans xmlns:s="http://tomee.apache.org/schemas/server" xmlns:c="http://tomee.apache.org/schemas/core"
-    xmlns:l="http://tomee.apache.org/schemas/loader">
-    <s:server id="server" init-method="init">
-        <property name="serviceManager" ref="serviceManager" />
-        <property name="propertiesService" ref="propertiesService" />
-    </s:server>
-    <c:propertiesService id="propertiesService" />
-    <bean id="serviceManager" class="org.apache.openejb.server.ServiceManager" factory-method="getManager" />
-    <!--
-       - FIXME: The only singleton class with lots of static code - really hard to get it XBean-ized properly
-       - 
-    <l:system factory-method="get" init-method="init" />
-    -->
-</beans>
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+    
+    Licensed to the Apache Software Foundation (ASF) under one or more
+    contributor license agreements.  See the NOTICE file distributed with
+    this work for additional information regarding copyright ownership.
+    The ASF licenses this file to You under the Apache License, Version 2.0
+    (the "License"); you may not use this file except in compliance with
+    the License.  You may obtain a copy of the License at
+    
+        http://www.apache.org/licenses/LICENSE-2.0
+    
+    Unless required by applicable law or agreed to in writing, software
+    distributed under the License is distributed on an "AS IS" BASIS,
+    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+    See the License for the specific language governing permissions and
+    limitations under the License.
+    
+-->
+
+<!-- $Rev$ $Date$ -->
+
+<beans xmlns:s="http://tomee.apache.org/schemas/server" xmlns:c="http://tomee.apache.org/schemas/core"
+    xmlns:l="http://tomee.apache.org/schemas/loader">
+    <s:server id="server" init-method="init">
+        <property name="serviceManager" ref="serviceManager" />
+        <property name="propertiesService" ref="propertiesService" />
+    </s:server>
+    <c:propertiesService id="propertiesService" />
+    <bean id="serviceManager" class="org.apache.openejb.server.ServiceManager" factory-method="getManager" />
+    <!--
+       - FIXME: The only singleton class with lots of static code - really hard to get it XBean-ized properly
+       - 
+    <l:system factory-method="get" init-method="init" />
+    -->
+</beans>

http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/server/openejb-server/src/main/resources/META-INF/org.apache.openejb.cli/stop.help
----------------------------------------------------------------------
diff --git a/server/openejb-server/src/main/resources/META-INF/org.apache.openejb.cli/stop.help b/server/openejb-server/src/main/resources/META-INF/org.apache.openejb.cli/stop.help
index 9632aa8..ce00fe0 100644
--- a/server/openejb-server/src/main/resources/META-INF/org.apache.openejb.cli/stop.help
+++ b/server/openejb-server/src/main/resources/META-INF/org.apache.openejb.cli/stop.help
@@ -1,15 +1,15 @@
-Usage: openejb stop [options]
-
-Stops the OpenEJB Server running on host 127.0.0.1 and port 4201
-
-OPTIONS
- -h host    Stops the server at the specified host address
-            Default host is 127.0.0.1
- -p port    Stops the server running on the specified port. 
-            Default port is 4201.
-
-OpenEJB -- EJB Container System and EJB Server.
-For OpenEJB updates and additional information, visit
-http://tomee.apache.org
-
+Usage: openejb stop [options]
+
+Stops the OpenEJB Server running on host 127.0.0.1 and port 4201
+
+OPTIONS
+ -h host    Stops the server at the specified host address
+            Default host is 127.0.0.1
+ -p port    Stops the server running on the specified port. 
+            Default port is 4201.
+
+OpenEJB -- EJB Container System and EJB Server.
+For OpenEJB updates and additional information, visit
+http://tomee.apache.org
+
 Bug Reports to <us...@tomee.apache.org>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/src/main/style/checkstyle.xml
----------------------------------------------------------------------
diff --git a/src/main/style/checkstyle.xml b/src/main/style/checkstyle.xml
index 4cc9921..a1524f1 100644
--- a/src/main/style/checkstyle.xml
+++ b/src/main/style/checkstyle.xml
@@ -1,165 +1,165 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-  Licensed to the Apache Software Foundation (ASF) under one
-  or more contributor license agreements.  See the NOTICE file
-  distributed with this work for additional information
-  regarding copyright ownership.  The ASF licenses this file
-  to you under the Apache License, Version 2.0 (the
-  "License"); you may not use this file except in compliance
-  with the License.  You may obtain a copy of the License at
-
-  http://www.apache.org/licenses/LICENSE-2.0
-
-  Unless required by applicable law or agreed to in writing,
-  software distributed under the License is distributed on an
-  "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-  KIND, either express or implied.  See the License for the
-  specific language governing permissions and limitations
-  under the License.
--->
-<!DOCTYPE module PUBLIC
-    "-//Puppy Crawl//DTD Check Configuration 1.2//EN"
-    "http://www.puppycrawl.com/dtds/configuration_1_2.dtd">
-<module name="Checker">
-  <!--
-      If you set the basedir property below, then all reported file
-      names will be relative to the specified directory. See
-      http://checkstyle.sourceforge.net/5.x/config.html#Checker
-
-      <property name="basedir" value="${basedir}"/>
-  -->
-
-  <!-- Checks that property files contain the same keys.         -->
-  <!-- See http://checkstyle.sf.net/config_misc.html#Translation -->
-  <!--<module name="Translation"/>-->
-
-  <!--<module name="FileLength"/>-->
-
-  <!-- Following interprets the header file as regular expressions. -->
-  <!-- <module name="RegexpHeader"/>                                -->
-
-  <module name="SuppressWarningsFilter" />
-
-  <module name="FileTabCharacter">
-    <property name="eachLine" value="true"/>
-  </module>
-
-  <!--<module name="RegexpSingleline">-->
-    <!--&lt;!&ndash; \s matches whitespace character, $ matches end of line. &ndash;&gt;-->
-    <!--<property name="format" value="\s+$"/>-->
-    <!--<property name="message" value="Line has trailing spaces."/>-->
-  <!--</module>-->
-
-    <!-- Checks for Headers                                -->
-    <!-- See http://checkstyle.sf.net/config_header.html   -->
-     <!--<module name="Header">-->
-        <!--<property name="headerFile" value="${checkstyle.header.file}"/>-->
-         <!--<property name="fileExtensions" value="java"/>-->
-     <!--</module>-->
-
-  <module name="TreeWalker">
-    <module name="SuppressWarningsHolder" />
-
-    <property name="cacheFile" value="${checkstyle.cache.file}"/>
-
-    <!-- Checks for Javadoc comments.                     -->
-    <!-- See http://checkstyle.sf.net/config_javadoc.html -->
-    <!--<module name="JavadocMethod"/>-->
-    <!--<module name="JavadocType"/>-->
-    <!--<module name="JavadocVariable"/>-->
-    <!--<module name="JavadocStyle"/>-->
-
-
-    <!-- Checks for Naming Conventions.                  -->
-    <!-- See http://checkstyle.sf.net/config_naming.html -->
-    <!--<module name="ConstantName"/>-->
-    <module name="LocalFinalVariableName"/>
-    <module name="LocalVariableName"/>
-    <module name="MemberName"/>
-    <!--<module name="MethodName"/>-->
-    <module name="PackageName"/>
-    <module name="ParameterName"/>
-    <!--<module name="StaticVariableName"/>-->
-    <!--<module name="TypeName"/>-->
-
-
-    <!-- Checks for imports                              -->
-    <!-- See http://checkstyle.sf.net/config_import.html -->
-    <module name="IllegalImport"/>
-    <!-- defaults to sun.* packages -->
-    <module name="RedundantImport"/>
-    <module name="UnusedImports">
-      <property name="processJavadoc" value="true" />
-    </module>
-
-
-    <!-- Checks for Size Violations.                    -->
-    <!-- See http://checkstyle.sf.net/config_sizes.html -->
-    <!--<module name="LineLength">-->
-      <!--<property name="max" value="120"/>-->
-    <!--</module>-->
-    <!--<module name="MethodLength"/>-->
-    <!--<module name="ParameterNumber"/>-->
-
-
-    <!-- Checks for whitespace                               -->
-    <!-- See http://checkstyle.sf.net/config_whitespace.html -->
-    <!--<module name="EmptyForIteratorPad"/>-->
-    <!--<module name="MethodParamPad"/>-->
-    <!--<module name="NoWhitespaceAfter"/>-->
-    <!--<module name="NoWhitespaceBefore"/>-->
-    <!--<module name="OperatorWrap"/>-->
-    <!--<module name="ParenPad"/>-->
-    <!--<module name="TypecastParenPad"/>-->
-    <!--<module name="WhitespaceAfter"/>-->
-
-    <!-- Modifier Checks                                    -->
-    <!-- See http://checkstyle.sf.net/config_modifiers.html -->
-    <module name="ModifierOrder"/>
-    <module name="RedundantModifier"/>
-
-
-    <!-- Checks for blocks. You know, those {}'s         -->
-    <!-- See http://checkstyle.sf.net/config_blocks.html -->
-    <!--<module name="AvoidNestedBlocks"/>-->
-    <!--<module name="LeftCurly"/>-->
-    <module name="NeedBraces"/>
-    <!--<module name="RightCurly"/>-->
-
-
-    <!-- Checks for common coding problems               -->
-    <!-- See http://checkstyle.sf.net/config_coding.html -->
-    <!--<module name="EmptyStatement"/>-->
-    <!--<module name="EqualsHashCode"/>-->
-    <!--<module name="HiddenField">-->
-      <!--<property name="ignoreSetter" value="true"/>-->
-    <!--</module>-->
-    <module name="IllegalInstantiation"/>
-    <!--<module name="InnerAssignment"/>-->
-    <!--<module name="MagicNumber">-->
-      <!--<property name="ignoreHashCodeMethod" value="true"/>-->
-    <!--</module>-->
-    <!--<module name="MissingSwitchDefault"/>-->
-    <!--<module name="RedundantThrows"/>-->
-    <module name="SimplifyBooleanExpression"/>
-    <module name="SimplifyBooleanReturn"/>
-
-    <!-- Checks for class design                         -->
-    <!-- See http://checkstyle.sf.net/config_design.html -->
-    <module name="FinalClass"/>
-    <!--<module name="HideUtilityClassConstructor"/>-->
-    <!--<module name="InterfaceIsType"/>-->
-    <!--<module name="VisibilityModifier">-->
-      <!--<property name="packageAllowed" value="true"/>-->
-      <!--<property name="protectedAllowed" value="true"/>-->
-    <!--</module>-->
-
-    <!-- Miscellaneous other checks.                   -->
-    <!-- See http://checkstyle.sf.net/config_misc.html -->
-    <module name="ArrayTypeStyle"/>
-    <!--<module name="TodoComment"/>-->
-    <!--<module name="UpperEll"/>-->
-
-  </module>
-
-</module>
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+  Licensed to the Apache Software Foundation (ASF) under one
+  or more contributor license agreements.  See the NOTICE file
+  distributed with this work for additional information
+  regarding copyright ownership.  The ASF licenses this file
+  to you under the Apache License, Version 2.0 (the
+  "License"); you may not use this file except in compliance
+  with the License.  You may obtain a copy of the License at
+
+  http://www.apache.org/licenses/LICENSE-2.0
+
+  Unless required by applicable law or agreed to in writing,
+  software distributed under the License is distributed on an
+  "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+  KIND, either express or implied.  See the License for the
+  specific language governing permissions and limitations
+  under the License.
+-->
+<!DOCTYPE module PUBLIC
+    "-//Puppy Crawl//DTD Check Configuration 1.2//EN"
+    "http://www.puppycrawl.com/dtds/configuration_1_2.dtd">
+<module name="Checker">
+  <!--
+      If you set the basedir property below, then all reported file
+      names will be relative to the specified directory. See
+      http://checkstyle.sourceforge.net/5.x/config.html#Checker
+
+      <property name="basedir" value="${basedir}"/>
+  -->
+
+  <!-- Checks that property files contain the same keys.         -->
+  <!-- See http://checkstyle.sf.net/config_misc.html#Translation -->
+  <!--<module name="Translation"/>-->
+
+  <!--<module name="FileLength"/>-->
+
+  <!-- Following interprets the header file as regular expressions. -->
+  <!-- <module name="RegexpHeader"/>                                -->
+
+  <module name="SuppressWarningsFilter" />
+
+  <module name="FileTabCharacter">
+    <property name="eachLine" value="true"/>
+  </module>
+
+  <!--<module name="RegexpSingleline">-->
+    <!--&lt;!&ndash; \s matches whitespace character, $ matches end of line. &ndash;&gt;-->
+    <!--<property name="format" value="\s+$"/>-->
+    <!--<property name="message" value="Line has trailing spaces."/>-->
+  <!--</module>-->
+
+    <!-- Checks for Headers                                -->
+    <!-- See http://checkstyle.sf.net/config_header.html   -->
+     <!--<module name="Header">-->
+        <!--<property name="headerFile" value="${checkstyle.header.file}"/>-->
+         <!--<property name="fileExtensions" value="java"/>-->
+     <!--</module>-->
+
+  <module name="TreeWalker">
+    <module name="SuppressWarningsHolder" />
+
+    <property name="cacheFile" value="${checkstyle.cache.file}"/>
+
+    <!-- Checks for Javadoc comments.                     -->
+    <!-- See http://checkstyle.sf.net/config_javadoc.html -->
+    <!--<module name="JavadocMethod"/>-->
+    <!--<module name="JavadocType"/>-->
+    <!--<module name="JavadocVariable"/>-->
+    <!--<module name="JavadocStyle"/>-->
+
+
+    <!-- Checks for Naming Conventions.                  -->
+    <!-- See http://checkstyle.sf.net/config_naming.html -->
+    <!--<module name="ConstantName"/>-->
+    <module name="LocalFinalVariableName"/>
+    <module name="LocalVariableName"/>
+    <module name="MemberName"/>
+    <!--<module name="MethodName"/>-->
+    <module name="PackageName"/>
+    <module name="ParameterName"/>
+    <!--<module name="StaticVariableName"/>-->
+    <!--<module name="TypeName"/>-->
+
+
+    <!-- Checks for imports                              -->
+    <!-- See http://checkstyle.sf.net/config_import.html -->
+    <module name="IllegalImport"/>
+    <!-- defaults to sun.* packages -->
+    <module name="RedundantImport"/>
+    <module name="UnusedImports">
+      <property name="processJavadoc" value="true" />
+    </module>
+
+
+    <!-- Checks for Size Violations.                    -->
+    <!-- See http://checkstyle.sf.net/config_sizes.html -->
+    <!--<module name="LineLength">-->
+      <!--<property name="max" value="120"/>-->
+    <!--</module>-->
+    <!--<module name="MethodLength"/>-->
+    <!--<module name="ParameterNumber"/>-->
+
+
+    <!-- Checks for whitespace                               -->
+    <!-- See http://checkstyle.sf.net/config_whitespace.html -->
+    <!--<module name="EmptyForIteratorPad"/>-->
+    <!--<module name="MethodParamPad"/>-->
+    <!--<module name="NoWhitespaceAfter"/>-->
+    <!--<module name="NoWhitespaceBefore"/>-->
+    <!--<module name="OperatorWrap"/>-->
+    <!--<module name="ParenPad"/>-->
+    <!--<module name="TypecastParenPad"/>-->
+    <!--<module name="WhitespaceAfter"/>-->
+
+    <!-- Modifier Checks                                    -->
+    <!-- See http://checkstyle.sf.net/config_modifiers.html -->
+    <module name="ModifierOrder"/>
+    <module name="RedundantModifier"/>
+
+
+    <!-- Checks for blocks. You know, those {}'s         -->
+    <!-- See http://checkstyle.sf.net/config_blocks.html -->
+    <!--<module name="AvoidNestedBlocks"/>-->
+    <!--<module name="LeftCurly"/>-->
+    <module name="NeedBraces"/>
+    <!--<module name="RightCurly"/>-->
+
+
+    <!-- Checks for common coding problems               -->
+    <!-- See http://checkstyle.sf.net/config_coding.html -->
+    <!--<module name="EmptyStatement"/>-->
+    <!--<module name="EqualsHashCode"/>-->
+    <!--<module name="HiddenField">-->
+      <!--<property name="ignoreSetter" value="true"/>-->
+    <!--</module>-->
+    <module name="IllegalInstantiation"/>
+    <!--<module name="InnerAssignment"/>-->
+    <!--<module name="MagicNumber">-->
+      <!--<property name="ignoreHashCodeMethod" value="true"/>-->
+    <!--</module>-->
+    <!--<module name="MissingSwitchDefault"/>-->
+    <!--<module name="RedundantThrows"/>-->
+    <module name="SimplifyBooleanExpression"/>
+    <module name="SimplifyBooleanReturn"/>
+
+    <!-- Checks for class design                         -->
+    <!-- See http://checkstyle.sf.net/config_design.html -->
+    <module name="FinalClass"/>
+    <!--<module name="HideUtilityClassConstructor"/>-->
+    <!--<module name="InterfaceIsType"/>-->
+    <!--<module name="VisibilityModifier">-->
+      <!--<property name="packageAllowed" value="true"/>-->
+      <!--<property name="protectedAllowed" value="true"/>-->
+    <!--</module>-->
+
+    <!-- Miscellaneous other checks.                   -->
+    <!-- See http://checkstyle.sf.net/config_misc.html -->
+    <module name="ArrayTypeStyle"/>
+    <!--<module name="TodoComment"/>-->
+    <!--<module name="UpperEll"/>-->
+
+  </module>
+
+</module>

http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/tck/tck-common/src/main/java/org/apache/openejb/tck/util/ServerLocal.java
----------------------------------------------------------------------
diff --git a/tck/tck-common/src/main/java/org/apache/openejb/tck/util/ServerLocal.java b/tck/tck-common/src/main/java/org/apache/openejb/tck/util/ServerLocal.java
index 856c429..422b12b 100644
--- a/tck/tck-common/src/main/java/org/apache/openejb/tck/util/ServerLocal.java
+++ b/tck/tck-common/src/main/java/org/apache/openejb/tck/util/ServerLocal.java
@@ -1,50 +1,50 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.openejb.tck.util;
-
-import org.apache.tomee.util.QuickServerXmlParser;
-
-import java.io.File;
-
-public class ServerLocal {
-
-    private ServerLocal() {
-    }
-
-    /**
-     * If the TCK is running against a local server extracted to the target dir
-     * then the server.xml will have the port defined already.
-     *
-     * @param def Default port to use if none is found
-     * @return The determined port, the value of 'server.http.port' or the provided default
-     */
-    public static int getPort(final int def) {
-        final String home = System.getProperty("openejb.home", "empty");
-
-        if (!"empty".equals(home)) {
-            final File serverXml = new File(home, "conf/server.xml");
-
-            if (serverXml.exists() && serverXml.isFile()) {
-                final QuickServerXmlParser parser = QuickServerXmlParser.parse(serverXml);
-
-                return Integer.parseInt(parser.http());
-            }
-        }
-
-        return Integer.getInteger("server.http.port", def);
-    }
-}
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.openejb.tck.util;
+
+import org.apache.tomee.util.QuickServerXmlParser;
+
+import java.io.File;
+
+public class ServerLocal {
+
+    private ServerLocal() {
+    }
+
+    /**
+     * If the TCK is running against a local server extracted to the target dir
+     * then the server.xml will have the port defined already.
+     *
+     * @param def Default port to use if none is found
+     * @return The determined port, the value of 'server.http.port' or the provided default
+     */
+    public static int getPort(final int def) {
+        final String home = System.getProperty("openejb.home", "empty");
+
+        if (!"empty".equals(home)) {
+            final File serverXml = new File(home, "conf/server.xml");
+
+            if (serverXml.exists() && serverXml.isFile()) {
+                final QuickServerXmlParser parser = QuickServerXmlParser.parse(serverXml);
+
+                return Integer.parseInt(parser.http());
+            }
+        }
+
+        return Integer.getInteger("server.http.port", def);
+    }
+}

http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/tomee/apache-tomee/src/main/resources/service.install.as.admin.bat
----------------------------------------------------------------------
diff --git a/tomee/apache-tomee/src/main/resources/service.install.as.admin.bat b/tomee/apache-tomee/src/main/resources/service.install.as.admin.bat
index 8569a4d..dcfbe6b 100644
--- a/tomee/apache-tomee/src/main/resources/service.install.as.admin.bat
+++ b/tomee/apache-tomee/src/main/resources/service.install.as.admin.bat
@@ -1,33 +1,33 @@
-@echo off
-cls
-REM================================================
-REM Licensed to the Apache Software Foundation (ASF) under one or more
-REM contributor license agreements.  See the NOTICE file distributed with
-REM this work for additional information regarding copyright ownership.
-REM The ASF licenses this file to You under the Apache License, Version 2.0
-REM (the "License"); you may not use this file except in compliance with
-REM the License.  You may obtain a copy of the License at
-REM
-REM    http://www.apache.org/licenses/LICENSE-2.0
-REM
-REM Unless required by applicable law or agreed to in writing, software
-REM distributed under the License is distributed on an "AS IS" BASIS,
-REM WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-REM See the License for the specific language governing permissions and
-REM limitations under the License.
-REM _______________________________________________
-REM $Rev$
-REM================================================
-
-@if not "%ECHO%" == ""  echo %ECHO%
-@if "%OS%" == "Windows_NT" setlocal
-
-if "%OS%" == "Windows_NT" (
-  set "DIRNAME=%~dp0%"
-) else (
-  set DIRNAME=.\
-)
-
-pushd %DIRNAME%
-
+@echo off
+cls
+REM================================================
+REM Licensed to the Apache Software Foundation (ASF) under one or more
+REM contributor license agreements.  See the NOTICE file distributed with
+REM this work for additional information regarding copyright ownership.
+REM The ASF licenses this file to You under the Apache License, Version 2.0
+REM (the "License"); you may not use this file except in compliance with
+REM the License.  You may obtain a copy of the License at
+REM
+REM    http://www.apache.org/licenses/LICENSE-2.0
+REM
+REM Unless required by applicable law or agreed to in writing, software
+REM distributed under the License is distributed on an "AS IS" BASIS,
+REM WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+REM See the License for the specific language governing permissions and
+REM limitations under the License.
+REM _______________________________________________
+REM $Rev$
+REM================================================
+
+@if not "%ECHO%" == ""  echo %ECHO%
+@if "%OS%" == "Windows_NT" setlocal
+
+if "%OS%" == "Windows_NT" (
+  set "DIRNAME=%~dp0%"
+) else (
+  set DIRNAME=.\
+)
+
+pushd %DIRNAME%
+
 service install
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/tomee/apache-tomee/src/main/resources/service.remove.as.admin.bat
----------------------------------------------------------------------
diff --git a/tomee/apache-tomee/src/main/resources/service.remove.as.admin.bat b/tomee/apache-tomee/src/main/resources/service.remove.as.admin.bat
index 3b5d4ac..bc5fe0a 100644
--- a/tomee/apache-tomee/src/main/resources/service.remove.as.admin.bat
+++ b/tomee/apache-tomee/src/main/resources/service.remove.as.admin.bat
@@ -1,33 +1,33 @@
-@echo off
-cls
-REM================================================
-REM Licensed to the Apache Software Foundation (ASF) under one or more
-REM contributor license agreements.  See the NOTICE file distributed with
-REM this work for additional information regarding copyright ownership.
-REM The ASF licenses this file to You under the Apache License, Version 2.0
-REM (the "License"); you may not use this file except in compliance with
-REM the License.  You may obtain a copy of the License at
-REM
-REM    http://www.apache.org/licenses/LICENSE-2.0
-REM
-REM Unless required by applicable law or agreed to in writing, software
-REM distributed under the License is distributed on an "AS IS" BASIS,
-REM WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-REM See the License for the specific language governing permissions and
-REM limitations under the License.
-REM _______________________________________________
-REM $Rev$
-REM================================================
-
-@if not "%ECHO%" == ""  echo %ECHO%
-@if "%OS%" == "Windows_NT" setlocal
-
-if "%OS%" == "Windows_NT" (
-  set "DIRNAME=%~dp0%"
-) else (
-  set DIRNAME=.\
-)
-
-pushd %DIRNAME%
-
+@echo off
+cls
+REM================================================
+REM Licensed to the Apache Software Foundation (ASF) under one or more
+REM contributor license agreements.  See the NOTICE file distributed with
+REM this work for additional information regarding copyright ownership.
+REM The ASF licenses this file to You under the Apache License, Version 2.0
+REM (the "License"); you may not use this file except in compliance with
+REM the License.  You may obtain a copy of the License at
+REM
+REM    http://www.apache.org/licenses/LICENSE-2.0
+REM
+REM Unless required by applicable law or agreed to in writing, software
+REM distributed under the License is distributed on an "AS IS" BASIS,
+REM WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+REM See the License for the specific language governing permissions and
+REM limitations under the License.
+REM _______________________________________________
+REM $Rev$
+REM================================================
+
+@if not "%ECHO%" == ""  echo %ECHO%
+@if "%OS%" == "Windows_NT" setlocal
+
+if "%OS%" == "Windows_NT" (
+  set "DIRNAME=%~dp0%"
+) else (
+  set DIRNAME=.\
+)
+
+pushd %DIRNAME%
+
 service remove
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/tomee/tomee-catalina/src/main/java/org/apache/tomee/catalina/TomcatDeploymentLoader.java
----------------------------------------------------------------------
diff --git a/tomee/tomee-catalina/src/main/java/org/apache/tomee/catalina/TomcatDeploymentLoader.java b/tomee/tomee-catalina/src/main/java/org/apache/tomee/catalina/TomcatDeploymentLoader.java
index 03fea68..4496e54 100644
--- a/tomee/tomee-catalina/src/main/java/org/apache/tomee/catalina/TomcatDeploymentLoader.java
+++ b/tomee/tomee-catalina/src/main/java/org/apache/tomee/catalina/TomcatDeploymentLoader.java
@@ -1,43 +1,43 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.tomee.catalina;
-
-import org.apache.catalina.core.StandardContext;
-import org.apache.openejb.config.DeploymentLoader;
-
-/**
- * @version $Id$
- */
-public class TomcatDeploymentLoader extends DeploymentLoader {
-    private StandardContext standardContext;
-    private String moduleId;
-
-    public TomcatDeploymentLoader(final StandardContext standardContext, final String moduleId) {
-        this.standardContext = standardContext;
-        this.moduleId = moduleId;
-    }
-
-    @Override
-    protected String getContextRoot() {
-        return standardContext.getPath();
-    }
-
-    @Override
-    protected String getModuleName() {
-        return moduleId;
-    }
-}
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.tomee.catalina;
+
+import org.apache.catalina.core.StandardContext;
+import org.apache.openejb.config.DeploymentLoader;
+
+/**
+ * @version $Id$
+ */
+public class TomcatDeploymentLoader extends DeploymentLoader {
+    private StandardContext standardContext;
+    private String moduleId;
+
+    public TomcatDeploymentLoader(final StandardContext standardContext, final String moduleId) {
+        this.standardContext = standardContext;
+        this.moduleId = moduleId;
+    }
+
+    @Override
+    protected String getContextRoot() {
+        return standardContext.getPath();
+    }
+
+    @Override
+    protected String getModuleName() {
+        return moduleId;
+    }
+}


[2/2] tomee git commit: Saving files before refreshing line endings

Posted by an...@apache.org.
Saving files before refreshing line endings


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

Branch: refs/heads/tomee-1.7.3-prepare
Commit: 81d3cd3ac38247179c56ff150a72f52fa7e5330a
Parents: ba185f5
Author: andy.is@gmx.de <an...@gmx.de>
Authored: Tue Nov 24 19:11:59 2015 +0100
Committer: andy.is@gmx.de <an...@gmx.de>
Committed: Tue Nov 24 19:11:59 2015 +0100

----------------------------------------------------------------------
 .../keys/generateKeyPair.bat                    |   62 +-
 .../keys/generateServerKey.bat                  |   48 +-
 .../CalculatorImplSign-server.properties        |   14 +-
 ...eTokenPlainPasswordEncrypt-server.properties |   14 +-
 .../src/main/resources/META-INF/ejb-jar.xml     |  198 ++--
 .../src/main/resources/META-INF/webservices.xml |  132 +--
 .../CalculatorImplSign-client.properties        |   14 +-
 ...eTokenPlainPasswordEncrypt-client.properties |   14 +-
 .../maven/plugin/AbstractSynchronizable.java    |  142 +--
 .../test/resources/schema/ComplexAllElement.xsd |   42 +-
 .../test/resources/schema/ComplexAllType.xsd    |   42 +-
 .../resources/schema/ComplexSequenceElement.xsd |   42 +-
 .../resources/schema/ComplexSequenceType.xsd    |   42 +-
 .../test/resources/schema/JaxRpcSpecExample.xsd |   42 +-
 .../src/test/resources/schema/SimpleElement.xsd |   42 +-
 .../src/test/resources/schema/SimpleType.xsd    |   42 +-
 .../resources/schema/SoapArrayByAttribute.xsd   |   42 +-
 .../resources/schema/SoapArrayByRestriction.xsd |   42 +-
 .../openejb/server/cxf/rs/PojoInvoker.java      |  124 +--
 .../server/cxf/fault/AuthenticatorService.java  |   60 +-
 .../src/test/resources/META-INF/ejb-jar.xml     |   36 +-
 .../apache/openejb/server/cxf/fault/handler.xml |   52 +-
 .../openejb/server/ejbd/RequestHandler.java     |   90 +-
 .../multipulse                                  |    6 +-
 .../discovery/MulticastPulseAgentTest.java      | 1026 +++++++++---------
 .../server/rest/InternalApplication.java        |   90 +-
 .../main/resources/META-INF/openejb-server.xml  |   72 +-
 .../META-INF/org.apache.openejb.cli/stop.help   |   28 +-
 src/main/style/checkstyle.xml                   |  330 +++---
 .../apache/openejb/tck/util/ServerLocal.java    |  100 +-
 .../main/resources/service.install.as.admin.bat |   64 +-
 .../main/resources/service.remove.as.admin.bat  |   64 +-
 .../tomee/catalina/TomcatDeploymentLoader.java  |   86 +-
 33 files changed, 1622 insertions(+), 1622 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/examples/webservice-ws-security/keys/generateKeyPair.bat
----------------------------------------------------------------------
diff --git a/examples/webservice-ws-security/keys/generateKeyPair.bat b/examples/webservice-ws-security/keys/generateKeyPair.bat
index ac58c92..48670b2 100644
--- a/examples/webservice-ws-security/keys/generateKeyPair.bat
+++ b/examples/webservice-ws-security/keys/generateKeyPair.bat
@@ -1,31 +1,31 @@
-@echo off
-REM================================================
-REM Licensed to the Apache Software Foundation (ASF) under one or more
-REM contributor license agreements.  See the NOTICE file distributed with
-REM this work for additional information regarding copyright ownership.
-REM The ASF licenses this file to You under the Apache License, Version 2.0
-REM (the "License"); you may not use this file except in compliance with
-REM the License.  You may obtain a copy of the License at
-REM
-REM    http://www.apache.org/licenses/LICENSE-2.0
-REM
-REM Unless required by applicable law or agreed to in writing, software
-REM distributed under the License is distributed on an "AS IS" BASIS,
-REM WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-REM See the License for the specific language governing permissions and
-REM limitations under the License.
-REM _______________________________________________
-REM $Rev: 636963 $ $Date: 2008-03-13 19:40:08 -0700 (Thu, 13 Mar 2008) $
-REM================================================
-
-rem @echo off
-echo alias %1
-echo keypass %2
-echo keystoreName %3
-echo KeyStorePass %4
-echo keyName %5
-
-echo keyName %5
-keytool -genkey -alias %1 -keypass %2 -keystore "%3" -storepass %4  -dname "cn=%1" -keyalg RSA
-keytool -selfcert -alias %1 -keystore "%3" -storepass %4 -keypass %2
-keytool -export -alias %1 -file %5 -keystore "%3" -storepass %4
+@echo off
+REM================================================
+REM Licensed to the Apache Software Foundation (ASF) under one or more
+REM contributor license agreements.  See the NOTICE file distributed with
+REM this work for additional information regarding copyright ownership.
+REM The ASF licenses this file to You under the Apache License, Version 2.0
+REM (the "License"); you may not use this file except in compliance with
+REM the License.  You may obtain a copy of the License at
+REM
+REM    http://www.apache.org/licenses/LICENSE-2.0
+REM
+REM Unless required by applicable law or agreed to in writing, software
+REM distributed under the License is distributed on an "AS IS" BASIS,
+REM WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+REM See the License for the specific language governing permissions and
+REM limitations under the License.
+REM _______________________________________________
+REM $Rev: 636963 $ $Date: 2008-03-13 19:40:08 -0700 (Thu, 13 Mar 2008) $
+REM================================================
+
+rem @echo off
+echo alias %1
+echo keypass %2
+echo keystoreName %3
+echo KeyStorePass %4
+echo keyName %5
+
+echo keyName %5
+keytool -genkey -alias %1 -keypass %2 -keystore "%3" -storepass %4  -dname "cn=%1" -keyalg RSA
+keytool -selfcert -alias %1 -keystore "%3" -storepass %4 -keypass %2
+keytool -export -alias %1 -file %5 -keystore "%3" -storepass %4

http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/examples/webservice-ws-security/keys/generateServerKey.bat
----------------------------------------------------------------------
diff --git a/examples/webservice-ws-security/keys/generateServerKey.bat b/examples/webservice-ws-security/keys/generateServerKey.bat
index 8ce997b..8be96bb 100644
--- a/examples/webservice-ws-security/keys/generateServerKey.bat
+++ b/examples/webservice-ws-security/keys/generateServerKey.bat
@@ -1,24 +1,24 @@
-@echo off
-REM================================================
-REM Licensed to the Apache Software Foundation (ASF) under one or more
-REM contributor license agreements.  See the NOTICE file distributed with
-REM this work for additional information regarding copyright ownership.
-REM The ASF licenses this file to You under the Apache License, Version 2.0
-REM (the "License"); you may not use this file except in compliance with
-REM the License.  You may obtain a copy of the License at
-REM
-REM    http://www.apache.org/licenses/LICENSE-2.0
-REM
-REM Unless required by applicable law or agreed to in writing, software
-REM distributed under the License is distributed on an "AS IS" BASIS,
-REM WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-REM See the License for the specific language governing permissions and
-REM limitations under the License.
-REM _______________________________________________
-REM $Rev: 636963 $ $Date: 2008-03-13 19:40:08 -0700 (Thu, 13 Mar 2008) $
-REM================================================
-
-call generateKeyPair.bat serveralias serverPassword serverStore.jks keystorePass serverKey.rsa
-call generateKeyPair.bat clientalias  clientPassword  clientStore.jks keystorePass clientKey.rsa
-keytool -import -alias serveralias -file serverKey.rsa -keystore clientStore.jks -storepass keystorePass -noprompt
-keytool -import -alias clientalias -file clientKey.rsa -keystore serverStore.jks -storepass keystorePass -noprompt
+@echo off
+REM================================================
+REM Licensed to the Apache Software Foundation (ASF) under one or more
+REM contributor license agreements.  See the NOTICE file distributed with
+REM this work for additional information regarding copyright ownership.
+REM The ASF licenses this file to You under the Apache License, Version 2.0
+REM (the "License"); you may not use this file except in compliance with
+REM the License.  You may obtain a copy of the License at
+REM
+REM    http://www.apache.org/licenses/LICENSE-2.0
+REM
+REM Unless required by applicable law or agreed to in writing, software
+REM distributed under the License is distributed on an "AS IS" BASIS,
+REM WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+REM See the License for the specific language governing permissions and
+REM limitations under the License.
+REM _______________________________________________
+REM $Rev: 636963 $ $Date: 2008-03-13 19:40:08 -0700 (Thu, 13 Mar 2008) $
+REM================================================
+
+call generateKeyPair.bat serveralias serverPassword serverStore.jks keystorePass serverKey.rsa
+call generateKeyPair.bat clientalias  clientPassword  clientStore.jks keystorePass clientKey.rsa
+keytool -import -alias serveralias -file serverKey.rsa -keystore clientStore.jks -storepass keystorePass -noprompt
+keytool -import -alias clientalias -file clientKey.rsa -keystore serverStore.jks -storepass keystorePass -noprompt

http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/examples/webservice-ws-security/src/main/resources/META-INF/CalculatorImplSign-server.properties
----------------------------------------------------------------------
diff --git a/examples/webservice-ws-security/src/main/resources/META-INF/CalculatorImplSign-server.properties b/examples/webservice-ws-security/src/main/resources/META-INF/CalculatorImplSign-server.properties
index 5b36649..4df5b2e 100644
--- a/examples/webservice-ws-security/src/main/resources/META-INF/CalculatorImplSign-server.properties
+++ b/examples/webservice-ws-security/src/main/resources/META-INF/CalculatorImplSign-server.properties
@@ -1,7 +1,7 @@
-org.apache.ws.security.crypto.provider=org.apache.ws.security.components.crypto.Merlin
-org.apache.ws.security.crypto.merlin.keystore.type=jks
-org.apache.ws.security.crypto.merlin.keystore.password=keystorePass
-org.apache.ws.security.crypto.merlin.keystore.alias=serveralias
-org.apache.ws.security.crypto.merlin.file=META-INF/serverStore.jks
-# OPENEJB-1061 OpenJDK doesn't come with cacerts
-org.apache.ws.security.crypto.merlin.load.cacerts=false
+org.apache.ws.security.crypto.provider=org.apache.ws.security.components.crypto.Merlin
+org.apache.ws.security.crypto.merlin.keystore.type=jks
+org.apache.ws.security.crypto.merlin.keystore.password=keystorePass
+org.apache.ws.security.crypto.merlin.keystore.alias=serveralias
+org.apache.ws.security.crypto.merlin.file=META-INF/serverStore.jks
+# OPENEJB-1061 OpenJDK doesn't come with cacerts
+org.apache.ws.security.crypto.merlin.load.cacerts=false

http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/examples/webservice-ws-security/src/main/resources/META-INF/CalculatorImplUsernameTokenPlainPasswordEncrypt-server.properties
----------------------------------------------------------------------
diff --git a/examples/webservice-ws-security/src/main/resources/META-INF/CalculatorImplUsernameTokenPlainPasswordEncrypt-server.properties b/examples/webservice-ws-security/src/main/resources/META-INF/CalculatorImplUsernameTokenPlainPasswordEncrypt-server.properties
index 5b36649..4df5b2e 100644
--- a/examples/webservice-ws-security/src/main/resources/META-INF/CalculatorImplUsernameTokenPlainPasswordEncrypt-server.properties
+++ b/examples/webservice-ws-security/src/main/resources/META-INF/CalculatorImplUsernameTokenPlainPasswordEncrypt-server.properties
@@ -1,7 +1,7 @@
-org.apache.ws.security.crypto.provider=org.apache.ws.security.components.crypto.Merlin
-org.apache.ws.security.crypto.merlin.keystore.type=jks
-org.apache.ws.security.crypto.merlin.keystore.password=keystorePass
-org.apache.ws.security.crypto.merlin.keystore.alias=serveralias
-org.apache.ws.security.crypto.merlin.file=META-INF/serverStore.jks
-# OPENEJB-1061 OpenJDK doesn't come with cacerts
-org.apache.ws.security.crypto.merlin.load.cacerts=false
+org.apache.ws.security.crypto.provider=org.apache.ws.security.components.crypto.Merlin
+org.apache.ws.security.crypto.merlin.keystore.type=jks
+org.apache.ws.security.crypto.merlin.keystore.password=keystorePass
+org.apache.ws.security.crypto.merlin.keystore.alias=serveralias
+org.apache.ws.security.crypto.merlin.file=META-INF/serverStore.jks
+# OPENEJB-1061 OpenJDK doesn't come with cacerts
+org.apache.ws.security.crypto.merlin.load.cacerts=false

http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/examples/webservice-ws-security/src/main/resources/META-INF/ejb-jar.xml
----------------------------------------------------------------------
diff --git a/examples/webservice-ws-security/src/main/resources/META-INF/ejb-jar.xml b/examples/webservice-ws-security/src/main/resources/META-INF/ejb-jar.xml
index 19cd263..ca04771 100644
--- a/examples/webservice-ws-security/src/main/resources/META-INF/ejb-jar.xml
+++ b/examples/webservice-ws-security/src/main/resources/META-INF/ejb-jar.xml
@@ -1,99 +1,99 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-
-    Licensed to the Apache Software Foundation (ASF) under one or more
-    contributor license agreements.  See the NOTICE file distributed with
-    this work for additional information regarding copyright ownership.
-    The ASF licenses this file to You under the Apache License, Version 2.0
-    (the "License"); you may not use this file except in compliance with
-    the License.  You may obtain a copy of the License at
-
-       http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing, software
-    distributed under the License is distributed on an "AS IS" BASIS,
-    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-    See the License for the specific language governing permissions and
-    limitations under the License.
--->
-<ejb-jar xmlns="http://java.sun.com/xml/ns/javaee" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-         xsi:schemaLocation="http://java.sun.com/xml/ns/javaee http://java.sun.com/xml/ns/javaee/ejb-jar_3_0.xsd"
-         version="3.0" id="webservice-ws-security" metadata-complete="false">
-
-  <enterprise-beans>
-
-    <session>
-      <ejb-name>CalculatorImplTimestamp1way</ejb-name>
-      <service-endpoint>org.superbiz.calculator.CalculatorWs</service-endpoint>
-      <ejb-class>org.superbiz.calculator.CalculatorImpl</ejb-class>
-      <session-type>Stateless</session-type>
-      <transaction-type>Container</transaction-type>
-    </session>
-
-    <session>
-      <ejb-name>CalculatorImplTimestamp2ways</ejb-name>
-      <service-endpoint>org.superbiz.calculator.CalculatorWs</service-endpoint>
-      <ejb-class>org.superbiz.calculator.CalculatorImpl</ejb-class>
-      <session-type>Stateless</session-type>
-      <transaction-type>Container</transaction-type>
-    </session>
-
-    <session>
-      <ejb-name>CalculatorImplUsernameTokenPlainPassword</ejb-name>
-      <service-endpoint>org.superbiz.calculator.CalculatorWs</service-endpoint>
-      <ejb-class>org.superbiz.calculator.CalculatorImpl</ejb-class>
-      <session-type>Stateless</session-type>
-      <transaction-type>Container</transaction-type>
-    </session>
-
-    <session>
-      <ejb-name>CalculatorImplUsernameTokenHashedPassword</ejb-name>
-      <service-endpoint>org.superbiz.calculator.CalculatorWs</service-endpoint>
-      <ejb-class>org.superbiz.calculator.CalculatorImpl</ejb-class>
-      <session-type>Stateless</session-type>
-      <transaction-type>Container</transaction-type>
-    </session>
-
-    <session>
-      <ejb-name>CalculatorImplUsernameTokenPlainPasswordEncrypt</ejb-name>
-      <service-endpoint>org.superbiz.calculator.CalculatorWs</service-endpoint>
-      <ejb-class>org.superbiz.calculator.CalculatorImpl</ejb-class>
-      <session-type>Stateless</session-type>
-      <transaction-type>Container</transaction-type>
-    </session>
-
-    <session>
-      <ejb-name>CalculatorImplSign</ejb-name>
-      <service-endpoint>org.superbiz.calculator.CalculatorWs</service-endpoint>
-      <ejb-class>org.superbiz.calculator.CalculatorImpl</ejb-class>
-      <session-type>Stateless</session-type>
-      <transaction-type>Container</transaction-type>
-    </session>
-
-    <session>
-      <ejb-name>CalculatorImplEncrypt2ways</ejb-name>
-      <service-endpoint>org.superbiz.calculator.CalculatorWs</service-endpoint>
-      <ejb-class>org.superbiz.calculator.CalculatorImpl</ejb-class>
-      <session-type>Stateless</session-type>
-      <transaction-type>Container</transaction-type>
-    </session>
-
-    <session>
-      <ejb-name>CalculatorImplSign2ways</ejb-name>
-      <service-endpoint>org.superbiz.calculator.CalculatorWs</service-endpoint>
-      <ejb-class>org.superbiz.calculator.CalculatorImpl</ejb-class>
-      <session-type>Stateless</session-type>
-      <transaction-type>Container</transaction-type>
-    </session>
-
-    <session>
-      <ejb-name>CalculatorImplEncryptAndSign2ways</ejb-name>
-      <service-endpoint>org.superbiz.calculator.CalculatorWs</service-endpoint>
-      <ejb-class>org.superbiz.calculator.CalculatorImpl</ejb-class>
-      <session-type>Stateless</session-type>
-      <transaction-type>Container</transaction-type>
-    </session>
-
-  </enterprise-beans>
-
-</ejb-jar>
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+
+    Licensed to the Apache Software Foundation (ASF) under one or more
+    contributor license agreements.  See the NOTICE file distributed with
+    this work for additional information regarding copyright ownership.
+    The ASF licenses this file to You under the Apache License, Version 2.0
+    (the "License"); you may not use this file except in compliance with
+    the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+    Unless required by applicable law or agreed to in writing, software
+    distributed under the License is distributed on an "AS IS" BASIS,
+    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+    See the License for the specific language governing permissions and
+    limitations under the License.
+-->
+<ejb-jar xmlns="http://java.sun.com/xml/ns/javaee" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+         xsi:schemaLocation="http://java.sun.com/xml/ns/javaee http://java.sun.com/xml/ns/javaee/ejb-jar_3_0.xsd"
+         version="3.0" id="webservice-ws-security" metadata-complete="false">
+
+  <enterprise-beans>
+
+    <session>
+      <ejb-name>CalculatorImplTimestamp1way</ejb-name>
+      <service-endpoint>org.superbiz.calculator.CalculatorWs</service-endpoint>
+      <ejb-class>org.superbiz.calculator.CalculatorImpl</ejb-class>
+      <session-type>Stateless</session-type>
+      <transaction-type>Container</transaction-type>
+    </session>
+
+    <session>
+      <ejb-name>CalculatorImplTimestamp2ways</ejb-name>
+      <service-endpoint>org.superbiz.calculator.CalculatorWs</service-endpoint>
+      <ejb-class>org.superbiz.calculator.CalculatorImpl</ejb-class>
+      <session-type>Stateless</session-type>
+      <transaction-type>Container</transaction-type>
+    </session>
+
+    <session>
+      <ejb-name>CalculatorImplUsernameTokenPlainPassword</ejb-name>
+      <service-endpoint>org.superbiz.calculator.CalculatorWs</service-endpoint>
+      <ejb-class>org.superbiz.calculator.CalculatorImpl</ejb-class>
+      <session-type>Stateless</session-type>
+      <transaction-type>Container</transaction-type>
+    </session>
+
+    <session>
+      <ejb-name>CalculatorImplUsernameTokenHashedPassword</ejb-name>
+      <service-endpoint>org.superbiz.calculator.CalculatorWs</service-endpoint>
+      <ejb-class>org.superbiz.calculator.CalculatorImpl</ejb-class>
+      <session-type>Stateless</session-type>
+      <transaction-type>Container</transaction-type>
+    </session>
+
+    <session>
+      <ejb-name>CalculatorImplUsernameTokenPlainPasswordEncrypt</ejb-name>
+      <service-endpoint>org.superbiz.calculator.CalculatorWs</service-endpoint>
+      <ejb-class>org.superbiz.calculator.CalculatorImpl</ejb-class>
+      <session-type>Stateless</session-type>
+      <transaction-type>Container</transaction-type>
+    </session>
+
+    <session>
+      <ejb-name>CalculatorImplSign</ejb-name>
+      <service-endpoint>org.superbiz.calculator.CalculatorWs</service-endpoint>
+      <ejb-class>org.superbiz.calculator.CalculatorImpl</ejb-class>
+      <session-type>Stateless</session-type>
+      <transaction-type>Container</transaction-type>
+    </session>
+
+    <session>
+      <ejb-name>CalculatorImplEncrypt2ways</ejb-name>
+      <service-endpoint>org.superbiz.calculator.CalculatorWs</service-endpoint>
+      <ejb-class>org.superbiz.calculator.CalculatorImpl</ejb-class>
+      <session-type>Stateless</session-type>
+      <transaction-type>Container</transaction-type>
+    </session>
+
+    <session>
+      <ejb-name>CalculatorImplSign2ways</ejb-name>
+      <service-endpoint>org.superbiz.calculator.CalculatorWs</service-endpoint>
+      <ejb-class>org.superbiz.calculator.CalculatorImpl</ejb-class>
+      <session-type>Stateless</session-type>
+      <transaction-type>Container</transaction-type>
+    </session>
+
+    <session>
+      <ejb-name>CalculatorImplEncryptAndSign2ways</ejb-name>
+      <service-endpoint>org.superbiz.calculator.CalculatorWs</service-endpoint>
+      <ejb-class>org.superbiz.calculator.CalculatorImpl</ejb-class>
+      <session-type>Stateless</session-type>
+      <transaction-type>Container</transaction-type>
+    </session>
+
+  </enterprise-beans>
+
+</ejb-jar>

http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/examples/webservice-ws-security/src/main/resources/META-INF/webservices.xml
----------------------------------------------------------------------
diff --git a/examples/webservice-ws-security/src/main/resources/META-INF/webservices.xml b/examples/webservice-ws-security/src/main/resources/META-INF/webservices.xml
index db709b6..64c9744 100644
--- a/examples/webservice-ws-security/src/main/resources/META-INF/webservices.xml
+++ b/examples/webservice-ws-security/src/main/resources/META-INF/webservices.xml
@@ -1,66 +1,66 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-
-    Licensed to the Apache Software Foundation (ASF) under one or more
-    contributor license agreements. See the NOTICE file distributed with
-    this work for additional information regarding copyright ownership. The
-    ASF licenses this file to You under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance with the
-    License. You may obtain a copy of the License at
-
-    http://www.apache.org/licenses/LICENSE-2.0 Unless required by applicable
-    law or agreed to in writing, software distributed under the License is
-    distributed on an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-    KIND, either express or implied. See the License for the specific
-    language governing permissions and limitations under the License.
--->
-<webservices xmlns="http://java.sun.com/xml/ns/j2ee" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-             xsi:schemaLocation="http://java.sun.com/xml/ns/j2ee
-http://www.ibm.com/webservices/xsd/j2ee_web_services_1_1.xsd"
-             version="1.1">
-
-  <webservice-description>
-    <webservice-description-name>CalculatorWsService</webservice-description-name>
-    <port-component>
-      <port-component-name>CalculatorImplTimestamp1way</port-component-name>
-      <wsdl-port>CalculatorImplTimestamp1way</wsdl-port>
-      <service-endpoint-interface>org.superbiz.calculator.CalculatorWs</service-endpoint-interface>
-      <service-impl-bean>
-        <ejb-link>CalculatorImplTimestamp1way</ejb-link>
-      </service-impl-bean>
-    </port-component>
-    <port-component>
-      <port-component-name>CalculatorImplTimestamp2ways</port-component-name>
-      <wsdl-port>CalculatorImplTimestamp2ways</wsdl-port>
-      <service-endpoint-interface>org.superbiz.calculator.CalculatorWs</service-endpoint-interface>
-      <service-impl-bean>
-        <ejb-link>CalculatorImplTimestamp2ways</ejb-link>
-      </service-impl-bean>
-    </port-component>
-    <port-component>
-      <port-component-name>CalculatorImplUsernameTokenPlainPassword</port-component-name>
-      <wsdl-port>CalculatorImplUsernameTokenPlainPassword</wsdl-port>
-      <service-endpoint-interface>org.superbiz.calculator.CalculatorWs</service-endpoint-interface>
-      <service-impl-bean>
-        <ejb-link>CalculatorImplUsernameTokenPlainPassword</ejb-link>
-      </service-impl-bean>
-    </port-component>
-    <port-component>
-      <port-component-name>CalculatorImplUsernameTokenHashedPassword</port-component-name>
-      <wsdl-port>CalculatorImplUsernameTokenHashedPassword</wsdl-port>
-      <service-endpoint-interface>org.superbiz.calculator.CalculatorWs</service-endpoint-interface>
-      <service-impl-bean>
-        <ejb-link>CalculatorImplUsernameTokenHashedPassword</ejb-link>
-      </service-impl-bean>
-    </port-component>
-    <port-component>
-      <port-component-name>CalculatorImplUsernameTokenPlainPasswordEncrypt</port-component-name>
-      <wsdl-port>CalculatorImplUsernameTokenPlainPasswordEncrypt</wsdl-port>
-      <service-endpoint-interface>org.superbiz.calculator.CalculatorWs</service-endpoint-interface>
-      <service-impl-bean>
-        <ejb-link>CalculatorImplUsernameTokenPlainPasswordEncrypt</ejb-link>
-      </service-impl-bean>
-    </port-component>
-  </webservice-description>
-
-</webservices>
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+
+    Licensed to the Apache Software Foundation (ASF) under one or more
+    contributor license agreements. See the NOTICE file distributed with
+    this work for additional information regarding copyright ownership. The
+    ASF licenses this file to You under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance with the
+    License. You may obtain a copy of the License at
+
+    http://www.apache.org/licenses/LICENSE-2.0 Unless required by applicable
+    law or agreed to in writing, software distributed under the License is
+    distributed on an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied. See the License for the specific
+    language governing permissions and limitations under the License.
+-->
+<webservices xmlns="http://java.sun.com/xml/ns/j2ee" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+             xsi:schemaLocation="http://java.sun.com/xml/ns/j2ee
+http://www.ibm.com/webservices/xsd/j2ee_web_services_1_1.xsd"
+             version="1.1">
+
+  <webservice-description>
+    <webservice-description-name>CalculatorWsService</webservice-description-name>
+    <port-component>
+      <port-component-name>CalculatorImplTimestamp1way</port-component-name>
+      <wsdl-port>CalculatorImplTimestamp1way</wsdl-port>
+      <service-endpoint-interface>org.superbiz.calculator.CalculatorWs</service-endpoint-interface>
+      <service-impl-bean>
+        <ejb-link>CalculatorImplTimestamp1way</ejb-link>
+      </service-impl-bean>
+    </port-component>
+    <port-component>
+      <port-component-name>CalculatorImplTimestamp2ways</port-component-name>
+      <wsdl-port>CalculatorImplTimestamp2ways</wsdl-port>
+      <service-endpoint-interface>org.superbiz.calculator.CalculatorWs</service-endpoint-interface>
+      <service-impl-bean>
+        <ejb-link>CalculatorImplTimestamp2ways</ejb-link>
+      </service-impl-bean>
+    </port-component>
+    <port-component>
+      <port-component-name>CalculatorImplUsernameTokenPlainPassword</port-component-name>
+      <wsdl-port>CalculatorImplUsernameTokenPlainPassword</wsdl-port>
+      <service-endpoint-interface>org.superbiz.calculator.CalculatorWs</service-endpoint-interface>
+      <service-impl-bean>
+        <ejb-link>CalculatorImplUsernameTokenPlainPassword</ejb-link>
+      </service-impl-bean>
+    </port-component>
+    <port-component>
+      <port-component-name>CalculatorImplUsernameTokenHashedPassword</port-component-name>
+      <wsdl-port>CalculatorImplUsernameTokenHashedPassword</wsdl-port>
+      <service-endpoint-interface>org.superbiz.calculator.CalculatorWs</service-endpoint-interface>
+      <service-impl-bean>
+        <ejb-link>CalculatorImplUsernameTokenHashedPassword</ejb-link>
+      </service-impl-bean>
+    </port-component>
+    <port-component>
+      <port-component-name>CalculatorImplUsernameTokenPlainPasswordEncrypt</port-component-name>
+      <wsdl-port>CalculatorImplUsernameTokenPlainPasswordEncrypt</wsdl-port>
+      <service-endpoint-interface>org.superbiz.calculator.CalculatorWs</service-endpoint-interface>
+      <service-impl-bean>
+        <ejb-link>CalculatorImplUsernameTokenPlainPasswordEncrypt</ejb-link>
+      </service-impl-bean>
+    </port-component>
+  </webservice-description>
+
+</webservices>

http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/examples/webservice-ws-security/src/test/resources/META-INF/CalculatorImplSign-client.properties
----------------------------------------------------------------------
diff --git a/examples/webservice-ws-security/src/test/resources/META-INF/CalculatorImplSign-client.properties b/examples/webservice-ws-security/src/test/resources/META-INF/CalculatorImplSign-client.properties
index 350eaf9..8495746 100644
--- a/examples/webservice-ws-security/src/test/resources/META-INF/CalculatorImplSign-client.properties
+++ b/examples/webservice-ws-security/src/test/resources/META-INF/CalculatorImplSign-client.properties
@@ -1,7 +1,7 @@
-org.apache.ws.security.crypto.provider=org.apache.ws.security.components.crypto.Merlin
-org.apache.ws.security.crypto.merlin.keystore.type=jks
-org.apache.ws.security.crypto.merlin.keystore.password=keystorePass
-org.apache.ws.security.crypto.merlin.keystore.alias=clientalias
-org.apache.ws.security.crypto.merlin.file=META-INF/clientStore.jks
-# OPENEJB-1061 OpenJDK doesn't come with cacerts
-org.apache.ws.security.crypto.merlin.load.cacerts=false
+org.apache.ws.security.crypto.provider=org.apache.ws.security.components.crypto.Merlin
+org.apache.ws.security.crypto.merlin.keystore.type=jks
+org.apache.ws.security.crypto.merlin.keystore.password=keystorePass
+org.apache.ws.security.crypto.merlin.keystore.alias=clientalias
+org.apache.ws.security.crypto.merlin.file=META-INF/clientStore.jks
+# OPENEJB-1061 OpenJDK doesn't come with cacerts
+org.apache.ws.security.crypto.merlin.load.cacerts=false

http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/examples/webservice-ws-security/src/test/resources/META-INF/CalculatorImplUsernameTokenPlainPasswordEncrypt-client.properties
----------------------------------------------------------------------
diff --git a/examples/webservice-ws-security/src/test/resources/META-INF/CalculatorImplUsernameTokenPlainPasswordEncrypt-client.properties b/examples/webservice-ws-security/src/test/resources/META-INF/CalculatorImplUsernameTokenPlainPasswordEncrypt-client.properties
index 350eaf9..8495746 100644
--- a/examples/webservice-ws-security/src/test/resources/META-INF/CalculatorImplUsernameTokenPlainPasswordEncrypt-client.properties
+++ b/examples/webservice-ws-security/src/test/resources/META-INF/CalculatorImplUsernameTokenPlainPasswordEncrypt-client.properties
@@ -1,7 +1,7 @@
-org.apache.ws.security.crypto.provider=org.apache.ws.security.components.crypto.Merlin
-org.apache.ws.security.crypto.merlin.keystore.type=jks
-org.apache.ws.security.crypto.merlin.keystore.password=keystorePass
-org.apache.ws.security.crypto.merlin.keystore.alias=clientalias
-org.apache.ws.security.crypto.merlin.file=META-INF/clientStore.jks
-# OPENEJB-1061 OpenJDK doesn't come with cacerts
-org.apache.ws.security.crypto.merlin.load.cacerts=false
+org.apache.ws.security.crypto.provider=org.apache.ws.security.components.crypto.Merlin
+org.apache.ws.security.crypto.merlin.keystore.type=jks
+org.apache.ws.security.crypto.merlin.keystore.password=keystorePass
+org.apache.ws.security.crypto.merlin.keystore.alias=clientalias
+org.apache.ws.security.crypto.merlin.file=META-INF/clientStore.jks
+# OPENEJB-1061 OpenJDK doesn't come with cacerts
+org.apache.ws.security.crypto.merlin.load.cacerts=false

http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/maven/tomee-maven-plugin/src/main/java/org/apache/openejb/maven/plugin/AbstractSynchronizable.java
----------------------------------------------------------------------
diff --git a/maven/tomee-maven-plugin/src/main/java/org/apache/openejb/maven/plugin/AbstractSynchronizable.java b/maven/tomee-maven-plugin/src/main/java/org/apache/openejb/maven/plugin/AbstractSynchronizable.java
index 488e372..1244882 100644
--- a/maven/tomee-maven-plugin/src/main/java/org/apache/openejb/maven/plugin/AbstractSynchronizable.java
+++ b/maven/tomee-maven-plugin/src/main/java/org/apache/openejb/maven/plugin/AbstractSynchronizable.java
@@ -1,71 +1,71 @@
-/**
- *
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- *  Unless required by applicable law or agreed to in writing, software
- *  distributed under the License is distributed on an "AS IS" BASIS,
- *  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- *  See the License for the specific language governing permissions and
- *  limitations under the License.
- */
-package org.apache.openejb.maven.plugin;
-
-import java.io.File;
-import java.util.ArrayList;
-import java.util.List;
-import java.util.Map;
-
-public abstract class AbstractSynchronizable {
-    protected int updateInterval;
-    protected List<String> extensions;
-    protected List<String> updateOnlyExtensions;
-    protected String regex;
-    protected Map<File, File> updates;
-
-    public abstract Map<File, File> updates();
-
-    public int getUpdateInterval() {
-        return updateInterval;
-    }
-
-    public void setUpdateInterval(final int updateInterval) {
-        this.updateInterval = updateInterval;
-    }
-
-    public List<String> getExtensions() {
-        if (extensions == null) {
-            extensions = new ArrayList<String>();
-        }
-        return extensions;
-    }
-
-    public void setExtensions(final List<String> extensions) {
-        this.extensions = extensions;
-    }
-
-    public String getRegex() {
-        return regex;
-    }
-
-    public void setRegex(final String regex) {
-        this.regex = regex;
-    }
-
-    public List<String> getUpdateOnlyExtenions() {
-        if (updateOnlyExtensions == null) {
-            updateOnlyExtensions = new ArrayList<String>();
-        }
-        return updateOnlyExtensions;
-    }
-
-    public void setUpdateOnlyExtensions(final List<String> updateOnlyExtensions) {
-        this.updateOnlyExtensions = updateOnlyExtensions;
-    }
-}
+/**
+ *
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ *  Unless required by applicable law or agreed to in writing, software
+ *  distributed under the License is distributed on an "AS IS" BASIS,
+ *  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ *  See the License for the specific language governing permissions and
+ *  limitations under the License.
+ */
+package org.apache.openejb.maven.plugin;
+
+import java.io.File;
+import java.util.ArrayList;
+import java.util.List;
+import java.util.Map;
+
+public abstract class AbstractSynchronizable {
+    protected int updateInterval;
+    protected List<String> extensions;
+    protected List<String> updateOnlyExtensions;
+    protected String regex;
+    protected Map<File, File> updates;
+
+    public abstract Map<File, File> updates();
+
+    public int getUpdateInterval() {
+        return updateInterval;
+    }
+
+    public void setUpdateInterval(final int updateInterval) {
+        this.updateInterval = updateInterval;
+    }
+
+    public List<String> getExtensions() {
+        if (extensions == null) {
+            extensions = new ArrayList<String>();
+        }
+        return extensions;
+    }
+
+    public void setExtensions(final List<String> extensions) {
+        this.extensions = extensions;
+    }
+
+    public String getRegex() {
+        return regex;
+    }
+
+    public void setRegex(final String regex) {
+        this.regex = regex;
+    }
+
+    public List<String> getUpdateOnlyExtenions() {
+        if (updateOnlyExtensions == null) {
+            updateOnlyExtensions = new ArrayList<String>();
+        }
+        return updateOnlyExtensions;
+    }
+
+    public void setUpdateOnlyExtensions(final List<String> updateOnlyExtensions) {
+        this.updateOnlyExtensions = updateOnlyExtensions;
+    }
+}

http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/server/openejb-axis/src/test/resources/schema/ComplexAllElement.xsd
----------------------------------------------------------------------
diff --git a/server/openejb-axis/src/test/resources/schema/ComplexAllElement.xsd b/server/openejb-axis/src/test/resources/schema/ComplexAllElement.xsd
index df9ef21..4821609 100644
--- a/server/openejb-axis/src/test/resources/schema/ComplexAllElement.xsd
+++ b/server/openejb-axis/src/test/resources/schema/ComplexAllElement.xsd
@@ -1,24 +1,24 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-
-    Licensed to the Apache Software Foundation (ASF) under one or more
-    contributor license agreements.  See the NOTICE file distributed with
-    this work for additional information regarding copyright ownership.
-    The ASF licenses this file to You under the Apache License, Version 2.0
-    (the "License"); you may not use this file except in compliance with
-    the License.  You may obtain a copy of the License at
-
-       http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing, software
-    distributed under the License is distributed on an "AS IS" BASIS,
-    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-    See the License for the specific language governing permissions and
-    limitations under the License.
--->
-
-<!-- $Rev$ $Date$ -->
-
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+
+    Licensed to the Apache Software Foundation (ASF) under one or more
+    contributor license agreements.  See the NOTICE file distributed with
+    this work for additional information regarding copyright ownership.
+    The ASF licenses this file to You under the Apache License, Version 2.0
+    (the "License"); you may not use this file except in compliance with
+    the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+    Unless required by applicable law or agreed to in writing, software
+    distributed under the License is distributed on an "AS IS" BASIS,
+    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+    See the License for the specific language governing permissions and
+    limitations under the License.
+-->
+
+<!-- $Rev$ $Date$ -->
+
 <schema xmlns="http://www.w3.org/2001/XMLSchema" targetNamespace="X"
         xmlns:tns="X"
         xmlns:xsd="http://www.w3.org/2001/XMLSchema"

http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/server/openejb-axis/src/test/resources/schema/ComplexAllType.xsd
----------------------------------------------------------------------
diff --git a/server/openejb-axis/src/test/resources/schema/ComplexAllType.xsd b/server/openejb-axis/src/test/resources/schema/ComplexAllType.xsd
index f9dd8b4..9409581 100644
--- a/server/openejb-axis/src/test/resources/schema/ComplexAllType.xsd
+++ b/server/openejb-axis/src/test/resources/schema/ComplexAllType.xsd
@@ -1,24 +1,24 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-
-    Licensed to the Apache Software Foundation (ASF) under one or more
-    contributor license agreements.  See the NOTICE file distributed with
-    this work for additional information regarding copyright ownership.
-    The ASF licenses this file to You under the Apache License, Version 2.0
-    (the "License"); you may not use this file except in compliance with
-    the License.  You may obtain a copy of the License at
-
-       http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing, software
-    distributed under the License is distributed on an "AS IS" BASIS,
-    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-    See the License for the specific language governing permissions and
-    limitations under the License.
--->
-
-<!-- $Rev$ $Date$ -->
-
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+
+    Licensed to the Apache Software Foundation (ASF) under one or more
+    contributor license agreements.  See the NOTICE file distributed with
+    this work for additional information regarding copyright ownership.
+    The ASF licenses this file to You under the Apache License, Version 2.0
+    (the "License"); you may not use this file except in compliance with
+    the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+    Unless required by applicable law or agreed to in writing, software
+    distributed under the License is distributed on an "AS IS" BASIS,
+    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+    See the License for the specific language governing permissions and
+    limitations under the License.
+-->
+
+<!-- $Rev$ $Date$ -->
+
 <schema xmlns="http://www.w3.org/2001/XMLSchema" targetNamespace="X"
         xmlns:tns="X"
         xmlns:xsd="http://www.w3.org/2001/XMLSchema"

http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/server/openejb-axis/src/test/resources/schema/ComplexSequenceElement.xsd
----------------------------------------------------------------------
diff --git a/server/openejb-axis/src/test/resources/schema/ComplexSequenceElement.xsd b/server/openejb-axis/src/test/resources/schema/ComplexSequenceElement.xsd
index 36299e3..f59ab72 100644
--- a/server/openejb-axis/src/test/resources/schema/ComplexSequenceElement.xsd
+++ b/server/openejb-axis/src/test/resources/schema/ComplexSequenceElement.xsd
@@ -1,24 +1,24 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-
-    Licensed to the Apache Software Foundation (ASF) under one or more
-    contributor license agreements.  See the NOTICE file distributed with
-    this work for additional information regarding copyright ownership.
-    The ASF licenses this file to You under the Apache License, Version 2.0
-    (the "License"); you may not use this file except in compliance with
-    the License.  You may obtain a copy of the License at
-
-       http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing, software
-    distributed under the License is distributed on an "AS IS" BASIS,
-    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-    See the License for the specific language governing permissions and
-    limitations under the License.
--->
-
-<!-- $Rev$ $Date$ -->
-
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+
+    Licensed to the Apache Software Foundation (ASF) under one or more
+    contributor license agreements.  See the NOTICE file distributed with
+    this work for additional information regarding copyright ownership.
+    The ASF licenses this file to You under the Apache License, Version 2.0
+    (the "License"); you may not use this file except in compliance with
+    the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+    Unless required by applicable law or agreed to in writing, software
+    distributed under the License is distributed on an "AS IS" BASIS,
+    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+    See the License for the specific language governing permissions and
+    limitations under the License.
+-->
+
+<!-- $Rev$ $Date$ -->
+
 <schema xmlns="http://www.w3.org/2001/XMLSchema" targetNamespace="X"
         xmlns:tns="X"
         xmlns:xsd="http://www.w3.org/2001/XMLSchema"

http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/server/openejb-axis/src/test/resources/schema/ComplexSequenceType.xsd
----------------------------------------------------------------------
diff --git a/server/openejb-axis/src/test/resources/schema/ComplexSequenceType.xsd b/server/openejb-axis/src/test/resources/schema/ComplexSequenceType.xsd
index 34dbf99..0484e30 100644
--- a/server/openejb-axis/src/test/resources/schema/ComplexSequenceType.xsd
+++ b/server/openejb-axis/src/test/resources/schema/ComplexSequenceType.xsd
@@ -1,24 +1,24 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-
-    Licensed to the Apache Software Foundation (ASF) under one or more
-    contributor license agreements.  See the NOTICE file distributed with
-    this work for additional information regarding copyright ownership.
-    The ASF licenses this file to You under the Apache License, Version 2.0
-    (the "License"); you may not use this file except in compliance with
-    the License.  You may obtain a copy of the License at
-
-       http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing, software
-    distributed under the License is distributed on an "AS IS" BASIS,
-    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-    See the License for the specific language governing permissions and
-    limitations under the License.
--->
-
-<!-- $Rev$ $Date$ -->
-
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+
+    Licensed to the Apache Software Foundation (ASF) under one or more
+    contributor license agreements.  See the NOTICE file distributed with
+    this work for additional information regarding copyright ownership.
+    The ASF licenses this file to You under the Apache License, Version 2.0
+    (the "License"); you may not use this file except in compliance with
+    the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+    Unless required by applicable law or agreed to in writing, software
+    distributed under the License is distributed on an "AS IS" BASIS,
+    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+    See the License for the specific language governing permissions and
+    limitations under the License.
+-->
+
+<!-- $Rev$ $Date$ -->
+
 <schema xmlns="http://www.w3.org/2001/XMLSchema" targetNamespace="X"
         xmlns:tns="X"
         xmlns:xsd="http://www.w3.org/2001/XMLSchema"

http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/server/openejb-axis/src/test/resources/schema/JaxRpcSpecExample.xsd
----------------------------------------------------------------------
diff --git a/server/openejb-axis/src/test/resources/schema/JaxRpcSpecExample.xsd b/server/openejb-axis/src/test/resources/schema/JaxRpcSpecExample.xsd
index a1bba13..65eb581 100644
--- a/server/openejb-axis/src/test/resources/schema/JaxRpcSpecExample.xsd
+++ b/server/openejb-axis/src/test/resources/schema/JaxRpcSpecExample.xsd
@@ -1,24 +1,24 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-
-    Licensed to the Apache Software Foundation (ASF) under one or more
-    contributor license agreements.  See the NOTICE file distributed with
-    this work for additional information regarding copyright ownership.
-    The ASF licenses this file to You under the Apache License, Version 2.0
-    (the "License"); you may not use this file except in compliance with
-    the License.  You may obtain a copy of the License at
-
-       http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing, software
-    distributed under the License is distributed on an "AS IS" BASIS,
-    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-    See the License for the specific language governing permissions and
-    limitations under the License.
--->
-
-<!-- $Rev$ $Date$ -->
-
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+
+    Licensed to the Apache Software Foundation (ASF) under one or more
+    contributor license agreements.  See the NOTICE file distributed with
+    this work for additional information regarding copyright ownership.
+    The ASF licenses this file to You under the Apache License, Version 2.0
+    (the "License"); you may not use this file except in compliance with
+    the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+    Unless required by applicable law or agreed to in writing, software
+    distributed under the License is distributed on an "AS IS" BASIS,
+    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+    See the License for the specific language governing permissions and
+    limitations under the License.
+-->
+
+<!-- $Rev$ $Date$ -->
+
 <schema xmlns="http://www.w3.org/2001/XMLSchema" targetNamespace="X"
         xmlns:tns="X"
         xmlns:xsd="http://www.w3.org/2001/XMLSchema"

http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/server/openejb-axis/src/test/resources/schema/SimpleElement.xsd
----------------------------------------------------------------------
diff --git a/server/openejb-axis/src/test/resources/schema/SimpleElement.xsd b/server/openejb-axis/src/test/resources/schema/SimpleElement.xsd
index 9d4bd82..3f483e3 100644
--- a/server/openejb-axis/src/test/resources/schema/SimpleElement.xsd
+++ b/server/openejb-axis/src/test/resources/schema/SimpleElement.xsd
@@ -1,24 +1,24 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-
-    Licensed to the Apache Software Foundation (ASF) under one or more
-    contributor license agreements.  See the NOTICE file distributed with
-    this work for additional information regarding copyright ownership.
-    The ASF licenses this file to You under the Apache License, Version 2.0
-    (the "License"); you may not use this file except in compliance with
-    the License.  You may obtain a copy of the License at
-
-       http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing, software
-    distributed under the License is distributed on an "AS IS" BASIS,
-    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-    See the License for the specific language governing permissions and
-    limitations under the License.
--->
-
-<!-- $Rev$ $Date$ -->
-
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+
+    Licensed to the Apache Software Foundation (ASF) under one or more
+    contributor license agreements.  See the NOTICE file distributed with
+    this work for additional information regarding copyright ownership.
+    The ASF licenses this file to You under the Apache License, Version 2.0
+    (the "License"); you may not use this file except in compliance with
+    the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+    Unless required by applicable law or agreed to in writing, software
+    distributed under the License is distributed on an "AS IS" BASIS,
+    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+    See the License for the specific language governing permissions and
+    limitations under the License.
+-->
+
+<!-- $Rev$ $Date$ -->
+
 <schema xmlns="http://www.w3.org/2001/XMLSchema" targetNamespace="X"
         xmlns:tns="X"
         xmlns:xsd="http://www.w3.org/2001/XMLSchema"

http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/server/openejb-axis/src/test/resources/schema/SimpleType.xsd
----------------------------------------------------------------------
diff --git a/server/openejb-axis/src/test/resources/schema/SimpleType.xsd b/server/openejb-axis/src/test/resources/schema/SimpleType.xsd
index 83339ae..894c3b4 100644
--- a/server/openejb-axis/src/test/resources/schema/SimpleType.xsd
+++ b/server/openejb-axis/src/test/resources/schema/SimpleType.xsd
@@ -1,24 +1,24 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-
-    Licensed to the Apache Software Foundation (ASF) under one or more
-    contributor license agreements.  See the NOTICE file distributed with
-    this work for additional information regarding copyright ownership.
-    The ASF licenses this file to You under the Apache License, Version 2.0
-    (the "License"); you may not use this file except in compliance with
-    the License.  You may obtain a copy of the License at
-
-       http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing, software
-    distributed under the License is distributed on an "AS IS" BASIS,
-    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-    See the License for the specific language governing permissions and
-    limitations under the License.
--->
-
-<!-- $Rev$ $Date$ -->
-
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+
+    Licensed to the Apache Software Foundation (ASF) under one or more
+    contributor license agreements.  See the NOTICE file distributed with
+    this work for additional information regarding copyright ownership.
+    The ASF licenses this file to You under the Apache License, Version 2.0
+    (the "License"); you may not use this file except in compliance with
+    the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+    Unless required by applicable law or agreed to in writing, software
+    distributed under the License is distributed on an "AS IS" BASIS,
+    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+    See the License for the specific language governing permissions and
+    limitations under the License.
+-->
+
+<!-- $Rev$ $Date$ -->
+
 <schema xmlns="http://www.w3.org/2001/XMLSchema" targetNamespace="X"
         xmlns:tns="X"
         xmlns:xsd="http://www.w3.org/2001/XMLSchema"

http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/server/openejb-axis/src/test/resources/schema/SoapArrayByAttribute.xsd
----------------------------------------------------------------------
diff --git a/server/openejb-axis/src/test/resources/schema/SoapArrayByAttribute.xsd b/server/openejb-axis/src/test/resources/schema/SoapArrayByAttribute.xsd
index 5696c61..1f63eed 100644
--- a/server/openejb-axis/src/test/resources/schema/SoapArrayByAttribute.xsd
+++ b/server/openejb-axis/src/test/resources/schema/SoapArrayByAttribute.xsd
@@ -1,24 +1,24 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-
-    Licensed to the Apache Software Foundation (ASF) under one or more
-    contributor license agreements.  See the NOTICE file distributed with
-    this work for additional information regarding copyright ownership.
-    The ASF licenses this file to You under the Apache License, Version 2.0
-    (the "License"); you may not use this file except in compliance with
-    the License.  You may obtain a copy of the License at
-
-       http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing, software
-    distributed under the License is distributed on an "AS IS" BASIS,
-    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-    See the License for the specific language governing permissions and
-    limitations under the License.
--->
-
-<!-- $Rev$ $Date$ -->
-
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+
+    Licensed to the Apache Software Foundation (ASF) under one or more
+    contributor license agreements.  See the NOTICE file distributed with
+    this work for additional information regarding copyright ownership.
+    The ASF licenses this file to You under the Apache License, Version 2.0
+    (the "License"); you may not use this file except in compliance with
+    the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+    Unless required by applicable law or agreed to in writing, software
+    distributed under the License is distributed on an "AS IS" BASIS,
+    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+    See the License for the specific language governing permissions and
+    limitations under the License.
+-->
+
+<!-- $Rev$ $Date$ -->
+
 <xsd:schema
         targetNamespace="X"
         xmlns:tns="X"

http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/server/openejb-axis/src/test/resources/schema/SoapArrayByRestriction.xsd
----------------------------------------------------------------------
diff --git a/server/openejb-axis/src/test/resources/schema/SoapArrayByRestriction.xsd b/server/openejb-axis/src/test/resources/schema/SoapArrayByRestriction.xsd
index 9b61fcc..ab4c67b 100644
--- a/server/openejb-axis/src/test/resources/schema/SoapArrayByRestriction.xsd
+++ b/server/openejb-axis/src/test/resources/schema/SoapArrayByRestriction.xsd
@@ -1,24 +1,24 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-
-    Licensed to the Apache Software Foundation (ASF) under one or more
-    contributor license agreements.  See the NOTICE file distributed with
-    this work for additional information regarding copyright ownership.
-    The ASF licenses this file to You under the Apache License, Version 2.0
-    (the "License"); you may not use this file except in compliance with
-    the License.  You may obtain a copy of the License at
-
-       http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing, software
-    distributed under the License is distributed on an "AS IS" BASIS,
-    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-    See the License for the specific language governing permissions and
-    limitations under the License.
--->
-
-<!-- $Rev$ $Date$ -->
-
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+
+    Licensed to the Apache Software Foundation (ASF) under one or more
+    contributor license agreements.  See the NOTICE file distributed with
+    this work for additional information regarding copyright ownership.
+    The ASF licenses this file to You under the Apache License, Version 2.0
+    (the "License"); you may not use this file except in compliance with
+    the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+    Unless required by applicable law or agreed to in writing, software
+    distributed under the License is distributed on an "AS IS" BASIS,
+    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+    See the License for the specific language governing permissions and
+    limitations under the License.
+-->
+
+<!-- $Rev$ $Date$ -->
+
 <schema xmlns="http://www.w3.org/2001/XMLSchema" targetNamespace="X"
         xmlns:tns="X"
         xmlns:xsd="http://www.w3.org/2001/XMLSchema"

http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/server/openejb-cxf-rs/src/main/java/org/apache/openejb/server/cxf/rs/PojoInvoker.java
----------------------------------------------------------------------
diff --git a/server/openejb-cxf-rs/src/main/java/org/apache/openejb/server/cxf/rs/PojoInvoker.java b/server/openejb-cxf-rs/src/main/java/org/apache/openejb/server/cxf/rs/PojoInvoker.java
index 61468be..805d813 100644
--- a/server/openejb-cxf-rs/src/main/java/org/apache/openejb/server/cxf/rs/PojoInvoker.java
+++ b/server/openejb-cxf-rs/src/main/java/org/apache/openejb/server/cxf/rs/PojoInvoker.java
@@ -1,62 +1,62 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
-    * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.openejb.server.cxf.rs;
-
-import org.apache.cxf.jaxrs.JAXRSInvoker;
-import org.apache.cxf.message.Exchange;
-import org.apache.cxf.message.Message;
-import org.apache.openejb.ApplicationException;
-import org.apache.openejb.InvalidateReferenceException;
-
-import java.lang.reflect.InvocationTargetException;
-import java.lang.reflect.Method;
-import java.rmi.RemoteException;
-import java.util.Arrays;
-import java.util.logging.Level;
-
-public class PojoInvoker extends JAXRSInvoker {
-    protected Object performInvocation(final Exchange exchange, final Object serviceObject,
-                                       final Method m, final Object[] paramArray) throws Exception {
-        final Object[] args = insertExchange(m, paramArray, exchange);
-        final ClassLoader tcclToUse = getClassLoader(exchange);
-        final Thread thread = Thread.currentThread();
-        ClassLoader oldLoader = null;
-        if (tcclToUse != null) {
-            oldLoader = thread.getContextClassLoader();
-            thread.setContextClassLoader(tcclToUse);
-        }
-        try {
-            return m.invoke(serviceObject, args);
-        } finally {
-            if (tcclToUse != null) {
-                thread.setContextClassLoader(oldLoader);
-            }
-        }
-    }
-
-    private ClassLoader getClassLoader(final Exchange exchange) {
-        final Message inMessage = exchange.getInMessage();
-        if (inMessage == null) {
-            return null;
-        }
-        final OpenEJBPerRequestPojoResourceProvider requestPojoResourceProvider = inMessage.get(OpenEJBPerRequestPojoResourceProvider.class);
-        if (requestPojoResourceProvider != null) {
-            return requestPojoResourceProvider.getClassLoader();
-        }
-        return null;
-    }
-}
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+    * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.openejb.server.cxf.rs;
+
+import org.apache.cxf.jaxrs.JAXRSInvoker;
+import org.apache.cxf.message.Exchange;
+import org.apache.cxf.message.Message;
+import org.apache.openejb.ApplicationException;
+import org.apache.openejb.InvalidateReferenceException;
+
+import java.lang.reflect.InvocationTargetException;
+import java.lang.reflect.Method;
+import java.rmi.RemoteException;
+import java.util.Arrays;
+import java.util.logging.Level;
+
+public class PojoInvoker extends JAXRSInvoker {
+    protected Object performInvocation(final Exchange exchange, final Object serviceObject,
+                                       final Method m, final Object[] paramArray) throws Exception {
+        final Object[] args = insertExchange(m, paramArray, exchange);
+        final ClassLoader tcclToUse = getClassLoader(exchange);
+        final Thread thread = Thread.currentThread();
+        ClassLoader oldLoader = null;
+        if (tcclToUse != null) {
+            oldLoader = thread.getContextClassLoader();
+            thread.setContextClassLoader(tcclToUse);
+        }
+        try {
+            return m.invoke(serviceObject, args);
+        } finally {
+            if (tcclToUse != null) {
+                thread.setContextClassLoader(oldLoader);
+            }
+        }
+    }
+
+    private ClassLoader getClassLoader(final Exchange exchange) {
+        final Message inMessage = exchange.getInMessage();
+        if (inMessage == null) {
+            return null;
+        }
+        final OpenEJBPerRequestPojoResourceProvider requestPojoResourceProvider = inMessage.get(OpenEJBPerRequestPojoResourceProvider.class);
+        if (requestPojoResourceProvider != null) {
+            return requestPojoResourceProvider.getClassLoader();
+        }
+        return null;
+    }
+}

http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/server/openejb-cxf/src/test/java/org/apache/openejb/server/cxf/fault/AuthenticatorService.java
----------------------------------------------------------------------
diff --git a/server/openejb-cxf/src/test/java/org/apache/openejb/server/cxf/fault/AuthenticatorService.java b/server/openejb-cxf/src/test/java/org/apache/openejb/server/cxf/fault/AuthenticatorService.java
index 6a29e16..1358cdd 100644
--- a/server/openejb-cxf/src/test/java/org/apache/openejb/server/cxf/fault/AuthenticatorService.java
+++ b/server/openejb-cxf/src/test/java/org/apache/openejb/server/cxf/fault/AuthenticatorService.java
@@ -1,31 +1,31 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- *  Unless required by applicable law or agreed to in writing, software
- *  distributed under the License is distributed on an "AS IS" BASIS,
- *  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- *  See the License for the specific language governing permissions and
- *  limitations under the License.
- */
-package org.apache.openejb.server.cxf.fault;
-
-import javax.jws.WebService;
-
-/**
- * @version $Rev$
- */
-@WebService(targetNamespace = "http://superbiz.org/wsdl")
-public interface AuthenticatorService {
-
-    boolean authenticate(String name, String password) throws WrongPasswordException;
-
-    boolean authenticateRuntime(String name, String password);
-
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ *  Unless required by applicable law or agreed to in writing, software
+ *  distributed under the License is distributed on an "AS IS" BASIS,
+ *  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ *  See the License for the specific language governing permissions and
+ *  limitations under the License.
+ */
+package org.apache.openejb.server.cxf.fault;
+
+import javax.jws.WebService;
+
+/**
+ * @version $Rev$
+ */
+@WebService(targetNamespace = "http://superbiz.org/wsdl")
+public interface AuthenticatorService {
+
+    boolean authenticate(String name, String password) throws WrongPasswordException;
+
+    boolean authenticateRuntime(String name, String password);
+
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/server/openejb-cxf/src/test/resources/META-INF/ejb-jar.xml
----------------------------------------------------------------------
diff --git a/server/openejb-cxf/src/test/resources/META-INF/ejb-jar.xml b/server/openejb-cxf/src/test/resources/META-INF/ejb-jar.xml
index 00a4cbe..676b4ba 100644
--- a/server/openejb-cxf/src/test/resources/META-INF/ejb-jar.xml
+++ b/server/openejb-cxf/src/test/resources/META-INF/ejb-jar.xml
@@ -1,19 +1,19 @@
-<!--
-  Licensed to the Apache Software Foundation (ASF) under one
-  or more contributor license agreements. See the NOTICE file
-  distributed with this work for additional information
-  regarding copyright ownership. The ASF licenses this file
-  to you under the Apache License, Version 2.0 (the
-  "License"); you may not use this file except in compliance
-  with the License. You may obtain a copy of the License at
-
-  http://www.apache.org/licenses/LICENSE-2.0
-
-  Unless required by applicable law or agreed to in writing,
-  software distributed under the License is distributed on an
-  "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-  KIND, either express or implied. See the License for the
-  specific language governing permissions and limitations
-  under the License.
--->
+<!--
+  Licensed to the Apache Software Foundation (ASF) under one
+  or more contributor license agreements. See the NOTICE file
+  distributed with this work for additional information
+  regarding copyright ownership. The ASF licenses this file
+  to you under the Apache License, Version 2.0 (the
+  "License"); you may not use this file except in compliance
+  with the License. You may obtain a copy of the License at
+
+  http://www.apache.org/licenses/LICENSE-2.0
+
+  Unless required by applicable law or agreed to in writing,
+  software distributed under the License is distributed on an
+  "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+  KIND, either express or implied. See the License for the
+  specific language governing permissions and limitations
+  under the License.
+-->
 <ejb-jar/>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/server/openejb-cxf/src/test/resources/org/apache/openejb/server/cxf/fault/handler.xml
----------------------------------------------------------------------
diff --git a/server/openejb-cxf/src/test/resources/org/apache/openejb/server/cxf/fault/handler.xml b/server/openejb-cxf/src/test/resources/org/apache/openejb/server/cxf/fault/handler.xml
index 337711f..8a3c7c4 100644
--- a/server/openejb-cxf/src/test/resources/org/apache/openejb/server/cxf/fault/handler.xml
+++ b/server/openejb-cxf/src/test/resources/org/apache/openejb/server/cxf/fault/handler.xml
@@ -1,27 +1,27 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-  Licensed to the Apache Software Foundation (ASF) under one
-  or more contributor license agreements. See the NOTICE file
-  distributed with this work for additional information
-  regarding copyright ownership. The ASF licenses this file
-  to you under the Apache License, Version 2.0 (the
-  "License"); you may not use this file except in compliance
-  with the License. You may obtain a copy of the License at
-
-  http://www.apache.org/licenses/LICENSE-2.0
-
-  Unless required by applicable law or agreed to in writing,
-  software distributed under the License is distributed on an
-  "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-  KIND, either express or implied. See the License for the
-  specific language governing permissions and limitations
-  under the License.
--->
-<handler-chains xmlns="http://java.sun.com/xml/ns/javaee">
-  <handler-chain>
-    <handler>
-      <handler-name>org.apache.openejb.server.cxf.fault.DummyInterceptor</handler-name>
-      <handler-class>org.apache.openejb.server.cxf.fault.DummyInterceptor</handler-class>
-    </handler>
-  </handler-chain>
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+  Licensed to the Apache Software Foundation (ASF) under one
+  or more contributor license agreements. See the NOTICE file
+  distributed with this work for additional information
+  regarding copyright ownership. The ASF licenses this file
+  to you under the Apache License, Version 2.0 (the
+  "License"); you may not use this file except in compliance
+  with the License. You may obtain a copy of the License at
+
+  http://www.apache.org/licenses/LICENSE-2.0
+
+  Unless required by applicable law or agreed to in writing,
+  software distributed under the License is distributed on an
+  "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+  KIND, either express or implied. See the License for the
+  specific language governing permissions and limitations
+  under the License.
+-->
+<handler-chains xmlns="http://java.sun.com/xml/ns/javaee">
+  <handler-chain>
+    <handler>
+      <handler-name>org.apache.openejb.server.cxf.fault.DummyInterceptor</handler-name>
+      <handler-class>org.apache.openejb.server.cxf.fault.DummyInterceptor</handler-class>
+    </handler>
+  </handler-chain>
 </handler-chains>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/server/openejb-ejbd/src/main/java/org/apache/openejb/server/ejbd/RequestHandler.java
----------------------------------------------------------------------
diff --git a/server/openejb-ejbd/src/main/java/org/apache/openejb/server/ejbd/RequestHandler.java b/server/openejb-ejbd/src/main/java/org/apache/openejb/server/ejbd/RequestHandler.java
index 93fcd3d..18f1c8d 100644
--- a/server/openejb-ejbd/src/main/java/org/apache/openejb/server/ejbd/RequestHandler.java
+++ b/server/openejb-ejbd/src/main/java/org/apache/openejb/server/ejbd/RequestHandler.java
@@ -1,45 +1,45 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.openejb.server.ejbd;
-
-import org.apache.openejb.client.ProtocolMetaData;
-import org.apache.openejb.client.Response;
-import org.apache.openejb.util.Logger;
-
-import java.io.ObjectInputStream;
-import java.io.ObjectOutputStream;
-
-public abstract class RequestHandler {
-
-    final EjbDaemon daemon;
-
-    protected RequestHandler(final EjbDaemon daemon) {
-        this.daemon = daemon;
-    }
-
-    public EjbDaemon getDaemon() {
-        return daemon;
-    }
-
-    public abstract String getName();
-
-    public abstract Logger getLogger();
-
-    public abstract Response processRequest(final ObjectInputStream in, final ProtocolMetaData metaData) throws Exception;
-
-    public abstract void processResponse(final Response response, final ObjectOutputStream out, final ProtocolMetaData metaData) throws Exception;
-}
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.openejb.server.ejbd;
+
+import org.apache.openejb.client.ProtocolMetaData;
+import org.apache.openejb.client.Response;
+import org.apache.openejb.util.Logger;
+
+import java.io.ObjectInputStream;
+import java.io.ObjectOutputStream;
+
+public abstract class RequestHandler {
+
+    final EjbDaemon daemon;
+
+    protected RequestHandler(final EjbDaemon daemon) {
+        this.daemon = daemon;
+    }
+
+    public EjbDaemon getDaemon() {
+        return daemon;
+    }
+
+    public abstract String getName();
+
+    public abstract Logger getLogger();
+
+    public abstract Response processRequest(final ObjectInputStream in, final ProtocolMetaData metaData) throws Exception;
+
+    public abstract void processResponse(final Response response, final ObjectOutputStream out, final ProtocolMetaData metaData) throws Exception;
+}

http://git-wip-us.apache.org/repos/asf/tomee/blob/81d3cd3a/server/openejb-multicast/src/main/resources/META-INF/org.apache.openejb.server.ServerService/multipulse
----------------------------------------------------------------------
diff --git a/server/openejb-multicast/src/main/resources/META-INF/org.apache.openejb.server.ServerService/multipulse b/server/openejb-multicast/src/main/resources/META-INF/org.apache.openejb.server.ServerService/multipulse
index 9f6f174..1ac80f9 100644
--- a/server/openejb-multicast/src/main/resources/META-INF/org.apache.openejb.server.ServerService/multipulse
+++ b/server/openejb-multicast/src/main/resources/META-INF/org.apache.openejb.server.ServerService/multipulse
@@ -1,4 +1,4 @@
-server      = org.apache.openejb.server.discovery.MulticastPulseAgent
-bind        = 239.255.2.3
-port        = 6142
+server      = org.apache.openejb.server.discovery.MulticastPulseAgent
+bind        = 239.255.2.3
+port        = 6142
 disabled    = ${openejb.profile.custom}
\ No newline at end of file