You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@logging.apache.org by mi...@apache.org on 2017/04/10 14:11:35 UTC

[03/14] logging-log4j2 git commit: Move server components from core to new server module

Move server components from core to new server module


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

Branch: refs/heads/master
Commit: f515fa3c4ab8ecca83f75bcb29ceb71b54c61bc4
Parents: 67c18b0
Author: Mikael St�ldal <mi...@magine.com>
Authored: Fri Mar 17 14:42:19 2017 +0100
Committer: Mikael St�ldal <mi...@magine.com>
Committed: Fri Mar 17 14:43:19 2017 +0100

----------------------------------------------------------------------
 .../core/net/mom/jms/AbstractJmsReceiver.java   |  48 ---
 .../core/net/mom/jms/JmsQueueReceiver.java      |  46 ---
 .../core/net/mom/jms/JmsTopicReceiver.java      |  46 ---
 .../log4j/core/net/mom/jms/package-info.java    |  26 --
 .../core/net/server/AbstractLogEventBridge.java |  44 ---
 .../core/net/server/AbstractSocketServer.java   | 209 ------------
 .../net/server/InputStreamLogEventBridge.java   | 103 ------
 .../log4j/core/net/server/JmsServer.java        | 148 ---------
 .../server/JsonInputStreamLogEventBridge.java   |  90 ------
 .../log4j/core/net/server/LogEventBridge.java   |  57 ----
 .../server/ObjectInputStreamLogEventBridge.java |  45 ---
 .../core/net/server/SecureTcpSocketServer.java  |  37 ---
 .../log4j/core/net/server/TcpSocketServer.java  | 314 -------------------
 .../log4j/core/net/server/UdpSocketServer.java  | 169 ----------
 .../server/XmlInputStreamLogEventBridge.java    |  54 ----
 .../log4j/core/net/server/package-info.java     |  24 --
 .../net/server/AbstractSocketServerTest.java    | 237 --------------
 .../core/net/server/SslXmlSocketServerTest.java | 104 ------
 .../net/server/TcpJsonSocketServerTest.java     |  62 ----
 .../server/TcpSerializedSocketServerTest.java   |  63 ----
 .../core/net/server/TcpXmlSocketServerTest.java |  65 ----
 .../log4j/core/net/server/ThreadIdFilter.java   |  40 ---
 .../log4j/core/net/server/ThreadNameFilter.java |  39 ---
 .../core/net/server/ThreadPriorityFilter.java   |  40 ---
 .../net/server/UdpJsonSocketServerTest.java     |  58 ----
 .../server/UdpSerializedSocketServerTest.java   |  60 ----
 .../core/net/server/UdpXmlSocketServerTest.java |  61 ----
 log4j-server/pom.xml                            | 197 ++++++++++++
 .../core/net/mom/jms/AbstractJmsReceiver.java   |  48 +++
 .../core/net/mom/jms/JmsQueueReceiver.java      |  46 +++
 .../core/net/mom/jms/JmsTopicReceiver.java      |  46 +++
 .../log4j/core/net/mom/jms/package-info.java    |  26 ++
 .../core/net/server/AbstractLogEventBridge.java |  44 +++
 .../core/net/server/AbstractSocketServer.java   | 209 ++++++++++++
 .../net/server/InputStreamLogEventBridge.java   | 103 ++++++
 .../log4j/core/net/server/JmsServer.java        | 148 +++++++++
 .../server/JsonInputStreamLogEventBridge.java   |  90 ++++++
 .../log4j/core/net/server/LogEventBridge.java   |  57 ++++
 .../server/ObjectInputStreamLogEventBridge.java |  45 +++
 .../core/net/server/SecureTcpSocketServer.java  |  37 +++
 .../log4j/core/net/server/TcpSocketServer.java  | 314 +++++++++++++++++++
 .../log4j/core/net/server/UdpSocketServer.java  | 169 ++++++++++
 .../server/XmlInputStreamLogEventBridge.java    |  54 ++++
 .../log4j/core/net/server/package-info.java     |  24 ++
 log4j-server/src/site/markdown/index.md         |  29 ++
 log4j-server/src/site/site.xml                  |  52 +++
 .../net/server/AbstractSocketServerTest.java    | 237 ++++++++++++++
 .../core/net/server/SslXmlSocketServerTest.java | 104 ++++++
 .../net/server/TcpJsonSocketServerTest.java     |  62 ++++
 .../server/TcpSerializedSocketServerTest.java   |  63 ++++
 .../core/net/server/TcpXmlSocketServerTest.java |  65 ++++
 .../log4j/core/net/server/ThreadIdFilter.java   |  40 +++
 .../log4j/core/net/server/ThreadNameFilter.java |  39 +++
 .../core/net/server/ThreadPriorityFilter.java   |  40 +++
 .../net/server/UdpJsonSocketServerTest.java     |  58 ++++
 .../server/UdpSerializedSocketServerTest.java   |  60 ++++
 .../core/net/server/UdpXmlSocketServerTest.java |  61 ++++
 pom.xml                                         |   6 +
 58 files changed, 2573 insertions(+), 2289 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/logging-log4j2/blob/f515fa3c/log4j-core/src/main/java/org/apache/logging/log4j/core/net/mom/jms/AbstractJmsReceiver.java
----------------------------------------------------------------------
diff --git a/log4j-core/src/main/java/org/apache/logging/log4j/core/net/mom/jms/AbstractJmsReceiver.java b/log4j-core/src/main/java/org/apache/logging/log4j/core/net/mom/jms/AbstractJmsReceiver.java
deleted file mode 100644
index 753fc80..0000000
--- a/log4j-core/src/main/java/org/apache/logging/log4j/core/net/mom/jms/AbstractJmsReceiver.java
+++ /dev/null
@@ -1,48 +0,0 @@
-/*
- * 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.logging.log4j.core.net.mom.jms;
-
-import org.apache.logging.log4j.core.net.server.JmsServer;
-
-/**
- * Common JMS server functionality.
- *
- * @since 2.6
- */
-public abstract class AbstractJmsReceiver {
-
-    /**
-     * Prints out usage information to {@linkplain System#err standard error}.
-     */
-    protected abstract void usage();
-
-    /**
-     * Executes a JmsServer with the given command line arguments.
-     *
-     * @param args command line arguments
-     * @throws Exception
-     */
-    protected void doMain(final String... args) throws Exception {
-        if (args.length != 4) {
-            usage();
-            System.exit(1);
-        }
-        final JmsServer server = new JmsServer(args[0], args[1], args[2], args[3]);
-        server.run();
-    }
-}

http://git-wip-us.apache.org/repos/asf/logging-log4j2/blob/f515fa3c/log4j-core/src/main/java/org/apache/logging/log4j/core/net/mom/jms/JmsQueueReceiver.java
----------------------------------------------------------------------
diff --git a/log4j-core/src/main/java/org/apache/logging/log4j/core/net/mom/jms/JmsQueueReceiver.java b/log4j-core/src/main/java/org/apache/logging/log4j/core/net/mom/jms/JmsQueueReceiver.java
deleted file mode 100644
index dac46d3..0000000
--- a/log4j-core/src/main/java/org/apache/logging/log4j/core/net/mom/jms/JmsQueueReceiver.java
+++ /dev/null
@@ -1,46 +0,0 @@
-/*
- * 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.logging.log4j.core.net.mom.jms;
-
-/**
- * Receives Log Events over a JMS Queue. This implementation expects that all messages will
- * contain a serialized LogEvent.
- */
-public class JmsQueueReceiver extends AbstractJmsReceiver {
-
-    private JmsQueueReceiver() {
-    }
-
-    /**
-     * Main startup for the receiver.
-     *
-     * @param args The command line arguments.
-     * @throws Exception if an error occurs.
-     */
-    public static void main(final String[] args) throws Exception {
-        final JmsQueueReceiver receiver = new JmsQueueReceiver();
-        receiver.doMain(args);
-    }
-
-    @Override
-    protected void usage() {
-        System.err.println("Wrong number of arguments.");
-        System.err.println("Usage: java " + JmsQueueReceiver.class.getName()
-            + " QueueConnectionFactoryBindingName QueueBindingName username password");
-    }
-}

http://git-wip-us.apache.org/repos/asf/logging-log4j2/blob/f515fa3c/log4j-core/src/main/java/org/apache/logging/log4j/core/net/mom/jms/JmsTopicReceiver.java
----------------------------------------------------------------------
diff --git a/log4j-core/src/main/java/org/apache/logging/log4j/core/net/mom/jms/JmsTopicReceiver.java b/log4j-core/src/main/java/org/apache/logging/log4j/core/net/mom/jms/JmsTopicReceiver.java
deleted file mode 100644
index 4442ab1..0000000
--- a/log4j-core/src/main/java/org/apache/logging/log4j/core/net/mom/jms/JmsTopicReceiver.java
+++ /dev/null
@@ -1,46 +0,0 @@
-/*
- * 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.logging.log4j.core.net.mom.jms;
-
-/**
- * Receives Topic messages that contain LogEvents. This implementation expects that all messages
- * are serialized log events.
- */
-public class JmsTopicReceiver extends AbstractJmsReceiver {
-
-    private JmsTopicReceiver() {
-    }
-
-    /**
-     * Main startup for the receiver.
-     *
-     * @param args The command line arguments.
-     * @throws Exception if an error occurs.
-     */
-    public static void main(final String[] args) throws Exception {
-        final JmsTopicReceiver receiver = new JmsTopicReceiver();
-        receiver.doMain(args);
-    }
-
-    @Override
-    protected void usage() {
-        System.err.println("Wrong number of arguments.");
-        System.err.println("Usage: java " + JmsTopicReceiver.class.getName()
-            + " TopicConnectionFactoryBindingName TopicBindingName username password");
-    }
-}

http://git-wip-us.apache.org/repos/asf/logging-log4j2/blob/f515fa3c/log4j-core/src/main/java/org/apache/logging/log4j/core/net/mom/jms/package-info.java
----------------------------------------------------------------------
diff --git a/log4j-core/src/main/java/org/apache/logging/log4j/core/net/mom/jms/package-info.java b/log4j-core/src/main/java/org/apache/logging/log4j/core/net/mom/jms/package-info.java
deleted file mode 100644
index 9c3e03e..0000000
--- a/log4j-core/src/main/java/org/apache/logging/log4j/core/net/mom/jms/package-info.java
+++ /dev/null
@@ -1,26 +0,0 @@
-/*
- * 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.
- */
-
-/**
- * Supporting network code for JMS appenders.
- *
- * <p>Note that you can use JmsQueueReceiver or JmsTopicReceiver as executable main classes to receive log events over
- * JMS (sent via the appropriate JMS appender) that can be subsequently logged according to the configuration given to
- * the running process. Of course, use of these classes as standalone executables are entirely optional and can
- * be used directly in your application (e.g., through your Spring {@code beans.xml} configuration).</p>
- */
-package org.apache.logging.log4j.core.net.mom.jms;

http://git-wip-us.apache.org/repos/asf/logging-log4j2/blob/f515fa3c/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/AbstractLogEventBridge.java
----------------------------------------------------------------------
diff --git a/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/AbstractLogEventBridge.java b/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/AbstractLogEventBridge.java
deleted file mode 100644
index 59b889b..0000000
--- a/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/AbstractLogEventBridge.java
+++ /dev/null
@@ -1,44 +0,0 @@
-/*
- * 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.logging.log4j.core.net.server;
-
-import java.io.IOException;
-import java.io.InputStream;
-
-import org.apache.logging.log4j.Logger;
-import org.apache.logging.log4j.status.StatusLogger;
-
-/**
- * Abstract class for implementations of {@link LogEventBridge}.
- * 
- * @param <T>
- *            The kind of input stream read
- */
-public abstract class AbstractLogEventBridge<T extends InputStream> implements LogEventBridge<T> {
-
-    protected static final int END = -1;
-
-    protected static final Logger logger = StatusLogger.getLogger();
-
-    // The default is to return the same object as given.
-    @SuppressWarnings("unchecked")
-    @Override
-    public T wrapStream(final InputStream inputStream) throws IOException {
-        return (T) inputStream;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/logging-log4j2/blob/f515fa3c/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/AbstractSocketServer.java
----------------------------------------------------------------------
diff --git a/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/AbstractSocketServer.java b/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/AbstractSocketServer.java
deleted file mode 100644
index 9836694..0000000
--- a/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/AbstractSocketServer.java
+++ /dev/null
@@ -1,209 +0,0 @@
-/*
- * 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.logging.log4j.core.net.server;
-
-import java.io.BufferedReader;
-import java.io.File;
-import java.io.FileInputStream;
-import java.io.FileNotFoundException;
-import java.io.IOException;
-import java.io.InputStream;
-import java.io.InputStreamReader;
-import java.net.InetAddress;
-import java.net.URI;
-import java.net.URL;
-import java.util.Objects;
-
-import com.beust.jcommander.Parameter;
-import com.beust.jcommander.validators.PositiveInteger;
-import org.apache.logging.log4j.LogManager;
-import org.apache.logging.log4j.Logger;
-import org.apache.logging.log4j.core.LogEventListener;
-import org.apache.logging.log4j.core.LoggerContext;
-import org.apache.logging.log4j.core.config.Configuration;
-import org.apache.logging.log4j.core.config.ConfigurationSource;
-import org.apache.logging.log4j.core.config.xml.XmlConfiguration;
-import org.apache.logging.log4j.core.config.xml.XmlConfigurationFactory;
-import org.apache.logging.log4j.core.util.BasicCommandLineArguments;
-import org.apache.logging.log4j.core.util.InetAddressConverter;
-import org.apache.logging.log4j.core.util.Log4jThread;
-import org.apache.logging.log4j.util.Strings;
-
-/**
- * Abstract socket server for TCP and UDP implementations.
- *
- * @param <T>
- *            The kind of input stream read
- *
- *            TODO Make a LifeCycle
- */
-public abstract class AbstractSocketServer<T extends InputStream> extends LogEventListener implements Runnable {
-
-    protected static class CommandLineArguments extends BasicCommandLineArguments {
-
-        @Parameter(names = { "--config", "-c" }, description = "Log4j configuration file location (path or URL).")
-        private String configLocation;
-
-        @Parameter(names = { "--interactive",
-                "-i" }, description = "Accepts commands on standard input (\"exit\" is the only command).")
-        private boolean interactive;
-
-        @Parameter(names = { "--port",
-                "-p" }, validateWith = PositiveInteger.class, description = "Server socket port.")
-        private int port;
-
-        @Parameter(names = { "--localbindaddress",
-                "-a" }, converter = InetAddressConverter.class, description = "Server socket local bind address.")
-        private InetAddress localBindAddress;
-
-        String getConfigLocation() {
-            return configLocation;
-        }
-
-        int getPort() {
-            return port;
-        }
-
-        protected boolean isInteractive() {
-            return interactive;
-        }
-
-        void setConfigLocation(final String configLocation) {
-            this.configLocation = configLocation;
-        }
-
-        void setInteractive(final boolean interactive) {
-            this.interactive = interactive;
-        }
-
-        void setPort(final int port) {
-            this.port = port;
-        }
-
-        InetAddress getLocalBindAddress() {
-            return localBindAddress;
-        }
-
-        void setLocalBindAddress(final InetAddress localBindAddress) {
-            this.localBindAddress = localBindAddress;
-        }
-    }
-
-    /**
-     * Factory that creates a Configuration for the server.
-     */
-    protected static class ServerConfigurationFactory extends XmlConfigurationFactory {
-
-        private final String path;
-
-        public ServerConfigurationFactory(final String path) {
-            this.path = path;
-        }
-
-        @Override
-        public Configuration getConfiguration(final LoggerContext loggerContext, final String name,
-                final URI configLocation) {
-            if (Strings.isNotEmpty(path)) {
-                File file = null;
-                ConfigurationSource source = null;
-                try {
-                    file = new File(path);
-                    final FileInputStream is = new FileInputStream(file);
-                    source = new ConfigurationSource(is, file);
-                } catch (final FileNotFoundException ignored) {
-                    // Ignore this error
-                }
-                if (source == null) {
-                    try {
-                        final URL url = new URL(path);
-                        source = new ConfigurationSource(url.openStream(), url);
-                    } catch (final IOException ignored) {
-                        // Ignore this error
-                    }
-                }
-
-                try {
-                    if (source != null) {
-                        return new XmlConfiguration(loggerContext, source);
-                    }
-                } catch (final Exception ignored) {
-                    // Ignore this error.
-                }
-                System.err.println("Unable to process configuration at " + path + ", using default.");
-            }
-            return super.getConfiguration(loggerContext, name, configLocation);
-        }
-    }
-
-    protected static final int MAX_PORT = 65534;
-
-    private volatile boolean active = true;
-
-    protected final LogEventBridge<T> logEventInput;
-
-    protected final Logger logger;
-
-    /**
-     * Creates a new socket server.
-     *
-     * @param port
-     *            listen to this port
-     * @param logEventInput
-     *            Use this input to read log events.
-     */
-    public AbstractSocketServer(final int port, final LogEventBridge<T> logEventInput) {
-        this.logger = LogManager.getLogger(this.getClass().getName() + '.' + port);
-        this.logEventInput = Objects.requireNonNull(logEventInput, "LogEventInput");
-    }
-
-    protected boolean isActive() {
-        return this.active;
-    }
-
-    protected void setActive(final boolean isActive) {
-        this.active = isActive;
-    }
-
-    /**
-     * Start this server in a new thread.
-     *
-     * @return the new thread that running this server.
-     */
-    public Thread startNewThread() {
-        final Thread thread = new Log4jThread(this);
-        thread.start();
-        return thread;
-    }
-
-    public abstract void shutdown() throws Exception;
-
-    public void awaitTermination(final Thread serverThread) throws Exception {
-        final BufferedReader reader = new BufferedReader(new InputStreamReader(System.in));
-        while (true) {
-            final String line = reader.readLine();
-            if (line == null
-                || line.equalsIgnoreCase("quit")
-                || line.equalsIgnoreCase("stop")
-                || line.equalsIgnoreCase("exit")) {
-                this.shutdown();
-                serverThread.join();
-                break;
-            }
-        }
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/logging-log4j2/blob/f515fa3c/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/InputStreamLogEventBridge.java
----------------------------------------------------------------------
diff --git a/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/InputStreamLogEventBridge.java b/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/InputStreamLogEventBridge.java
deleted file mode 100644
index 11b4aa4..0000000
--- a/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/InputStreamLogEventBridge.java
+++ /dev/null
@@ -1,103 +0,0 @@
-/*
- * 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.logging.log4j.core.net.server;
-
-import java.io.IOException;
-import java.io.InputStream;
-import java.nio.charset.Charset;
-
-import org.apache.logging.log4j.core.LogEvent;
-import org.apache.logging.log4j.core.LogEventListener;
-import org.apache.logging.log4j.core.impl.Log4jLogEvent;
-import org.apache.logging.log4j.util.Strings;
-
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.fasterxml.jackson.databind.ObjectReader;
-
-/**
- * Reads and logs {@link LogEvent}s from an {@link InputStream}.
- */
-public abstract class InputStreamLogEventBridge extends AbstractLogEventBridge<InputStream> {
-
-    private final int bufferSize;
-
-    private final Charset charset;
-
-    private final String eventEndMarker;
-    
-    private final ObjectReader objectReader;
-    
-    public InputStreamLogEventBridge(final ObjectMapper mapper, final int bufferSize, final Charset charset, final String eventEndMarker) {
-        this.bufferSize = bufferSize;
-        this.charset = charset;
-        this.eventEndMarker = eventEndMarker;
-        this.objectReader = mapper.readerFor(Log4jLogEvent.class);
-    }
-
-    abstract protected int[] getEventIndices(final String text, int beginIndex);
-
-    @Override
-    public void logEvents(final InputStream inputStream, final LogEventListener logEventListener) throws IOException {
-        String workingText = Strings.EMPTY;
-        try {
-            // Allocate buffer once
-            final byte[] buffer = new byte[bufferSize];
-            String textRemains = workingText = Strings.EMPTY;
-            while (true) {
-                // Process until the stream is EOF.
-                final int streamReadLength = inputStream.read(buffer);
-                if (streamReadLength == END) {
-                    // The input stream is EOF
-                    break;
-                }
-                final String text = workingText = textRemains + new String(buffer, 0, streamReadLength, charset);
-                int beginIndex = 0;
-                while (true) {
-                    // Extract and log all XML events in the buffer
-                    final int[] pair = getEventIndices(text, beginIndex);
-                    final int eventStartMarkerIndex = pair[0];
-                    if (eventStartMarkerIndex < 0) {
-                        // No more events or partial XML only in the buffer.
-                        // Save the unprocessed string part
-                        textRemains = text.substring(beginIndex);
-                        break;
-                    }
-                    final int eventEndMarkerIndex = pair[1];
-                    if (eventEndMarkerIndex > 0) {
-                        final int eventEndXmlIndex = eventEndMarkerIndex + eventEndMarker.length();
-                        final String textEvent = workingText = text.substring(eventStartMarkerIndex, eventEndXmlIndex);
-                        final LogEvent logEvent = unmarshal(textEvent);
-                        logEventListener.log(logEvent);
-                        beginIndex = eventEndXmlIndex;
-                    } else {
-                        // No more events or partial XML only in the buffer.
-                        // Save the unprocessed string part
-                        textRemains = text.substring(beginIndex);
-                        break;
-                    }
-                }
-            }
-        } catch (final IOException ex) {
-            logger.error(workingText, ex);
-        }
-    }
-
-    protected Log4jLogEvent unmarshal(final String jsonEvent) throws IOException {
-        return this.objectReader.readValue(jsonEvent);
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/logging-log4j2/blob/f515fa3c/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/JmsServer.java
----------------------------------------------------------------------
diff --git a/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/JmsServer.java b/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/JmsServer.java
deleted file mode 100644
index bcbba40..0000000
--- a/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/JmsServer.java
+++ /dev/null
@@ -1,148 +0,0 @@
-/*
- * 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.logging.log4j.core.net.server;
-
-import java.io.BufferedReader;
-import java.io.IOException;
-import java.io.InputStreamReader;
-import java.nio.charset.Charset;
-import java.util.concurrent.TimeUnit;
-import java.util.concurrent.atomic.AtomicReference;
-import javax.jms.JMSException;
-import javax.jms.Message;
-import javax.jms.MessageConsumer;
-import javax.jms.MessageListener;
-import javax.jms.ObjectMessage;
-
-import org.apache.logging.log4j.LoggingException;
-import org.apache.logging.log4j.core.AbstractLifeCycle;
-import org.apache.logging.log4j.core.LifeCycle2;
-import org.apache.logging.log4j.core.LogEvent;
-import org.apache.logging.log4j.core.LogEventListener;
-import org.apache.logging.log4j.core.appender.mom.JmsManager;
-import org.apache.logging.log4j.core.net.JndiManager;
-
-/**
- * LogEventListener server that receives LogEvents over a JMS {@link javax.jms.Destination}.
- *
- * @since 2.1
- */
-public class JmsServer extends LogEventListener implements MessageListener, LifeCycle2 {
-
-    private final AtomicReference<State> state = new AtomicReference<>(State.INITIALIZED);
-    private final JmsManager jmsManager;
-    private MessageConsumer messageConsumer;
-
-    public JmsServer(final String connectionFactoryBindingName,
-                     final String destinationBindingName,
-                     final String username,
-                     final String password) {
-        final String managerName = JmsServer.class.getName() + '@' + JmsServer.class.hashCode();
-        final JndiManager jndiManager = JndiManager.getDefaultManager(managerName);
-        jmsManager = JmsManager.getJmsManager(managerName, jndiManager, connectionFactoryBindingName,
-            destinationBindingName, username, password);
-    }
-
-    @Override
-    public State getState() {
-        return state.get();
-    }
-
-    @Override
-    public void onMessage(final Message message) {
-        try {
-            if (message instanceof ObjectMessage) {
-                final Object body = ((ObjectMessage) message).getObject();
-                if (body instanceof LogEvent) {
-                    log((LogEvent) body);
-                } else {
-                    LOGGER.warn("Expected ObjectMessage to contain LogEvent. Got type {} instead.", body.getClass());
-                }
-            } else {
-                LOGGER.warn("Received message of type {} and JMSType {} which cannot be handled.", message.getClass(),
-                    message.getJMSType());
-            }
-        } catch (final JMSException e) {
-            LOGGER.catching(e);
-        }
-    }
-
-    @Override
-    public void initialize() {
-    }
-
-    @Override
-    public void start() {
-        if (state.compareAndSet(State.INITIALIZED, State.STARTING)) {
-            try {
-                messageConsumer = jmsManager.createMessageConsumer();
-                messageConsumer.setMessageListener(this);
-            } catch (final JMSException e) {
-                throw new LoggingException(e);
-            }
-        }
-    }
-
-    @Override
-    public void stop() {
-        stop(AbstractLifeCycle.DEFAULT_STOP_TIMEOUT, AbstractLifeCycle.DEFAULT_STOP_TIMEUNIT);
-    }
-
-    @Override
-    public boolean stop(final long timeout, final TimeUnit timeUnit) {
-        boolean stopped = true;
-        try {
-            messageConsumer.close();
-        } catch (final JMSException e) {
-            LOGGER.debug("Exception closing {}", messageConsumer, e);
-            stopped = false;
-        }
-        return stopped && jmsManager.stop(timeout, timeUnit);
-    }
-
-    @Override
-    public boolean isStarted() {
-        return state.get() == State.STARTED;
-    }
-
-    @Override
-    public boolean isStopped() {
-        return state.get() == State.STOPPED;
-    }
-
-    /**
-     * Starts and runs this server until the user types "exit" into standard input.
-     *
-     * @throws IOException
-     * @since 2.6
-     */
-    public void run() throws IOException {
-        this.start();
-        System.out.println("Type \"exit\" to quit.");
-        final BufferedReader stdin = new BufferedReader(new InputStreamReader(System.in, Charset.defaultCharset()));
-        while (true) {
-            final String line = stdin.readLine();
-            if (line == null || line.equalsIgnoreCase("exit")) {
-                System.out.println("Exiting. Kill the application if it does not exit due to daemon threads.");
-                this.stop();
-                return;
-            }
-        }
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/logging-log4j2/blob/f515fa3c/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/JsonInputStreamLogEventBridge.java
----------------------------------------------------------------------
diff --git a/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/JsonInputStreamLogEventBridge.java b/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/JsonInputStreamLogEventBridge.java
deleted file mode 100644
index a0e4fdb..0000000
--- a/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/JsonInputStreamLogEventBridge.java
+++ /dev/null
@@ -1,90 +0,0 @@
-/*
- * 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.logging.log4j.core.net.server;
-
-import java.io.InputStream;
-import java.nio.charset.Charset;
-
-import org.apache.logging.log4j.core.LogEvent;
-import org.apache.logging.log4j.core.jackson.Log4jJsonObjectMapper;
-import org.apache.logging.log4j.util.Chars;
-
-/**
- * Reads and logs JSON {@link LogEvent}s from an {@link InputStream}..
- */
-public class JsonInputStreamLogEventBridge extends InputStreamLogEventBridge {
-
-    private static final int[] END_PAIR = new int[] { END, END };
-    private static final char EVENT_END_MARKER = '}';
-    private static final char EVENT_START_MARKER = '{';
-    private static final char JSON_ESC = '\\';
-    private static final char JSON_STR_DELIM = Chars.DQUOTE;
-    private static final boolean THREAD_CONTEXT_MAP_AS_LIST = false;
-
-    public JsonInputStreamLogEventBridge() {
-        this(1024, Charset.defaultCharset());
-    }
-
-    public JsonInputStreamLogEventBridge(final int bufferSize, final Charset charset) {
-        super(new Log4jJsonObjectMapper(THREAD_CONTEXT_MAP_AS_LIST, true), bufferSize, charset,
-                String.valueOf(EVENT_END_MARKER));
-    }
-
-    @Override
-    protected int[] getEventIndices(final String text, final int beginIndex) {
-        // Scan the text for the end of the next JSON object.
-        final int start = text.indexOf(EVENT_START_MARKER, beginIndex);
-        if (start == END) {
-            return END_PAIR;
-        }
-        final char[] charArray = text.toCharArray();
-        int stack = 0;
-        boolean inStr = false;
-        boolean inEsc = false;
-        for (int i = start; i < charArray.length; i++) {
-            final char c = charArray[i];
-            if (inEsc) {
-            	// Skip this char and continue
-            	inEsc = false;
-            } else {
-                switch (c) {
-                case EVENT_START_MARKER:
-                    if (!inStr) {
-                        stack++;
-                    }
-                    break;
-                case EVENT_END_MARKER:
-                    if (!inStr) {
-                        stack--;
-                    }
-                    break;
-                case JSON_STR_DELIM:
-                    inStr = !inStr;
-                    break;
-                case JSON_ESC:
-                    inEsc = true;
-                    break;
-                }
-                if (stack == 0) {
-                    return new int[] { start, i };
-                }
-            }
-        }
-        return END_PAIR;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/logging-log4j2/blob/f515fa3c/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/LogEventBridge.java
----------------------------------------------------------------------
diff --git a/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/LogEventBridge.java b/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/LogEventBridge.java
deleted file mode 100644
index ba45bb6..0000000
--- a/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/LogEventBridge.java
+++ /dev/null
@@ -1,57 +0,0 @@
-/*
- * 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.logging.log4j.core.net.server;
-
-import java.io.IOException;
-import java.io.InputStream;
-
-import org.apache.logging.log4j.core.LogEvent;
-import org.apache.logging.log4j.core.LogEventListener;
-
-/**
- * Reads {@link LogEvent}s from the given input stream and logs them as they are discovered on the given logger.
- * 
- * <p>
- * Should be stateless.
- * </p>
- * 
- * @param <T>
- *            The kind of {@link InputStream} to wrap and read.
- */
-public interface LogEventBridge<T extends InputStream> {
-
-    /**
-     * Reads {@link LogEvent}s from the given input stream and logs them as they are discovered on the given logger.
-     * 
-     * @param inputStream
-     *            the input stream to read
-     * @param logEventListener
-     *            TODO
-     * @throws IOException
-     */
-    void logEvents(T inputStream, LogEventListener logEventListener) throws IOException;
-
-    /**
-     * Wraps the given stream if needed.
-     * 
-     * @param inputStream
-     *            the stream to wrap
-     * @return the wrapped stream or the given stream.
-     * @throws IOException
-     */
-    T wrapStream(InputStream inputStream) throws IOException;
-}

http://git-wip-us.apache.org/repos/asf/logging-log4j2/blob/f515fa3c/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/ObjectInputStreamLogEventBridge.java
----------------------------------------------------------------------
diff --git a/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/ObjectInputStreamLogEventBridge.java b/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/ObjectInputStreamLogEventBridge.java
deleted file mode 100644
index 059f069..0000000
--- a/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/ObjectInputStreamLogEventBridge.java
+++ /dev/null
@@ -1,45 +0,0 @@
-/*
- * 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.logging.log4j.core.net.server;
-
-import java.io.IOException;
-import java.io.InputStream;
-import java.io.ObjectInputStream;
-
-import org.apache.logging.log4j.core.LogEvent;
-import org.apache.logging.log4j.core.LogEventListener;
-
-/**
- * Reads and logs serialized {@link LogEvent} objects from an {@link ObjectInputStream}.
- */
-public class ObjectInputStreamLogEventBridge extends AbstractLogEventBridge<ObjectInputStream> {
-
-    @Override
-    public void logEvents(final ObjectInputStream inputStream, final LogEventListener logEventListener)
-            throws IOException {
-        try {
-            logEventListener.log((LogEvent) inputStream.readObject());
-        } catch (final ClassNotFoundException e) {
-            throw new IOException(e);
-        }
-    }
-
-    @Override
-    public ObjectInputStream wrapStream(final InputStream inputStream) throws IOException {
-        return new ObjectInputStream(inputStream);
-    }
-}

http://git-wip-us.apache.org/repos/asf/logging-log4j2/blob/f515fa3c/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/SecureTcpSocketServer.java
----------------------------------------------------------------------
diff --git a/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/SecureTcpSocketServer.java b/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/SecureTcpSocketServer.java
deleted file mode 100644
index 87390e8..0000000
--- a/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/SecureTcpSocketServer.java
+++ /dev/null
@@ -1,37 +0,0 @@
-/*
- * 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.logging.log4j.core.net.server;
-
-import java.io.IOException;
-import java.io.InputStream;
-
-import org.apache.logging.log4j.core.net.ssl.SslConfiguration;
-
-/**
- * Listens for events over a secure socket connection (SSL/TLS).
- * 
- * @param <T>
- *        The kind of input stream read
- */
-public class SecureTcpSocketServer<T extends InputStream> extends TcpSocketServer<T> {
-
-    public SecureTcpSocketServer(final int port, final LogEventBridge<T> logEventInput,
-            final SslConfiguration sslConfig) throws IOException {
-        super(port, logEventInput, sslConfig.getSslServerSocketFactory().createServerSocket(port));
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/logging-log4j2/blob/f515fa3c/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/TcpSocketServer.java
----------------------------------------------------------------------
diff --git a/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/TcpSocketServer.java b/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/TcpSocketServer.java
deleted file mode 100644
index 68ac1ba..0000000
--- a/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/TcpSocketServer.java
+++ /dev/null
@@ -1,314 +0,0 @@
-/*
- * 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.logging.log4j.core.net.server;
-
-import java.io.EOFException;
-import java.io.IOException;
-import java.io.InputStream;
-import java.io.ObjectInputStream;
-import java.io.OptionalDataException;
-import java.net.InetAddress;
-import java.net.ServerSocket;
-import java.net.Socket;
-import java.util.Map;
-import java.util.concurrent.ConcurrentHashMap;
-import java.util.concurrent.ConcurrentMap;
-
-import com.beust.jcommander.Parameter;
-import com.beust.jcommander.validators.PositiveInteger;
-import org.apache.logging.log4j.core.config.ConfigurationFactory;
-import org.apache.logging.log4j.core.util.BasicCommandLineArguments;
-import org.apache.logging.log4j.core.util.Closer;
-import org.apache.logging.log4j.core.util.Log4jThread;
-import org.apache.logging.log4j.message.EntryMessage;
-
-/**
- * Listens for Log4j events on a TCP server socket and passes them on to Log4j.
- * 
- * @param <T>
- *        The kind of input stream read
- * @see #main(String[])
- */
-public class TcpSocketServer<T extends InputStream> extends AbstractSocketServer<T> {
-
-    protected static class CommandLineArguments extends AbstractSocketServer.CommandLineArguments {
-        
-        @Parameter(names = { "--backlog",
-                "-b" }, validateWith = PositiveInteger.class, description = "Server socket backlog.")
-        // Same default as ServerSocket
-        private int backlog = 50;
-
-        int getBacklog() {
-            return backlog;
-        }
-
-        void setBacklog(final int backlog) {
-            this.backlog = backlog;
-        }        
-
-    }
-
-    /**
-     * Thread that processes the events.
-     */
-    private class SocketHandler extends Log4jThread {
-
-        private final T inputStream;
-
-        private volatile boolean shutdown = false;
-
-        public SocketHandler(final Socket socket) throws IOException {
-            this.inputStream = logEventInput.wrapStream(socket.getInputStream());
-        }
-
-        @Override
-        public void run() {
-            final EntryMessage entry = logger.traceEntry();
-            boolean closed = false;
-            try {
-                try {
-                    while (!shutdown) {
-                        logEventInput.logEvents(inputStream, TcpSocketServer.this);
-                    }
-                } catch (final EOFException e) {
-                    closed = true;
-                } catch (final OptionalDataException e) {
-                    logger.error("OptionalDataException eof=" + e.eof + " length=" + e.length, e);
-                } catch (final IOException e) {
-                    logger.error("IOException encountered while reading from socket", e);
-                }
-                if (!closed) {
-                    Closer.closeSilently(inputStream);
-                }
-            } finally {
-                handlers.remove(Long.valueOf(getId()));
-            }
-            logger.traceExit(entry);
-        }
-
-        public void shutdown() {
-            this.shutdown = true;
-            interrupt();
-        }
-    }
-
-    /**
-     * Creates a socket server that reads JSON log events.
-     * 
-     * @param port
-     *        the port to listen
-     * @return a new a socket server
-     * @throws IOException
-     *         if an I/O error occurs when opening the socket.
-     */
-    public static TcpSocketServer<InputStream> createJsonSocketServer(final int port) throws IOException {
-        LOGGER.entry("createJsonSocketServer", port);
-        final TcpSocketServer<InputStream> socketServer = new TcpSocketServer<>(port, new JsonInputStreamLogEventBridge());
-        return LOGGER.exit(socketServer);
-    }
-
-    /**
-     * Creates a socket server that reads serialized log events.
-     * 
-     * @param port
-     *        the port to listen
-     * @return a new a socket server
-     * @throws IOException
-     *         if an I/O error occurs when opening the socket.
-     */
-    public static TcpSocketServer<ObjectInputStream> createSerializedSocketServer(final int port) throws IOException {
-        LOGGER.entry(port);
-        final TcpSocketServer<ObjectInputStream> socketServer = new TcpSocketServer<>(port, new ObjectInputStreamLogEventBridge());
-        return LOGGER.exit(socketServer);
-    }
-
-    /**
-     * Creates a socket server that reads serialized log events.
-     * 
-     * @param port the port to listen
-     * @param localBindAddress The server socket's local bin address
-     * @return a new a socket server
-     * @throws IOException
-     *         if an I/O error occurs when opening the socket.
-     * @since 2.7
-     */
-    public static TcpSocketServer<ObjectInputStream> createSerializedSocketServer(final int port, final int backlog,
-            final InetAddress localBindAddress) throws IOException {
-        LOGGER.entry(port);
-        final TcpSocketServer<ObjectInputStream> socketServer = new TcpSocketServer<>(port, backlog, localBindAddress,
-                new ObjectInputStreamLogEventBridge());
-        return LOGGER.exit(socketServer);
-    }
-
-    /**
-     * Creates a socket server that reads XML log events.
-     * 
-     * @param port
-     *        the port to listen
-     * @return a new a socket server
-     * @throws IOException
-     *         if an I/O error occurs when opening the socket.
-     */
-    public static TcpSocketServer<InputStream> createXmlSocketServer(final int port) throws IOException {
-        LOGGER.entry(port);
-        final TcpSocketServer<InputStream> socketServer = new TcpSocketServer<>(port, new XmlInputStreamLogEventBridge());
-        return LOGGER.exit(socketServer);
-    }
-
-    /**
-     * Main startup for the server. Run with "--help" for to print command line help on the console.
-     * 
-     * @param args
-     *        The command line arguments.
-     * @throws Exception
-     *         if an error occurs.
-     */
-    public static void main(final String[] args) throws Exception {
-        final CommandLineArguments cla = BasicCommandLineArguments.parseCommandLine(args, TcpSocketServer.class, new CommandLineArguments());
-        if (cla.isHelp()) {
-            return;
-        }
-        if (cla.getConfigLocation() != null) {
-            ConfigurationFactory.setConfigurationFactory(new ServerConfigurationFactory(cla.getConfigLocation()));
-        }
-        final TcpSocketServer<ObjectInputStream> socketServer = TcpSocketServer
-                .createSerializedSocketServer(cla.getPort(), cla.getBacklog(), cla.getLocalBindAddress());
-        final Thread serverThread = socketServer.startNewThread();
-        if (cla.isInteractive()) {
-            socketServer.awaitTermination(serverThread);
-        }
-    }
-
-    private final ConcurrentMap<Long, SocketHandler> handlers = new ConcurrentHashMap<>();
-
-    private final ServerSocket serverSocket;
-
-    /**
-     * Constructor.
-     * 
-     * @param port
-     *        The server socket port.
-     * @param backlog
-     *        The server socket backlog.
-     * @param localBindAddress TODO
-     * @param logEventInput
-     *        the log even input
-     * @throws IOException
-     *         if an I/O error occurs when opening the socket.
-     * @since 2.7
-     */
-    @SuppressWarnings("resource")
-    public TcpSocketServer(final int port, final int backlog, final InetAddress localBindAddress, final LogEventBridge<T> logEventInput) throws IOException {
-        this(port, logEventInput, new ServerSocket(port, backlog, localBindAddress));
-    }
-
-    /**
-     * Constructor.
-     * 
-     * @param port
-     *        to listen.
-     * @param logEventInput
-     *        the log even input
-     * @throws IOException
-     *         if an I/O error occurs when opening the socket.
-     */
-    public TcpSocketServer(final int port, final LogEventBridge<T> logEventInput) throws IOException {
-        this(port, logEventInput, extracted(port));
-    }
-
-    private static ServerSocket extracted(final int port) throws IOException {
-        return new ServerSocket(port);
-    }
-
-    /**
-     * Constructor.
-     * 
-     * @param port
-     *        to listen.
-     * @param logEventInput
-     *        the log even input
-     * @param serverSocket
-     *        the socket server
-     * @throws IOException
-     *         if an I/O error occurs when opening the socket.
-     */
-    public TcpSocketServer(final int port, final LogEventBridge<T> logEventInput, final ServerSocket serverSocket)
-            throws IOException {
-        super(port, logEventInput);
-        this.serverSocket = serverSocket;
-    }
-
-    /**
-     * Accept incoming events and processes them.
-     */
-    @Override
-    public void run() {
-        final EntryMessage entry = logger.traceEntry();
-        while (isActive()) {
-            if (serverSocket.isClosed()) {
-                return;
-            }
-            try {
-                // Accept incoming connections.
-                logger.debug("Listening for a connection {}...", serverSocket);
-                final Socket clientSocket = serverSocket.accept();
-                logger.debug("Acepted connection on {}...", serverSocket);
-                logger.debug("Socket accepted: {}", clientSocket);
-                clientSocket.setSoLinger(true, 0);
-
-                // accept() will block until a client connects to the server.
-                // If execution reaches this point, then it means that a client
-                // socket has been accepted.
-
-                final SocketHandler handler = new SocketHandler(clientSocket);
-                handlers.put(Long.valueOf(handler.getId()), handler);
-                handler.start();
-            } catch (final IOException e) {
-                if (serverSocket.isClosed()) {
-                    // OK we're done.
-                    logger.traceExit(entry);
-                    return;
-                }
-                logger.error("Exception encountered on accept. Ignoring. Stack trace :", e);
-            }
-        }
-        for (final Map.Entry<Long, SocketHandler> handlerEntry : handlers.entrySet()) {
-            final SocketHandler handler = handlerEntry.getValue();
-            handler.shutdown();
-            try {
-                handler.join();
-            } catch (final InterruptedException ignored) {
-                // Ignore the exception
-            }
-        }
-        logger.traceExit(entry);
-    }
-
-    /**
-     * Shutdown the server.
-     * 
-     * @throws IOException if the server socket could not be closed
-     */
-    @Override
-    public void shutdown() throws IOException {
-        final EntryMessage entry = logger.traceEntry();
-        setActive(false);
-        Thread.currentThread().interrupt();
-        serverSocket.close();
-        logger.traceExit(entry);
-    }
-}

http://git-wip-us.apache.org/repos/asf/logging-log4j2/blob/f515fa3c/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/UdpSocketServer.java
----------------------------------------------------------------------
diff --git a/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/UdpSocketServer.java b/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/UdpSocketServer.java
deleted file mode 100644
index ed04f69..0000000
--- a/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/UdpSocketServer.java
+++ /dev/null
@@ -1,169 +0,0 @@
-/*
- * 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.logging.log4j.core.net.server;
-
-import java.io.ByteArrayInputStream;
-import java.io.EOFException;
-import java.io.IOException;
-import java.io.InputStream;
-import java.io.ObjectInputStream;
-import java.io.OptionalDataException;
-import java.net.DatagramPacket;
-import java.net.DatagramSocket;
-
-import org.apache.logging.log4j.core.config.ConfigurationFactory;
-import org.apache.logging.log4j.core.util.BasicCommandLineArguments;
-
-/**
- * Listens for Log4j events on a datagram socket and passes them on to Log4j. 
- * 
- * @param <T>
- *            The kind of input stream read
- * @see #main(String[])
- */
-public class UdpSocketServer<T extends InputStream> extends AbstractSocketServer<T> {
-
-    /**
-     * Creates a socket server that reads JSON log events.
-     * 
-     * @param port
-     *            the port to listen
-     * @return a new a socket server
-     * @throws IOException
-     *             if an I/O error occurs when opening the socket.
-     */
-    public static UdpSocketServer<InputStream> createJsonSocketServer(final int port) throws IOException {
-        return new UdpSocketServer<>(port, new JsonInputStreamLogEventBridge());
-    }
-
-    /**
-     * Creates a socket server that reads serialized log events.
-     * 
-     * @param port
-     *            the port to listen
-     * @return a new a socket server
-     * @throws IOException
-     *             if an I/O error occurs when opening the socket.
-     */
-    public static UdpSocketServer<ObjectInputStream> createSerializedSocketServer(final int port) throws IOException {
-        return new UdpSocketServer<>(port, new ObjectInputStreamLogEventBridge());
-    }
-
-    /**
-     * Creates a socket server that reads XML log events.
-     * 
-     * @param port
-     *            the port to listen
-     * @return a new a socket server
-     * @throws IOException
-     *             if an I/O error occurs when opening the socket.
-     */
-    public static UdpSocketServer<InputStream> createXmlSocketServer(final int port) throws IOException {
-        return new UdpSocketServer<>(port, new XmlInputStreamLogEventBridge());
-    }
-
-    /**
-     * Main startup for the server. Run with "--help" for to print command line help on the console.
-     * 
-     * @param args
-     *            The command line arguments.
-     * @throws Exception
-     *             if an error occurs.
-     */
-    public static void main(final String[] args) throws Exception {
-        final CommandLineArguments cla = BasicCommandLineArguments.parseCommandLine(args, UdpSocketServer.class, new CommandLineArguments());
-        if (cla.isHelp()) {
-            return;
-        }
-        if (cla.getConfigLocation() != null) {
-            ConfigurationFactory.setConfigurationFactory(new ServerConfigurationFactory(cla.getConfigLocation()));
-        }
-        final UdpSocketServer<ObjectInputStream> socketServer = UdpSocketServer
-                .createSerializedSocketServer(cla.getPort());
-        final Thread serverThread = socketServer.startNewThread();
-        if (cla.isInteractive()) {
-            socketServer.awaitTermination(serverThread);
-        }
-    }
-
-    private final DatagramSocket datagramSocket;
-
-    // max size so we only have to deal with one packet
-    private final int maxBufferSize = 1024 * 65 + 1024;
-
-    /**
-     * Constructor.
-     * 
-     * @param port
-     *            to listen on.
-     * @param logEventInput
-     * @throws IOException
-     *             If an error occurs.
-     */
-    public UdpSocketServer(final int port, final LogEventBridge<T> logEventInput) throws IOException {
-        super(port, logEventInput);
-        this.datagramSocket = new DatagramSocket(port);
-    }
-
-    /**
-     * Accept incoming events and processes them.
-     */
-    @Override
-    public void run() {
-        while (isActive()) {
-            if (datagramSocket.isClosed()) {
-                // OK we're done.
-                return;
-            }
-            try {
-                final byte[] buf = new byte[maxBufferSize];
-                final DatagramPacket packet = new DatagramPacket(buf, buf.length);
-                datagramSocket.receive(packet);
-                final ByteArrayInputStream bais = new ByteArrayInputStream(packet.getData(), packet.getOffset(), packet.getLength());
-                logEventInput.logEvents(logEventInput.wrapStream(bais), this);
-            } catch (final OptionalDataException e) {
-                if (datagramSocket.isClosed()) {
-                    // OK we're done.
-                    return;
-                }
-                logger.error("OptionalDataException eof=" + e.eof + " length=" + e.length, e);
-            } catch (final EOFException e) {
-                if (datagramSocket.isClosed()) {
-                    // OK we're done.
-                    return;
-                }
-                logger.info("EOF encountered");
-            } catch (final IOException e) {
-                if (datagramSocket.isClosed()) {
-                    // OK we're done.
-                    return;
-                }
-                logger.error("Exception encountered on accept. Ignoring. Stack Trace :", e);
-            }
-        }
-    }
-
-    /**
-     * Shutdown the server.
-     */
-    @Override
-    public void shutdown() {
-        this.setActive(false);
-        Thread.currentThread().interrupt();
-        datagramSocket.close();
-    }
-}

http://git-wip-us.apache.org/repos/asf/logging-log4j2/blob/f515fa3c/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/XmlInputStreamLogEventBridge.java
----------------------------------------------------------------------
diff --git a/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/XmlInputStreamLogEventBridge.java b/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/XmlInputStreamLogEventBridge.java
deleted file mode 100644
index 7853398..0000000
--- a/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/XmlInputStreamLogEventBridge.java
+++ /dev/null
@@ -1,54 +0,0 @@
-/*
- * 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.logging.log4j.core.net.server;
-
-import java.io.InputStream;
-import java.nio.charset.Charset;
-
-import org.apache.logging.log4j.core.LogEvent;
-import org.apache.logging.log4j.core.jackson.Log4jXmlObjectMapper;
-
-/**
- * Reads and logs {@link LogEvent}s from an {@link InputStream}.
- */
-public class XmlInputStreamLogEventBridge extends InputStreamLogEventBridge {
-
-    private static final String EVENT_END = "</Event>";
-    private static final String EVENT_START_NS_N = "<Event>";
-    private static final String EVENT_START_NS_Y = "<Event ";
-
-    public XmlInputStreamLogEventBridge() {
-        this(1024, Charset.defaultCharset());
-    }
-
-    public XmlInputStreamLogEventBridge(final int bufferSize, final Charset charset) {
-        super(new Log4jXmlObjectMapper(), bufferSize, charset, EVENT_END);
-    }
-
-    @Override
-    protected int[] getEventIndices(final String text, final int beginIndex) {
-        int start = text.indexOf(EVENT_START_NS_Y, beginIndex);
-        int startLen = EVENT_START_NS_Y.length();
-        if (start < 0) {
-            start = text.indexOf(EVENT_START_NS_N, beginIndex);
-            startLen = EVENT_START_NS_N.length();
-        }
-        final int end = start < 0 ? -1 : text.indexOf(EVENT_END, start + startLen);
-        return new int[] { start, end };
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/logging-log4j2/blob/f515fa3c/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/package-info.java
----------------------------------------------------------------------
diff --git a/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/package-info.java b/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/package-info.java
deleted file mode 100644
index 0d9d027..0000000
--- a/log4j-core/src/main/java/org/apache/logging/log4j/core/net/server/package-info.java
+++ /dev/null
@@ -1,24 +0,0 @@
-/*
- * 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.
- */
-
-/**
- * Standalone server classes for consuming log events over a network. Each of the various servers should be used with
- * another Log4j configuration to handle incoming {@link org.apache.logging.log4j.core.LogEvent}s. It is recommended
- * to consider using the <a href="../../../../../../../../../manual/appenders.html#FlumeAppender">Flume Appender</a>
- * for highly reliable networked logging.
- */
-package org.apache.logging.log4j.core.net.server;

http://git-wip-us.apache.org/repos/asf/logging-log4j2/blob/f515fa3c/log4j-core/src/test/java/org/apache/logging/log4j/core/net/server/AbstractSocketServerTest.java
----------------------------------------------------------------------
diff --git a/log4j-core/src/test/java/org/apache/logging/log4j/core/net/server/AbstractSocketServerTest.java b/log4j-core/src/test/java/org/apache/logging/log4j/core/net/server/AbstractSocketServerTest.java
deleted file mode 100644
index 7351313..0000000
--- a/log4j-core/src/test/java/org/apache/logging/log4j/core/net/server/AbstractSocketServerTest.java
+++ /dev/null
@@ -1,237 +0,0 @@
-/*
- * 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.logging.log4j.core.net.server;
-
-import java.io.IOException;
-import java.io.Serializable;
-import java.util.Arrays;
-import java.util.List;
-import java.util.Map;
-
-import org.apache.logging.log4j.Level;
-import org.apache.logging.log4j.core.Appender;
-import org.apache.logging.log4j.core.Filter;
-import org.apache.logging.log4j.core.Layout;
-import org.apache.logging.log4j.core.LogEvent;
-import org.apache.logging.log4j.core.Logger;
-import org.apache.logging.log4j.core.LoggerContext;
-import org.apache.logging.log4j.core.appender.AppenderLoggingException;
-import org.apache.logging.log4j.core.appender.ConsoleAppender;
-import org.apache.logging.log4j.core.appender.SocketAppender;
-import org.apache.logging.log4j.core.layout.JsonLayout;
-import org.apache.logging.log4j.core.layout.PatternLayout;
-import org.apache.logging.log4j.core.layout.XmlLayout;
-import org.apache.logging.log4j.core.net.Protocol;
-import org.apache.logging.log4j.test.AvailablePortFinder;
-import org.apache.logging.log4j.test.appender.ListAppender;
-import org.junit.After;
-import org.junit.Ignore;
-import org.junit.Test;
-
-import static org.junit.Assert.*;
-
-/**
- *
- */
-public abstract class AbstractSocketServerTest {
-
-    protected static Thread thread;
-
-    private static final String MESSAGE = "This is test message";
-
-    private static final String MESSAGE_2 = "This is test message 2";
-
-    private static final String MESSAGE_WITH_SPECIAL_CHARS = "{This}\n[is]\"n\"a\"\r\ntrue:\n\ttest,\nmessage";
-
-    static final int PORT_NUM = AvailablePortFinder.getNextAvailable();
-
-    static final int PORT = PORT_NUM;
-
-    private final LoggerContext ctx = LoggerContext.getContext(false);
-
-    private final boolean expectLengthException;
-
-    protected final int port;
-
-    protected final Protocol protocol;
-
-    private final Logger rootLogger = ctx.getLogger(AbstractSocketServerTest.class.getSimpleName());
-
-    protected AbstractSocketServerTest(final Protocol protocol, final int port, final boolean expectLengthException) {
-        this.protocol = protocol;
-        this.port = port;
-        this.expectLengthException = expectLengthException;
-    }
-
-    protected Layout<String> createJsonLayout() {
-        // @formatter: off
-        return JsonLayout.newBuilder()
-            .setLocationInfo(true)
-            .setProperties(true)
-            .setPropertiesAsList(false)
-            .setComplete(false)
-            .setCompact(false)
-            .setEventEol(false)
-            .setIncludeStacktrace(true)
-            .build();
-        // @formatter: on
-            
-        //return JsonLayout.createLayout(null, true, true, false, false, false, false, null, null, null, true);
-    }
-
-    protected abstract Layout<? extends Serializable> createLayout();
-
-    protected Layout<? extends Serializable> createSerializedLayout() {
-        return null;
-    }
-
-    protected Layout<String> createXmlLayout() {
-        return XmlLayout.createLayout(true, true, false, false, null, true);
-    }
-
-    @After
-    public void tearDown() {
-        final Map<String, Appender> map = rootLogger.getAppenders();
-        for (final Map.Entry<String, Appender> entry : map.entrySet()) {
-            final Appender appender = entry.getValue();
-            rootLogger.removeAppender(appender);
-            appender.stop();
-        }
-    }
-
-    @Test
-    @Ignore("Broken test?")
-    public void test1000ShortMessages() throws Exception {
-        testServer(1000);
-    }
-
-    @Test
-    @Ignore("Broken test?")
-    public void test100ShortMessages() throws Exception {
-        testServer(100);
-    }
-
-    @Test
-    public void test10ShortMessages() throws Exception {
-        testServer(10);
-    }
-
-    @Test
-    public void test1ShortMessages() throws Exception {
-        testServer(1);
-    }
-
-    @Test
-    public void test2ShortMessages() throws Exception {
-        testServer(2);
-    }
-
-    @Test
-    public void test64KBMessages() throws Exception {
-        final char[] a64K = new char[1024 * 64];
-        Arrays.fill(a64K, 'a');
-        final String m1 = new String(a64K);
-        final String m2 = MESSAGE_2 + m1;
-        if (expectLengthException) {
-            try {
-                testServer(m1, m2);
-            } catch (final AppenderLoggingException are) {
-                assertTrue("", are.getCause() != null && are.getCause() instanceof IOException);
-                // Failure expected.
-            }
-        } else {
-            testServer(m1, m2);
-        }
-    }
-
-
-    @Test
-    public void testMessagesWithSpecialChars() throws Exception {
-        testServer(MESSAGE_WITH_SPECIAL_CHARS);
-    }
-
-
-    private void testServer(final int size) throws Exception {
-        final String[] messages = new String[size];
-        for (int i = 0; i < messages.length; i++) {
-            messages[i] = MESSAGE + " " + i;
-        }
-        testServer(messages);
-    }
-
-    protected void testServer(final String... messages) throws Exception {
-        final Filter socketFilter = new ThreadNameFilter(Filter.Result.NEUTRAL, Filter.Result.DENY);
-        final Filter serverFilter = new ThreadNameFilter(Filter.Result.DENY, Filter.Result.NEUTRAL);
-        final Layout<? extends Serializable> socketLayout = createLayout();
-        final SocketAppender socketAppender = createSocketAppender(socketFilter, socketLayout);
-        socketAppender.start();
-        final ListAppender listAppender = new ListAppender("Events", serverFilter, null, false, false);
-        listAppender.start();
-        final PatternLayout layout = PatternLayout.newBuilder().withPattern("%m %ex%n").build();
-        final ConsoleAppender console = ConsoleAppender.createDefaultAppenderForLayout(layout);
-        final Logger serverLogger = ctx.getLogger(this.getClass().getName());
-        serverLogger.addAppender(console);
-        serverLogger.setAdditive(false);
-
-        // set appender on root and set level to debug
-        rootLogger.addAppender(socketAppender);
-        rootLogger.addAppender(listAppender);
-        rootLogger.setAdditive(false);
-        rootLogger.setLevel(Level.DEBUG);
-        for (final String message : messages) {
-            rootLogger.debug(message);
-        }
-        final int MAX_TRIES = 400;
-        for (int i = 0; i < MAX_TRIES; i++) {
-            if (listAppender.getEvents().size() < messages.length) {
-                try {
-                    // Let the server-side read the messages.
-                    Thread.sleep(50);
-                } catch (final Exception e) {
-                    e.printStackTrace();
-                }
-            } else {
-                break;
-            }
-        }
-        final List<LogEvent> events = listAppender.getEvents();
-        assertNotNull("No event retrieved", events);
-        assertEquals("Incorrect number of events received", messages.length, events.size());
-        for (int i = 0; i < messages.length; i++) {
-            assertTrue("Incorrect event", events.get(i).getMessage().getFormattedMessage().equals(messages[i]));
-        }
-    }
-
-    protected SocketAppender createSocketAppender(final Filter socketFilter,
-            final Layout<? extends Serializable> socketLayout) {
-        // @formatter:off
-        return SocketAppender.newBuilder()
-                .withProtocol(this.protocol)
-                .withHost("localhost")
-                .withPort(this.port)
-                .withReconnectDelayMillis(-1)
-                .withName("test")
-                .withImmediateFlush(true)
-                .withImmediateFail(false)
-                .withIgnoreExceptions(false)
-                .withLayout(socketLayout)
-                .withFilter(socketFilter)
-                .build();
-        // @formatter:on        
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/logging-log4j2/blob/f515fa3c/log4j-core/src/test/java/org/apache/logging/log4j/core/net/server/SslXmlSocketServerTest.java
----------------------------------------------------------------------
diff --git a/log4j-core/src/test/java/org/apache/logging/log4j/core/net/server/SslXmlSocketServerTest.java b/log4j-core/src/test/java/org/apache/logging/log4j/core/net/server/SslXmlSocketServerTest.java
deleted file mode 100644
index 8ca07a4..0000000
--- a/log4j-core/src/test/java/org/apache/logging/log4j/core/net/server/SslXmlSocketServerTest.java
+++ /dev/null
@@ -1,104 +0,0 @@
-/*
- * 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.logging.log4j.core.net.server;
-
-import java.io.IOException;
-import java.io.InputStream;
-import java.io.Serializable;
-import java.nio.charset.Charset;
-
-import org.apache.logging.log4j.core.Filter;
-import org.apache.logging.log4j.core.Layout;
-import org.apache.logging.log4j.core.LoggerContext;
-import org.apache.logging.log4j.core.appender.SocketAppender;
-import org.apache.logging.log4j.core.net.Protocol;
-import org.apache.logging.log4j.core.net.ssl.KeyStoreConfiguration;
-import org.apache.logging.log4j.core.net.ssl.SslConfiguration;
-import org.apache.logging.log4j.core.net.ssl.StoreConfigurationException;
-import org.apache.logging.log4j.core.net.ssl.TestConstants;
-import org.apache.logging.log4j.core.net.ssl.TrustStoreConfiguration;
-import org.junit.AfterClass;
-import org.junit.BeforeClass;
-
-public class SslXmlSocketServerTest extends AbstractSocketServerTest {
-
-    private static TcpSocketServer<InputStream> server;
-
-    private static SslConfiguration sslConfiguration;
-
-    private static void initServerSocketFactory() throws StoreConfigurationException {
-        final KeyStoreConfiguration ksc = new KeyStoreConfiguration(TestConstants.KEYSTORE_FILE,
-                TestConstants.KEYSTORE_PWD, TestConstants.KEYSTORE_TYPE, null);
-        final TrustStoreConfiguration tsc = new TrustStoreConfiguration(TestConstants.TRUSTSTORE_FILE,
-                TestConstants.TRUSTSTORE_PWD, null, null);
-        sslConfiguration = SslConfiguration.createSSLConfiguration(null, ksc, tsc);
-    }
-
-    @Override
-    protected SocketAppender createSocketAppender(final Filter socketFilter,
-            final Layout<? extends Serializable> socketLayout) {
-        // @formatter:off
-        return SocketAppender.newBuilder()
-                .withProtocol(this.protocol)
-                .withHost("localhost")
-                .withPort(this.port)
-                .withReconnectDelayMillis(-1)
-                .withName("test")
-                .withImmediateFlush(true)
-                .withImmediateFail(false)
-                .withIgnoreExceptions(false)
-                .withLayout(socketLayout)
-                .withFilter(socketFilter)
-                .withSslConfiguration(sslConfiguration)
-                .build();
-        // @formatter:on        
-    }
-
-    @BeforeClass
-    public static void setupClass() throws Exception {
-        (LoggerContext.getContext(false)).reconfigure();
-        initServerSocketFactory();
-        // Use a large buffer just to test the code, the UDP test uses a tiny buffer
-        server = new SecureTcpSocketServer<>(PORT_NUM, new XmlInputStreamLogEventBridge(1024 * 100,
-                Charset.defaultCharset()), sslConfiguration);
-        thread = server.startNewThread();
-    }
-
-    @AfterClass
-    public static void tearDownClass() {
-        try {
-            server.shutdown();
-        } catch (final IOException e) {
-            e.printStackTrace();
-        }
-        try {
-            thread.join();
-        } catch (final InterruptedException e) {
-            // ignore
-        }
-    }
-
-    public SslXmlSocketServerTest() {
-        super(Protocol.SSL, PORT, false);
-    }
-
-    @Override
-    protected Layout<String> createLayout() {
-        return super.createXmlLayout();
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/logging-log4j2/blob/f515fa3c/log4j-core/src/test/java/org/apache/logging/log4j/core/net/server/TcpJsonSocketServerTest.java
----------------------------------------------------------------------
diff --git a/log4j-core/src/test/java/org/apache/logging/log4j/core/net/server/TcpJsonSocketServerTest.java b/log4j-core/src/test/java/org/apache/logging/log4j/core/net/server/TcpJsonSocketServerTest.java
deleted file mode 100644
index 6420e7e..0000000
--- a/log4j-core/src/test/java/org/apache/logging/log4j/core/net/server/TcpJsonSocketServerTest.java
+++ /dev/null
@@ -1,62 +0,0 @@
-/*
- * 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.logging.log4j.core.net.server;
-
-import java.io.IOException;
-import java.io.InputStream;
-
-import org.apache.logging.log4j.core.Layout;
-import org.apache.logging.log4j.core.LoggerContext;
-import org.apache.logging.log4j.core.net.Protocol;
-import org.junit.AfterClass;
-import org.junit.BeforeClass;
-
-public class TcpJsonSocketServerTest extends AbstractSocketServerTest {
-    
-    private static TcpSocketServer<InputStream> server;
-
-    @BeforeClass
-    public static void setupClass() throws Exception {
-        (LoggerContext.getContext(false)).reconfigure();
-        server = TcpSocketServer.createJsonSocketServer(PORT_NUM);
-        thread = server.startNewThread();
-    }
-
-    @AfterClass
-    public static void tearDownClass() {
-        try {
-            server.shutdown();
-        } catch (final IOException e) {
-            e.printStackTrace();
-        }
-        try {
-            thread.join();
-        } catch (final InterruptedException e) {
-            // ignore
-        }
-    }
-
-    public TcpJsonSocketServerTest() {
-        super(Protocol.TCP, PORT, false);
-    }
-
-    @Override
-    protected Layout<String> createLayout() {
-        return super.createJsonLayout();
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/logging-log4j2/blob/f515fa3c/log4j-core/src/test/java/org/apache/logging/log4j/core/net/server/TcpSerializedSocketServerTest.java
----------------------------------------------------------------------
diff --git a/log4j-core/src/test/java/org/apache/logging/log4j/core/net/server/TcpSerializedSocketServerTest.java b/log4j-core/src/test/java/org/apache/logging/log4j/core/net/server/TcpSerializedSocketServerTest.java
deleted file mode 100644
index 645701b..0000000
--- a/log4j-core/src/test/java/org/apache/logging/log4j/core/net/server/TcpSerializedSocketServerTest.java
+++ /dev/null
@@ -1,63 +0,0 @@
-/*
- * 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.logging.log4j.core.net.server;
-
-import java.io.IOException;
-import java.io.ObjectInputStream;
-import java.io.Serializable;
-
-import org.apache.logging.log4j.core.Layout;
-import org.apache.logging.log4j.core.LoggerContext;
-import org.apache.logging.log4j.core.net.Protocol;
-import org.junit.AfterClass;
-import org.junit.BeforeClass;
-
-public class TcpSerializedSocketServerTest extends AbstractSocketServerTest {
-    
-    private static TcpSocketServer<ObjectInputStream> server;
-
-    @BeforeClass
-    public static void setupClass() throws Exception {
-        (LoggerContext.getContext(false)).reconfigure();
-        server = TcpSocketServer.createSerializedSocketServer(PORT_NUM);
-        thread = server.startNewThread();
-    }
-
-    @AfterClass
-    public static void tearDownClass() {
-        try {
-            server.shutdown();
-        } catch (final IOException e) {
-            e.printStackTrace();
-        }
-        try {
-            thread.join();
-        } catch (final InterruptedException e) {
-            // ignore
-        }
-    }
-
-    public TcpSerializedSocketServerTest() {
-        super(Protocol.TCP, PORT, false);
-    }
-
-    @Override
-    protected Layout<? extends Serializable> createLayout() {
-        return super.createSerializedLayout();
-    }
-
-}