You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@cxf.apache.org by dk...@apache.org on 2009/12/03 23:27:02 UTC

svn commit: r886957 [4/5] - in /cxf/trunk: api/src/test/java/org/apache/cxf/databinding/ distribution/src/main/release/samples/wsdl_first/src/main/java/com/example/customerservice/client/ distribution/src/main/release/samples/wsdl_first/src/main/java/c...

Modified: cxf/trunk/rt/frontend/jaxrs/src/main/java/org/apache/cxf/jaxrs/ext/logging/atom/deliverer/RetryingDeliverer.java
URL: http://svn.apache.org/viewvc/cxf/trunk/rt/frontend/jaxrs/src/main/java/org/apache/cxf/jaxrs/ext/logging/atom/deliverer/RetryingDeliverer.java?rev=886957&r1=886956&r2=886957&view=diff
==============================================================================
--- cxf/trunk/rt/frontend/jaxrs/src/main/java/org/apache/cxf/jaxrs/ext/logging/atom/deliverer/RetryingDeliverer.java (original)
+++ cxf/trunk/rt/frontend/jaxrs/src/main/java/org/apache/cxf/jaxrs/ext/logging/atom/deliverer/RetryingDeliverer.java Thu Dec  3 22:26:58 2009
@@ -1,139 +1,139 @@
-/**
- * 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.cxf.jaxrs.ext.logging.atom.deliverer;
-
-import java.util.Calendar;
-import java.util.Date;
-
-import org.apache.abdera.model.Element;
-import org.apache.commons.lang.Validate;
-
-/**
- * Wrapper on other deliverer retrying delivery in case of failure. Delivery attempts repeat in loop with some
- * pause time between retries until successful delivery or exceeding time limit. Time delay between delivery
- * is configurable strategy. Two predefined strategies are given: each time pause same amount of time (linear)
- * and each next time pause time doubles (exponential).
- */
-public final class RetryingDeliverer implements Deliverer {
-
-    private Deliverer deliverer;
-    private PauseCalculator pauser;
-    private int timeout;
-
-    /**
-     * Creates retrying deliverer with predefined retry strategy.
-     * 
-     * @param worker real deliverer used to push data out.
-     * @param timeout maximum time range (in seconds) that retrial is continued; time spent on delivery call
-     *            is included. No timeout (infinite loop) if set to zero.
-     * @param pause time of pause (in seconds) greater than zero.
-     * @param linear if true linear strategy (each time pause same amount of time), exponential otherwise
-     *            (each next time pause time doubles).
-     */
-    public RetryingDeliverer(Deliverer worker, int timeout, int pause, boolean linear) {
-        Validate.notNull(worker, "worker is null");
-        Validate.isTrue(timeout >= 0, "timeout is negative");
-        Validate.isTrue(pause > 0, "pause is not greater than zero");
-        deliverer = worker;
-        this.timeout = timeout;
-        this.pauser = linear ? new ConstantPause(pause) : new ExponentialPause(pause);
-    }
-
-    /**
-     * Creates retrying deliverer with custom retry strategy.
-     * 
-     * @param worker real deliverer used to push data out.
-     * @param timeout maximum time range (in seconds) that retrial is continued; time spent on delivery call
-     *            is included. No timeout (infinite loop) if set to zero.
-     * @param strategy custom retry pausing strategy.
-     */
-    public RetryingDeliverer(Deliverer worker, int timeout, PauseCalculator strategy) {
-        Validate.notNull(worker, "worker is null");
-        Validate.notNull(strategy, "strategy is null");
-        Validate.isTrue(timeout >= 0, "timeout is negative");
-        deliverer = worker;
-        pauser = strategy;
-        this.timeout = timeout;
-    }
-
-    public boolean deliver(Element element) throws InterruptedException {
-        Calendar cal = Calendar.getInstance();
-        cal.add(Calendar.SECOND, timeout);
-        Date timeoutDate = cal.getTime();
-        while (!deliverer.deliver(element)) {
-            int sleep = pauser.nextPause();
-            cal = Calendar.getInstance();
-            cal.add(Calendar.SECOND, sleep);
-            if (timeout == 0 || timeoutDate.after(cal.getTime())) {
-                Thread.sleep(sleep * 1000);
-            } else {
-                pauser.reset();
-                return false;
-            }
-        }
-        pauser.reset();
-        return true;
-    }
-
-    /** Calculates time of subsequent pauses between delivery attempts. */
-    public interface PauseCalculator {
-
-        /** Time of next pause (in seconds). */
-        int nextPause();
-
-        /** Restarts calculation. */
-        void reset();
-    }
-
-    private static class ConstantPause implements PauseCalculator {
-        private int pause;
-
-        public ConstantPause(int pause) {
-            this.pause = pause;
-        }
-
-        public int nextPause() {
-            return pause;
-        }
-
-        public void reset() {
-        }
-    }
-
-    private static class ExponentialPause implements PauseCalculator {
-        private int pause;
-        private int current;
-
-        public ExponentialPause(int pause) {
-            this.pause = pause;
-            current = pause;
-        }
-
-        public int nextPause() {
-            int c = current;
-            current *= 2;
-            return c;
-        }
-
-        public void reset() {
-            current = pause;
-        }
-    }
-
-}
+/**
+ * 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.cxf.jaxrs.ext.logging.atom.deliverer;
+
+import java.util.Calendar;
+import java.util.Date;
+
+import org.apache.abdera.model.Element;
+import org.apache.commons.lang.Validate;
+
+/**
+ * Wrapper on other deliverer retrying delivery in case of failure. Delivery attempts repeat in loop with some
+ * pause time between retries until successful delivery or exceeding time limit. Time delay between delivery
+ * is configurable strategy. Two predefined strategies are given: each time pause same amount of time (linear)
+ * and each next time pause time doubles (exponential).
+ */
+public final class RetryingDeliverer implements Deliverer {
+
+    private Deliverer deliverer;
+    private PauseCalculator pauser;
+    private int timeout;
+
+    /**
+     * Creates retrying deliverer with predefined retry strategy.
+     * 
+     * @param worker real deliverer used to push data out.
+     * @param timeout maximum time range (in seconds) that retrial is continued; time spent on delivery call
+     *            is included. No timeout (infinite loop) if set to zero.
+     * @param pause time of pause (in seconds) greater than zero.
+     * @param linear if true linear strategy (each time pause same amount of time), exponential otherwise
+     *            (each next time pause time doubles).
+     */
+    public RetryingDeliverer(Deliverer worker, int timeout, int pause, boolean linear) {
+        Validate.notNull(worker, "worker is null");
+        Validate.isTrue(timeout >= 0, "timeout is negative");
+        Validate.isTrue(pause > 0, "pause is not greater than zero");
+        deliverer = worker;
+        this.timeout = timeout;
+        this.pauser = linear ? new ConstantPause(pause) : new ExponentialPause(pause);
+    }
+
+    /**
+     * Creates retrying deliverer with custom retry strategy.
+     * 
+     * @param worker real deliverer used to push data out.
+     * @param timeout maximum time range (in seconds) that retrial is continued; time spent on delivery call
+     *            is included. No timeout (infinite loop) if set to zero.
+     * @param strategy custom retry pausing strategy.
+     */
+    public RetryingDeliverer(Deliverer worker, int timeout, PauseCalculator strategy) {
+        Validate.notNull(worker, "worker is null");
+        Validate.notNull(strategy, "strategy is null");
+        Validate.isTrue(timeout >= 0, "timeout is negative");
+        deliverer = worker;
+        pauser = strategy;
+        this.timeout = timeout;
+    }
+
+    public boolean deliver(Element element) throws InterruptedException {
+        Calendar cal = Calendar.getInstance();
+        cal.add(Calendar.SECOND, timeout);
+        Date timeoutDate = cal.getTime();
+        while (!deliverer.deliver(element)) {
+            int sleep = pauser.nextPause();
+            cal = Calendar.getInstance();
+            cal.add(Calendar.SECOND, sleep);
+            if (timeout == 0 || timeoutDate.after(cal.getTime())) {
+                Thread.sleep(sleep * 1000);
+            } else {
+                pauser.reset();
+                return false;
+            }
+        }
+        pauser.reset();
+        return true;
+    }
+
+    /** Calculates time of subsequent pauses between delivery attempts. */
+    public interface PauseCalculator {
+
+        /** Time of next pause (in seconds). */
+        int nextPause();
+
+        /** Restarts calculation. */
+        void reset();
+    }
+
+    private static class ConstantPause implements PauseCalculator {
+        private int pause;
+
+        public ConstantPause(int pause) {
+            this.pause = pause;
+        }
+
+        public int nextPause() {
+            return pause;
+        }
+
+        public void reset() {
+        }
+    }
+
+    private static class ExponentialPause implements PauseCalculator {
+        private int pause;
+        private int current;
+
+        public ExponentialPause(int pause) {
+            this.pause = pause;
+            current = pause;
+        }
+
+        public int nextPause() {
+            int c = current;
+            current *= 2;
+            return c;
+        }
+
+        public void reset() {
+            current = pause;
+        }
+    }
+
+}

Propchange: cxf/trunk/rt/frontend/jaxrs/src/main/java/org/apache/cxf/jaxrs/ext/logging/atom/deliverer/RetryingDeliverer.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: cxf/trunk/rt/frontend/jaxrs/src/main/java/org/apache/cxf/jaxrs/ext/logging/atom/deliverer/RetryingDeliverer.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: cxf/trunk/rt/frontend/jaxrs/src/main/java/org/apache/cxf/jaxrs/ext/logging/atom/deliverer/WebClientDeliverer.java
URL: http://svn.apache.org/viewvc/cxf/trunk/rt/frontend/jaxrs/src/main/java/org/apache/cxf/jaxrs/ext/logging/atom/deliverer/WebClientDeliverer.java?rev=886957&r1=886956&r2=886957&view=diff
==============================================================================
--- cxf/trunk/rt/frontend/jaxrs/src/main/java/org/apache/cxf/jaxrs/ext/logging/atom/deliverer/WebClientDeliverer.java (original)
+++ cxf/trunk/rt/frontend/jaxrs/src/main/java/org/apache/cxf/jaxrs/ext/logging/atom/deliverer/WebClientDeliverer.java Thu Dec  3 22:26:58 2009
@@ -1,56 +1,56 @@
-/**
- * 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.cxf.jaxrs.ext.logging.atom.deliverer;
-
-import java.util.Arrays;
-import java.util.List;
-
-import javax.ws.rs.core.Response;
-
-import org.apache.abdera.model.Element;
-import org.apache.commons.lang.Validate;
-import org.apache.cxf.jaxrs.client.WebClient;
-import org.apache.cxf.jaxrs.provider.AtomEntryProvider;
-import org.apache.cxf.jaxrs.provider.AtomFeedProvider;
-
-/**
- * Marshaling and delivering based on JAXRS' WebClient.
- */
-public final class WebClientDeliverer implements Deliverer {
-    private WebClient wc;
-
-    @SuppressWarnings("unchecked")
-    public WebClientDeliverer(String deliveryAddress) {
-        Validate.notEmpty(deliveryAddress, "deliveryAddress is empty or null");
-        List<?> providers = Arrays.asList(new AtomFeedProvider(), new AtomEntryProvider());
-        wc = WebClient.create(deliveryAddress, providers);
-        wc.type("application/atom+xml");
-    }
-
-    public WebClientDeliverer(WebClient wc) {
-        Validate.notNull(wc, "wc is null");
-        this.wc = wc;
-    }
-
-    public boolean deliver(Element element) {
-        Response res = wc.post(element);
-        int status = res.getStatus();
-        return status >= 200 && status <= 299;
-    }
-}
+/**
+ * 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.cxf.jaxrs.ext.logging.atom.deliverer;
+
+import java.util.Arrays;
+import java.util.List;
+
+import javax.ws.rs.core.Response;
+
+import org.apache.abdera.model.Element;
+import org.apache.commons.lang.Validate;
+import org.apache.cxf.jaxrs.client.WebClient;
+import org.apache.cxf.jaxrs.provider.AtomEntryProvider;
+import org.apache.cxf.jaxrs.provider.AtomFeedProvider;
+
+/**
+ * Marshaling and delivering based on JAXRS' WebClient.
+ */
+public final class WebClientDeliverer implements Deliverer {
+    private WebClient wc;
+
+    @SuppressWarnings("unchecked")
+    public WebClientDeliverer(String deliveryAddress) {
+        Validate.notEmpty(deliveryAddress, "deliveryAddress is empty or null");
+        List<?> providers = Arrays.asList(new AtomFeedProvider(), new AtomEntryProvider());
+        wc = WebClient.create(deliveryAddress, providers);
+        wc.type("application/atom+xml");
+    }
+
+    public WebClientDeliverer(WebClient wc) {
+        Validate.notNull(wc, "wc is null");
+        this.wc = wc;
+    }
+
+    public boolean deliver(Element element) {
+        Response res = wc.post(element);
+        int status = res.getStatus();
+        return status >= 200 && status <= 299;
+    }
+}

Propchange: cxf/trunk/rt/frontend/jaxrs/src/main/java/org/apache/cxf/jaxrs/ext/logging/atom/deliverer/WebClientDeliverer.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: cxf/trunk/rt/frontend/jaxrs/src/main/java/org/apache/cxf/jaxrs/ext/logging/atom/deliverer/WebClientDeliverer.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: cxf/trunk/rt/frontend/jaxrs/src/main/java/org/apache/cxf/jaxrs/ext/logging/atom/package-info.java
URL: http://svn.apache.org/viewvc/cxf/trunk/rt/frontend/jaxrs/src/main/java/org/apache/cxf/jaxrs/ext/logging/atom/package-info.java?rev=886957&r1=886956&r2=886957&view=diff
==============================================================================
--- cxf/trunk/rt/frontend/jaxrs/src/main/java/org/apache/cxf/jaxrs/ext/logging/atom/package-info.java (original)
+++ cxf/trunk/rt/frontend/jaxrs/src/main/java/org/apache/cxf/jaxrs/ext/logging/atom/package-info.java Thu Dec  3 22:26:58 2009
@@ -1,27 +1,27 @@
-/**
- * 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.
- */
-
-/**
- * Support for producing logs in
- * <a href="http://tools.ietf.org/html/rfc4287">ATOM Syndication Format</a>.
- * Allows to configure <tt>java.util.logging</tt> (JUL) loggers to use
- * handlers producing ATOM feeds that are either pushed to or pulled by client.  
- */
-package org.apache.cxf.jaxrs.ext.logging.atom;
-
+/**
+ * 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.
+ */
+
+/**
+ * Support for producing logs in
+ * <a href="http://tools.ietf.org/html/rfc4287">ATOM Syndication Format</a>.
+ * Allows to configure <tt>java.util.logging</tt> (JUL) loggers to use
+ * handlers producing ATOM feeds that are either pushed to or pulled by client.  
+ */
+package org.apache.cxf.jaxrs.ext.logging.atom;
+

Propchange: cxf/trunk/rt/frontend/jaxrs/src/main/java/org/apache/cxf/jaxrs/ext/logging/atom/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: cxf/trunk/rt/frontend/jaxrs/src/main/java/org/apache/cxf/jaxrs/ext/logging/atom/package-info.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: cxf/trunk/rt/frontend/jaxrs/src/main/java/org/apache/cxf/jaxrs/ext/logging/package-info.java
URL: http://svn.apache.org/viewvc/cxf/trunk/rt/frontend/jaxrs/src/main/java/org/apache/cxf/jaxrs/ext/logging/package-info.java?rev=886957&r1=886956&r2=886957&view=diff
==============================================================================
--- cxf/trunk/rt/frontend/jaxrs/src/main/java/org/apache/cxf/jaxrs/ext/logging/package-info.java (original)
+++ cxf/trunk/rt/frontend/jaxrs/src/main/java/org/apache/cxf/jaxrs/ext/logging/package-info.java Thu Dec  3 22:26:58 2009
@@ -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.
- */
-
-/**
- * JAX-RS specific logging support. Based on <tt>java.util.logging</tt> (JUL)
- * with use of different logging frameworks factored out; assumes that client 
- * with source code logging to other systems, like Log4J, can bridge 
- * to this implementation applying <a href="www.slf4j.org">SLF4J</a> 
- * that JAXRS already depends on.
- */
-@javax.xml.bind.annotation.XmlSchema(xmlns = {
-        @javax.xml.bind.annotation.XmlNs(namespaceURI = "http://cxf.apache.org/jaxrs/log", prefix = "log")
-            })
-package org.apache.cxf.jaxrs.ext.logging;
-
+/**
+ * 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.
+ */
+
+/**
+ * JAX-RS specific logging support. Based on <tt>java.util.logging</tt> (JUL)
+ * with use of different logging frameworks factored out; assumes that client 
+ * with source code logging to other systems, like Log4J, can bridge 
+ * to this implementation applying <a href="www.slf4j.org">SLF4J</a> 
+ * that JAXRS already depends on.
+ */
+@javax.xml.bind.annotation.XmlSchema(xmlns = {
+        @javax.xml.bind.annotation.XmlNs(namespaceURI = "http://cxf.apache.org/jaxrs/log", prefix = "log")
+            })
+package org.apache.cxf.jaxrs.ext.logging;
+

Propchange: cxf/trunk/rt/frontend/jaxrs/src/main/java/org/apache/cxf/jaxrs/ext/logging/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: cxf/trunk/rt/frontend/jaxrs/src/main/java/org/apache/cxf/jaxrs/ext/logging/package-info.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: cxf/trunk/rt/frontend/jaxrs/src/main/java/org/apache/cxf/jaxrs/provider/PrefixCollectingXMLStreamWriter.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: cxf/trunk/rt/frontend/jaxrs/src/main/java/org/apache/cxf/jaxrs/provider/PrefixRespectingMappedNamespaceConvention.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: cxf/trunk/rt/frontend/jaxrs/src/test/resources/org/apache/cxf/jaxrs/provider/jsonCases.xml
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: cxf/trunk/rt/frontend/jaxws/src/main/java/org/apache/cxf/jaxws/spring/JaxWsWebServicePublisherBeanPostProcessor.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: cxf/trunk/rt/frontend/jaxws/src/main/java/org/apache/cxf/jaxws/spring/Messages.properties
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: cxf/trunk/rt/transports/http-osgi/pom.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: cxf/trunk/rt/transports/http-osgi/pom.xml
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: cxf/trunk/rt/transports/http-osgi/pom.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: cxf/trunk/rt/transports/http-osgi/src/main/resources/META-INF/cxf/osgi/cxf-extension-osgi.xml
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: cxf/trunk/rt/transports/http-osgi/src/main/resources/META-INF/cxf/osgi/cxf-extension-osgi.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: cxf/trunk/rt/transports/http-osgi/src/main/resources/META-INF/spring/cxf-transport-osgi.xml
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: cxf/trunk/rt/transports/http-osgi/src/main/resources/META-INF/spring/cxf-transport-osgi.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/BookServerResourceJacksonSpringProviders.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/JAXRSClientServerResourceJacksonSpringProviderTest.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/JAXRSLoggingAtomPushSpringTest.java
URL: http://svn.apache.org/viewvc/cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/JAXRSLoggingAtomPushSpringTest.java?rev=886957&r1=886956&r2=886957&view=diff
==============================================================================
--- cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/JAXRSLoggingAtomPushSpringTest.java (original)
+++ cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/JAXRSLoggingAtomPushSpringTest.java Thu Dec  3 22:26:58 2009
@@ -1,110 +1,110 @@
-/**
- * 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.cxf.systest.jaxrs;
-
-import java.util.ArrayList;
-import java.util.List;
-import java.util.logging.Level;
-import java.util.logging.LogRecord;
-import java.util.logging.Logger;
-
-import javax.ws.rs.GET;
-import javax.ws.rs.POST;
-import javax.ws.rs.Path;
-
-import org.apache.abdera.model.Element;
-import org.apache.abdera.model.Feed;
-import org.apache.cxf.common.logging.LogUtils;
-import org.apache.cxf.jaxrs.client.WebClient;
-import org.apache.cxf.testutil.common.AbstractClientServerTestBase;
-
-import org.junit.Before;
-import org.junit.BeforeClass;
-import org.junit.Ignore;
-import org.junit.Test;
-
-public class JAXRSLoggingAtomPushSpringTest extends AbstractClientServerTestBase {
-
-    private static List<Element> retrieved = new ArrayList<Element>();
-
-    @BeforeClass
-    public static void beforeClass() throws Exception {
-        // must be 'in-process' to communicate with inner class in single JVM
-        // and to spawn class SpringServer w/o using main() method
-        launchServer(SpringServer.class, true);
-    }
-
-    @Ignore
-    public static class SpringServer extends AbstractSpringServer {
-        public SpringServer() {
-            super("/jaxrs_logging_atompush");
-        }
-    }
-
-    @Before
-    public void before() {
-        retrieved.clear();
-    }
-
-    @Ignore
-    @Path("/")
-    public static class Resource {
-        private static final Logger LOG1 = LogUtils.getL7dLogger(Resource.class);
-        private static final Logger LOG2 = LogUtils.getL7dLogger(Resource.class, null, "namedLogger");
-
-        @GET
-        @Path("/log")
-        public void doLogging() {
-            LOG1.severe("severe message");
-            LOG1.warning("warning message");
-            LOG1.info("info message");
-            LogRecord r = new LogRecord(Level.FINE, "fine message");
-            r.setThrown(new IllegalArgumentException("tadaam"));
-            LOG1.log(r);
-            r = new LogRecord(Level.FINER, "finer message with {0} and {1}");
-            r.setParameters(new Object[] {
-                "param1", "param2"
-            });
-            r.setLoggerName("faky-logger");
-            LOG1.log(r);
-            LOG1.finest("finest message");
-
-            // for LOG2 only 'warning' and above messages should be logged
-            LOG2.severe("severe message");
-            LOG2.info("info message - should not pass!");
-            LOG2.finer("finer message - should not pass!");
-        }
-
-        // 2. ATOM push handler should populate logs here
-        @POST
-        @Path("/feed")
-        public void consume(Feed feed) {
-            // System.out.println(feed);
-            retrieved.add(feed);
-        }
-    }
-
-    @Test
-    public void testLogEvents() throws Exception {
-        WebClient wc = WebClient.create("http://localhost:9080");
-        wc.path("/log").get();
-        Thread.sleep(1000);
-        assertEquals(7, retrieved.size());
-    }
-}
+/**
+ * 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.cxf.systest.jaxrs;
+
+import java.util.ArrayList;
+import java.util.List;
+import java.util.logging.Level;
+import java.util.logging.LogRecord;
+import java.util.logging.Logger;
+
+import javax.ws.rs.GET;
+import javax.ws.rs.POST;
+import javax.ws.rs.Path;
+
+import org.apache.abdera.model.Element;
+import org.apache.abdera.model.Feed;
+import org.apache.cxf.common.logging.LogUtils;
+import org.apache.cxf.jaxrs.client.WebClient;
+import org.apache.cxf.testutil.common.AbstractClientServerTestBase;
+
+import org.junit.Before;
+import org.junit.BeforeClass;
+import org.junit.Ignore;
+import org.junit.Test;
+
+public class JAXRSLoggingAtomPushSpringTest extends AbstractClientServerTestBase {
+
+    private static List<Element> retrieved = new ArrayList<Element>();
+
+    @BeforeClass
+    public static void beforeClass() throws Exception {
+        // must be 'in-process' to communicate with inner class in single JVM
+        // and to spawn class SpringServer w/o using main() method
+        launchServer(SpringServer.class, true);
+    }
+
+    @Ignore
+    public static class SpringServer extends AbstractSpringServer {
+        public SpringServer() {
+            super("/jaxrs_logging_atompush");
+        }
+    }
+
+    @Before
+    public void before() {
+        retrieved.clear();
+    }
+
+    @Ignore
+    @Path("/")
+    public static class Resource {
+        private static final Logger LOG1 = LogUtils.getL7dLogger(Resource.class);
+        private static final Logger LOG2 = LogUtils.getL7dLogger(Resource.class, null, "namedLogger");
+
+        @GET
+        @Path("/log")
+        public void doLogging() {
+            LOG1.severe("severe message");
+            LOG1.warning("warning message");
+            LOG1.info("info message");
+            LogRecord r = new LogRecord(Level.FINE, "fine message");
+            r.setThrown(new IllegalArgumentException("tadaam"));
+            LOG1.log(r);
+            r = new LogRecord(Level.FINER, "finer message with {0} and {1}");
+            r.setParameters(new Object[] {
+                "param1", "param2"
+            });
+            r.setLoggerName("faky-logger");
+            LOG1.log(r);
+            LOG1.finest("finest message");
+
+            // for LOG2 only 'warning' and above messages should be logged
+            LOG2.severe("severe message");
+            LOG2.info("info message - should not pass!");
+            LOG2.finer("finer message - should not pass!");
+        }
+
+        // 2. ATOM push handler should populate logs here
+        @POST
+        @Path("/feed")
+        public void consume(Feed feed) {
+            // System.out.println(feed);
+            retrieved.add(feed);
+        }
+    }
+
+    @Test
+    public void testLogEvents() throws Exception {
+        WebClient wc = WebClient.create("http://localhost:9080");
+        wc.path("/log").get();
+        Thread.sleep(1000);
+        assertEquals(7, retrieved.size());
+    }
+}

Propchange: cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/JAXRSLoggingAtomPushSpringTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/JAXRSLoggingAtomPushSpringTest.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/JAXRSLoggingAtomPushTest.java
URL: http://svn.apache.org/viewvc/cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/JAXRSLoggingAtomPushTest.java?rev=886957&r1=886956&r2=886957&view=diff
==============================================================================
--- cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/JAXRSLoggingAtomPushTest.java (original)
+++ cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/JAXRSLoggingAtomPushTest.java Thu Dec  3 22:26:58 2009
@@ -1,183 +1,183 @@
-/**
- * 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.cxf.systest.jaxrs;
-
-import java.io.InputStream;
-import java.util.ArrayList;
-import java.util.Arrays;
-import java.util.List;
-import java.util.logging.Handler;
-import java.util.logging.Level;
-import java.util.logging.LogManager;
-import java.util.logging.LogRecord;
-import java.util.logging.Logger;
-
-import javax.ws.rs.POST;
-import javax.ws.rs.Path;
-
-import org.apache.abdera.model.Entry;
-import org.apache.abdera.model.Feed;
-import org.apache.cxf.common.logging.LogUtils;
-import org.apache.cxf.endpoint.Server;
-import org.apache.cxf.jaxrs.JAXRSServerFactoryBean;
-import org.apache.cxf.jaxrs.ext.logging.atom.AtomPushHandler;
-import org.apache.cxf.jaxrs.ext.logging.atom.converter.Converter;
-import org.apache.cxf.jaxrs.ext.logging.atom.converter.StandardConverter;
-import org.apache.cxf.jaxrs.ext.logging.atom.converter.StandardConverter.Format;
-import org.apache.cxf.jaxrs.ext.logging.atom.converter.StandardConverter.Multiplicity;
-import org.apache.cxf.jaxrs.ext.logging.atom.converter.StandardConverter.Output;
-import org.apache.cxf.jaxrs.ext.logging.atom.deliverer.Deliverer;
-import org.apache.cxf.jaxrs.ext.logging.atom.deliverer.WebClientDeliverer;
-import org.apache.cxf.jaxrs.provider.AtomEntryProvider;
-import org.apache.cxf.jaxrs.provider.AtomFeedProvider;
-
-import org.junit.AfterClass;
-import org.junit.Before;
-import org.junit.BeforeClass;
-import org.junit.Ignore;
-import org.junit.Test;
-
-import static org.junit.Assert.assertEquals;
-
-public class JAXRSLoggingAtomPushTest {
-    private static final Logger LOG = LogUtils.getL7dLogger(JAXRSLoggingAtomPushTest.class);
-    private static Server server;
-    private static List<Feed> feeds = new ArrayList<Feed>();
-    private static List<Entry> entries = new ArrayList<Entry>();
-
-    @Ignore
-    @Path("/")
-    public static class Resource {
-        @POST
-        public void consume(Feed feed) {
-            System.out.println(feed);
-            feeds.add(feed);
-        }
-
-        @POST
-        @Path("/atomPub")
-        public void consume(Entry entry) {
-            System.out.println(entry);
-            entries.add(entry);
-        }
-    }
-
-    @SuppressWarnings("unchecked")
-    @BeforeClass
-    public static void beforeClass() throws Exception {
-        // disable logging for server startup
-        configureLogging("resources/logging_atompush_disabled.properties");
-
-        JAXRSServerFactoryBean sf = new JAXRSServerFactoryBean();
-        sf.setResourceClasses(JAXRSLoggingAtomPushTest.Resource.class);
-        sf.setAddress("http://localhost:9080/");
-        sf.setProviders(Arrays.asList(new AtomFeedProvider(), new AtomEntryProvider()));
-        server = sf.create();
-        server.start();
-    }
-
-    /** Configures global logging */
-    private static void configureLogging(String propFile) throws Exception {
-        LogManager lm = LogManager.getLogManager();
-        InputStream ins = JAXRSLoggingAtomPushTest.class.getResourceAsStream(propFile);
-        lm.readConfiguration(ins);
-    }
-
-    private static void logSixEvents(Logger log) {
-        log.severe("severe message");
-        log.warning("warning message");
-        log.info("info message");
-        LogRecord r = new LogRecord(Level.FINE, "fine message");
-        r.setThrown(new IllegalArgumentException("tadaam"));
-        log.log(r);
-        r = new LogRecord(Level.FINER, "finer message with {0} and {1}");
-        r.setParameters(new Object[] {
-            "param1", "param2"
-        });
-        r.setLoggerName("faky-logger");
-        log.log(r);
-        log.finest("finest message");
-    }
-
-    @AfterClass
-    public static void afterClass() throws Exception {
-        if (server != null) {
-            server.stop();
-        }
-        LogManager lm = LogManager.getLogManager();
-        try {
-            // restoring original configuration to not use tested logging handlers
-            lm.readConfiguration();
-        } catch (Exception e) {
-            // ignore missing config file
-        }
-    }
-
-    @Before
-    public void before() throws Exception {
-        feeds.clear();
-        entries.clear();
-    }
-
-    @Test
-    public void testOneElementBatch() throws Exception {
-        configureLogging("resources/logging_atompush.properties");
-        logSixEvents(LOG);
-        // need to wait: multithreaded and client-server journey
-        Thread.sleep(1000);
-        assertEquals("Different logged events count;", 6, feeds.size());
-    }
-
-    @Test
-    public void testMultiElementBatch() throws Exception {
-        configureLogging("resources/logging_atompush_batch.properties");
-        logSixEvents(LOG);
-        // need to wait: multithreaded and client-server journey
-        Thread.sleep(1000);
-        // 6 events / 3 element batch = 2 feeds expected
-        assertEquals("Different logged events count;", 2, feeds.size());
-    }
-
-    @Test
-    public void testPrivateLogger() throws Exception {
-        configureLogging("resources/logging_atompush_disabled.properties");
-        Logger log = LogUtils.getL7dLogger(JAXRSLoggingAtomPushTest.class, null, "private-log");
-        Converter c = new StandardConverter(Output.FEED, Multiplicity.ONE, Format.CONTENT);
-        Deliverer d = new WebClientDeliverer("http://localhost:9080");
-        Handler h = new AtomPushHandler(2, c, d);
-        log.addHandler(h);
-        log.setLevel(Level.ALL);
-        logSixEvents(log);
-        // need to wait: multithreaded and client-server journey
-        Thread.sleep(1000);
-        // 6 events / 2 element batch = 3 feeds expected
-        assertEquals("Different logged events count;", 3, feeds.size());
-    }
-
-    @Test
-    public void testAtomPubEntries() throws Exception {
-        configureLogging("resources/logging_atompush_atompub.properties");
-        logSixEvents(LOG);
-        // need to wait: multithreaded and client-server journey
-        Thread.sleep(1000);
-        // 6 events logged as entries
-        assertEquals("Different logged events count;", 6, entries.size());
-    }
-
-}
+/**
+ * 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.cxf.systest.jaxrs;
+
+import java.io.InputStream;
+import java.util.ArrayList;
+import java.util.Arrays;
+import java.util.List;
+import java.util.logging.Handler;
+import java.util.logging.Level;
+import java.util.logging.LogManager;
+import java.util.logging.LogRecord;
+import java.util.logging.Logger;
+
+import javax.ws.rs.POST;
+import javax.ws.rs.Path;
+
+import org.apache.abdera.model.Entry;
+import org.apache.abdera.model.Feed;
+import org.apache.cxf.common.logging.LogUtils;
+import org.apache.cxf.endpoint.Server;
+import org.apache.cxf.jaxrs.JAXRSServerFactoryBean;
+import org.apache.cxf.jaxrs.ext.logging.atom.AtomPushHandler;
+import org.apache.cxf.jaxrs.ext.logging.atom.converter.Converter;
+import org.apache.cxf.jaxrs.ext.logging.atom.converter.StandardConverter;
+import org.apache.cxf.jaxrs.ext.logging.atom.converter.StandardConverter.Format;
+import org.apache.cxf.jaxrs.ext.logging.atom.converter.StandardConverter.Multiplicity;
+import org.apache.cxf.jaxrs.ext.logging.atom.converter.StandardConverter.Output;
+import org.apache.cxf.jaxrs.ext.logging.atom.deliverer.Deliverer;
+import org.apache.cxf.jaxrs.ext.logging.atom.deliverer.WebClientDeliverer;
+import org.apache.cxf.jaxrs.provider.AtomEntryProvider;
+import org.apache.cxf.jaxrs.provider.AtomFeedProvider;
+
+import org.junit.AfterClass;
+import org.junit.Before;
+import org.junit.BeforeClass;
+import org.junit.Ignore;
+import org.junit.Test;
+
+import static org.junit.Assert.assertEquals;
+
+public class JAXRSLoggingAtomPushTest {
+    private static final Logger LOG = LogUtils.getL7dLogger(JAXRSLoggingAtomPushTest.class);
+    private static Server server;
+    private static List<Feed> feeds = new ArrayList<Feed>();
+    private static List<Entry> entries = new ArrayList<Entry>();
+
+    @Ignore
+    @Path("/")
+    public static class Resource {
+        @POST
+        public void consume(Feed feed) {
+            System.out.println(feed);
+            feeds.add(feed);
+        }
+
+        @POST
+        @Path("/atomPub")
+        public void consume(Entry entry) {
+            System.out.println(entry);
+            entries.add(entry);
+        }
+    }
+
+    @SuppressWarnings("unchecked")
+    @BeforeClass
+    public static void beforeClass() throws Exception {
+        // disable logging for server startup
+        configureLogging("resources/logging_atompush_disabled.properties");
+
+        JAXRSServerFactoryBean sf = new JAXRSServerFactoryBean();
+        sf.setResourceClasses(JAXRSLoggingAtomPushTest.Resource.class);
+        sf.setAddress("http://localhost:9080/");
+        sf.setProviders(Arrays.asList(new AtomFeedProvider(), new AtomEntryProvider()));
+        server = sf.create();
+        server.start();
+    }
+
+    /** Configures global logging */
+    private static void configureLogging(String propFile) throws Exception {
+        LogManager lm = LogManager.getLogManager();
+        InputStream ins = JAXRSLoggingAtomPushTest.class.getResourceAsStream(propFile);
+        lm.readConfiguration(ins);
+    }
+
+    private static void logSixEvents(Logger log) {
+        log.severe("severe message");
+        log.warning("warning message");
+        log.info("info message");
+        LogRecord r = new LogRecord(Level.FINE, "fine message");
+        r.setThrown(new IllegalArgumentException("tadaam"));
+        log.log(r);
+        r = new LogRecord(Level.FINER, "finer message with {0} and {1}");
+        r.setParameters(new Object[] {
+            "param1", "param2"
+        });
+        r.setLoggerName("faky-logger");
+        log.log(r);
+        log.finest("finest message");
+    }
+
+    @AfterClass
+    public static void afterClass() throws Exception {
+        if (server != null) {
+            server.stop();
+        }
+        LogManager lm = LogManager.getLogManager();
+        try {
+            // restoring original configuration to not use tested logging handlers
+            lm.readConfiguration();
+        } catch (Exception e) {
+            // ignore missing config file
+        }
+    }
+
+    @Before
+    public void before() throws Exception {
+        feeds.clear();
+        entries.clear();
+    }
+
+    @Test
+    public void testOneElementBatch() throws Exception {
+        configureLogging("resources/logging_atompush.properties");
+        logSixEvents(LOG);
+        // need to wait: multithreaded and client-server journey
+        Thread.sleep(1000);
+        assertEquals("Different logged events count;", 6, feeds.size());
+    }
+
+    @Test
+    public void testMultiElementBatch() throws Exception {
+        configureLogging("resources/logging_atompush_batch.properties");
+        logSixEvents(LOG);
+        // need to wait: multithreaded and client-server journey
+        Thread.sleep(1000);
+        // 6 events / 3 element batch = 2 feeds expected
+        assertEquals("Different logged events count;", 2, feeds.size());
+    }
+
+    @Test
+    public void testPrivateLogger() throws Exception {
+        configureLogging("resources/logging_atompush_disabled.properties");
+        Logger log = LogUtils.getL7dLogger(JAXRSLoggingAtomPushTest.class, null, "private-log");
+        Converter c = new StandardConverter(Output.FEED, Multiplicity.ONE, Format.CONTENT);
+        Deliverer d = new WebClientDeliverer("http://localhost:9080");
+        Handler h = new AtomPushHandler(2, c, d);
+        log.addHandler(h);
+        log.setLevel(Level.ALL);
+        logSixEvents(log);
+        // need to wait: multithreaded and client-server journey
+        Thread.sleep(1000);
+        // 6 events / 2 element batch = 3 feeds expected
+        assertEquals("Different logged events count;", 3, feeds.size());
+    }
+
+    @Test
+    public void testAtomPubEntries() throws Exception {
+        configureLogging("resources/logging_atompush_atompub.properties");
+        logSixEvents(LOG);
+        // need to wait: multithreaded and client-server journey
+        Thread.sleep(1000);
+        // 6 events logged as entries
+        assertEquals("Different logged events count;", 6, entries.size());
+    }
+
+}

Propchange: cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/JAXRSLoggingAtomPushTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/JAXRSLoggingAtomPushTest.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/resources/logging_atompush.properties
URL: http://svn.apache.org/viewvc/cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/resources/logging_atompush.properties?rev=886957&r1=886956&r2=886957&view=diff
==============================================================================
--- cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/resources/logging_atompush.properties (original)
+++ cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/resources/logging_atompush.properties Thu Dec  3 22:26:58 2009
@@ -1,30 +1,30 @@
-# Atom logger plus echo on console
-handlers = org.apache.cxf.jaxrs.ext.logging.atom.AtomPushHandler, java.util.logging.ConsoleHandler
-
-# Set the default logging level for the root logger
-.level = ALL
-
-# Set logging levels for the package-named loggers 
-org.apache.cxf.systest.jaxrs.level = ALL
-
-# Need to turn off logging from surrounding environment to properly count log entries in tests
-# (specified sub-entries since root level overrides sub-levels... yes, JUL is dumb :)
-org.apache.cxf.jaxrs.level = OFF
-org.apache.cxf.phase.level = OFF
-org.apache.cxf.service.level = OFF
-org.apache.cxf.interceptor.level = OFF
-org.apache.cxf.transport.level = OFF
-org.apache.cxf.bus.level = OFF
-org.apache.cxf.configuration.level = OFF
-org.apache.cxf.endpoint.level = OFF
-org.apache.cxf.resource.level = OFF
-org.springframework.level = OFF
-org.mortbay.level = OFF
-org.apache.axiom.level = OFF
-
-# Atom handler specific settings
-org.apache.cxf.jaxrs.ext.logging.atom.AtomPushHandler.url = http://localhost:9080
-org.apache.cxf.jaxrs.ext.logging.atom.AtomPushHandler.batchSize = 1
-org.apache.cxf.jaxrs.ext.logging.atom.AtomPushHandler.output = feed
-org.apache.cxf.jaxrs.ext.logging.atom.AtomPushHandler.entries = one
-org.apache.cxf.jaxrs.ext.logging.atom.AtomPushHandler.format = content
+# Atom logger plus echo on console
+handlers = org.apache.cxf.jaxrs.ext.logging.atom.AtomPushHandler, java.util.logging.ConsoleHandler
+
+# Set the default logging level for the root logger
+.level = ALL
+
+# Set logging levels for the package-named loggers 
+org.apache.cxf.systest.jaxrs.level = ALL
+
+# Need to turn off logging from surrounding environment to properly count log entries in tests
+# (specified sub-entries since root level overrides sub-levels... yes, JUL is dumb :)
+org.apache.cxf.jaxrs.level = OFF
+org.apache.cxf.phase.level = OFF
+org.apache.cxf.service.level = OFF
+org.apache.cxf.interceptor.level = OFF
+org.apache.cxf.transport.level = OFF
+org.apache.cxf.bus.level = OFF
+org.apache.cxf.configuration.level = OFF
+org.apache.cxf.endpoint.level = OFF
+org.apache.cxf.resource.level = OFF
+org.springframework.level = OFF
+org.mortbay.level = OFF
+org.apache.axiom.level = OFF
+
+# Atom handler specific settings
+org.apache.cxf.jaxrs.ext.logging.atom.AtomPushHandler.url = http://localhost:9080
+org.apache.cxf.jaxrs.ext.logging.atom.AtomPushHandler.batchSize = 1
+org.apache.cxf.jaxrs.ext.logging.atom.AtomPushHandler.output = feed
+org.apache.cxf.jaxrs.ext.logging.atom.AtomPushHandler.entries = one
+org.apache.cxf.jaxrs.ext.logging.atom.AtomPushHandler.format = content

Propchange: cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/resources/logging_atompush.properties
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/resources/logging_atompush.properties
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/resources/logging_atompush.properties
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Modified: cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/resources/logging_atompush_atompub.properties
URL: http://svn.apache.org/viewvc/cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/resources/logging_atompush_atompub.properties?rev=886957&r1=886956&r2=886957&view=diff
==============================================================================
--- cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/resources/logging_atompush_atompub.properties (original)
+++ cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/resources/logging_atompush_atompub.properties Thu Dec  3 22:26:58 2009
@@ -1,31 +1,31 @@
-# Atom logger plus echo on console
-handlers = org.apache.cxf.jaxrs.ext.logging.atom.AtomPushHandler, java.util.logging.ConsoleHandler
-
-# Set the default logging level for the root logger
-.level = ALL
-
-# Set logging levels for the package-named loggers 
-org.apache.cxf.systest.jaxrs.level = ALL
-
-# Need to turn off logging from surrounding environment to properly count log entries in tests
-# (specified sub-entries since root level overrides sub-levels... yes, JUL is dumb :)
-org.apache.cxf.jaxrs.level = OFF
-org.apache.cxf.phase.level = OFF
-org.apache.cxf.service.level = OFF
-org.apache.cxf.interceptor.level = OFF
-org.apache.cxf.transport.level = OFF
-org.apache.cxf.bus.level = OFF
-org.apache.cxf.configuration.level = OFF
-org.apache.cxf.endpoint.level = OFF
-org.apache.cxf.resource.level = OFF
-org.springframework.level = OFF
-org.mortbay.level = OFF
-org.apache.axiom.level = OFF
-
-# Atom handler specific settings
-org.apache.cxf.jaxrs.ext.logging.atom.AtomPushHandler.url = http://localhost:9080/atomPub
-org.apache.cxf.jaxrs.ext.logging.atom.AtomPushHandler.batchSize = 1
-org.apache.cxf.jaxrs.ext.logging.atom.AtomPushHandler.output = entry
-org.apache.cxf.jaxrs.ext.logging.atom.AtomPushHandler.multiplicity = one
-org.apache.cxf.jaxrs.ext.logging.atom.AtomPushHandler.format = extension
-
+# Atom logger plus echo on console
+handlers = org.apache.cxf.jaxrs.ext.logging.atom.AtomPushHandler, java.util.logging.ConsoleHandler
+
+# Set the default logging level for the root logger
+.level = ALL
+
+# Set logging levels for the package-named loggers 
+org.apache.cxf.systest.jaxrs.level = ALL
+
+# Need to turn off logging from surrounding environment to properly count log entries in tests
+# (specified sub-entries since root level overrides sub-levels... yes, JUL is dumb :)
+org.apache.cxf.jaxrs.level = OFF
+org.apache.cxf.phase.level = OFF
+org.apache.cxf.service.level = OFF
+org.apache.cxf.interceptor.level = OFF
+org.apache.cxf.transport.level = OFF
+org.apache.cxf.bus.level = OFF
+org.apache.cxf.configuration.level = OFF
+org.apache.cxf.endpoint.level = OFF
+org.apache.cxf.resource.level = OFF
+org.springframework.level = OFF
+org.mortbay.level = OFF
+org.apache.axiom.level = OFF
+
+# Atom handler specific settings
+org.apache.cxf.jaxrs.ext.logging.atom.AtomPushHandler.url = http://localhost:9080/atomPub
+org.apache.cxf.jaxrs.ext.logging.atom.AtomPushHandler.batchSize = 1
+org.apache.cxf.jaxrs.ext.logging.atom.AtomPushHandler.output = entry
+org.apache.cxf.jaxrs.ext.logging.atom.AtomPushHandler.multiplicity = one
+org.apache.cxf.jaxrs.ext.logging.atom.AtomPushHandler.format = extension
+

Propchange: cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/resources/logging_atompush_atompub.properties
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/resources/logging_atompush_atompub.properties
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/resources/logging_atompush_atompub.properties
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Modified: cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/resources/logging_atompush_batch.properties
URL: http://svn.apache.org/viewvc/cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/resources/logging_atompush_batch.properties?rev=886957&r1=886956&r2=886957&view=diff
==============================================================================
--- cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/resources/logging_atompush_batch.properties (original)
+++ cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/resources/logging_atompush_batch.properties Thu Dec  3 22:26:58 2009
@@ -1,27 +1,27 @@
-# Atom logger plus echo on console
-handlers = org.apache.cxf.jaxrs.ext.logging.atom.AtomPushHandler, java.util.logging.ConsoleHandler
-
-# Set the default logging level for the root logger
-.level = ALL
-
-# Set logging levels for the package-named loggers 
-org.apache.cxf.systest.jaxrs.level = ALL
-
-# Need to turn off logging from surrounding environment to properly count log entries in tests
-# (specified sub-entries since root level overrides sub-levels... yes, JUL is dumb :)
-org.apache.cxf.jaxrs.level = OFF
-org.apache.cxf.phase.level = OFF
-org.apache.cxf.service.level = OFF
-org.apache.cxf.interceptor.level = OFF
-org.apache.cxf.transport.level = OFF
-org.apache.cxf.bus.level = OFF
-org.apache.cxf.configuration.level = OFF
-org.apache.cxf.endpoint.level = OFF
-org.apache.cxf.resource.level = OFF
-org.springframework.level = OFF
-org.mortbay.level = OFF
-org.apache.axiom.level = OFF
-
-# Atom handler specific settings
-org.apache.cxf.jaxrs.ext.logging.atom.AtomPushHandler.url = http://localhost:9080
-org.apache.cxf.jaxrs.ext.logging.atom.AtomPushHandler.batchSize = 3
+# Atom logger plus echo on console
+handlers = org.apache.cxf.jaxrs.ext.logging.atom.AtomPushHandler, java.util.logging.ConsoleHandler
+
+# Set the default logging level for the root logger
+.level = ALL
+
+# Set logging levels for the package-named loggers 
+org.apache.cxf.systest.jaxrs.level = ALL
+
+# Need to turn off logging from surrounding environment to properly count log entries in tests
+# (specified sub-entries since root level overrides sub-levels... yes, JUL is dumb :)
+org.apache.cxf.jaxrs.level = OFF
+org.apache.cxf.phase.level = OFF
+org.apache.cxf.service.level = OFF
+org.apache.cxf.interceptor.level = OFF
+org.apache.cxf.transport.level = OFF
+org.apache.cxf.bus.level = OFF
+org.apache.cxf.configuration.level = OFF
+org.apache.cxf.endpoint.level = OFF
+org.apache.cxf.resource.level = OFF
+org.springframework.level = OFF
+org.mortbay.level = OFF
+org.apache.axiom.level = OFF
+
+# Atom handler specific settings
+org.apache.cxf.jaxrs.ext.logging.atom.AtomPushHandler.url = http://localhost:9080
+org.apache.cxf.jaxrs.ext.logging.atom.AtomPushHandler.batchSize = 3

Propchange: cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/resources/logging_atompush_batch.properties
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/resources/logging_atompush_batch.properties
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/resources/logging_atompush_batch.properties
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Modified: cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/resources/logging_atompush_disabled.properties
URL: http://svn.apache.org/viewvc/cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/resources/logging_atompush_disabled.properties?rev=886957&r1=886956&r2=886957&view=diff
==============================================================================
--- cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/resources/logging_atompush_disabled.properties (original)
+++ cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/resources/logging_atompush_disabled.properties Thu Dec  3 22:26:58 2009
@@ -1,15 +1,15 @@
-handlers = java.util.logging.ConsoleHandler
-.level = OFF
-org.apache.cxf.jaxrs.level = OFF
-org.apache.cxf.phase.level = OFF
-org.apache.cxf.service.level = OFF
-org.apache.cxf.interceptor.level = OFF
-org.apache.cxf.transport.level = OFF
-org.apache.cxf.bus.level = OFF
-org.apache.cxf.configuration.level = OFF
-org.apache.cxf.endpoint.level = OFF
-org.apache.cxf.resource.level = OFF
-org.springframework.level = OFF
-org.mortbay.level = OFF
-org.apache.axiom.level = OFF
-
+handlers = java.util.logging.ConsoleHandler
+.level = OFF
+org.apache.cxf.jaxrs.level = OFF
+org.apache.cxf.phase.level = OFF
+org.apache.cxf.service.level = OFF
+org.apache.cxf.interceptor.level = OFF
+org.apache.cxf.transport.level = OFF
+org.apache.cxf.bus.level = OFF
+org.apache.cxf.configuration.level = OFF
+org.apache.cxf.endpoint.level = OFF
+org.apache.cxf.resource.level = OFF
+org.springframework.level = OFF
+org.mortbay.level = OFF
+org.apache.axiom.level = OFF
+

Propchange: cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/resources/logging_atompush_disabled.properties
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/resources/logging_atompush_disabled.properties
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: cxf/trunk/systests/jaxrs/src/test/java/org/apache/cxf/systest/jaxrs/resources/logging_atompush_disabled.properties
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: cxf/trunk/systests/jaxrs/src/test/resources/jaxrs_jackson_provider/WEB-INF/beans.xml
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: cxf/trunk/systests/jaxrs/src/test/resources/jaxrs_jackson_provider/WEB-INF/web.xml
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: cxf/trunk/systests/jaxrs/src/test/resources/jaxrs_logging_atompush/WEB-INF/beans.xml
URL: http://svn.apache.org/viewvc/cxf/trunk/systests/jaxrs/src/test/resources/jaxrs_logging_atompush/WEB-INF/beans.xml?rev=886957&r1=886956&r2=886957&view=diff
==============================================================================
--- cxf/trunk/systests/jaxrs/src/test/resources/jaxrs_logging_atompush/WEB-INF/beans.xml (original)
+++ cxf/trunk/systests/jaxrs/src/test/resources/jaxrs_logging_atompush/WEB-INF/beans.xml Thu Dec  3 22:26:58 2009
@@ -1,92 +1,92 @@
-<?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.
-	-->
-	<!-- START SNIPPET: beans -->
-	<!--
-		beans xmlns="http://www.springframework.org/schema/beans"
-		xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-		xmlns:simple="http://cxf.apache.org/simple" xsi:schemaLocation="
-		http://www.springframework.org/schema/beans
-		http://www.springframework.org/schema/beans/spring-beans.xsd
-		http://cxf.apache.org/simple http://cxf.apache.org/schemas/simple.xsd"
-	-->
-<beans xmlns="http://www.springframework.org/schema/beans"
-	xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xmlns:jaxrs="http://cxf.apache.org/jaxrs"
-	xmlns:aop="http://www.springframework.org/schema/aop"
-	xsi:schemaLocation="
-http://www.springframework.org/schema/beans 
-http://www.springframework.org/schema/beans/spring-beans.xsd
-http://cxf.apache.org/jaxrs
-http://cxf.apache.org/schemas/jaxrs.xsd">
-
-	<import resource="classpath:META-INF/cxf/cxf.xml" />
-	<import resource="classpath:META-INF/cxf/cxf-extension-jaxrs-binding.xml" />
-	<import resource="classpath:META-INF/cxf/cxf-servlet.xml" />
-
-	<bean class="org.apache.cxf.jaxrs.ext.logging.atom.AtomPushBean"
-		init-method="init">
-		<property name="url" value="http://localhost:9080/feed" />
-		<!-- Mind the '$' instead of '.' for inner classes! -->
-		<property name="loggers"
-			value="
-			org.apache.cxf.systest.jaxrs.JAXRSLoggingAtomPushSpringTest$Resource:ALL,
-			namedLogger:WARN" />
-	</bean>
-
-	<!--  
-	Other config samples:
-	
-	<bean class="org.apache.cxf.jaxrs.ext.logging.atom.AtomPushBean"
-		init-method="init">
-
-		<property name="url" value="http://localhost:9080/feed" />
-		<property name="level" value="ALL" />
-	</bean>
-
-	<bean id="soapDeliverer" ... />
-	<bean class="org.apache.cxf.jaxrs.ext.logging.atom.AtomPushBean"
-		init-method="init">
-		<property name="deliverer">
-			<ref bean="soapDeliverer" />
-		</property>
-		<property name="loggers"
-			value="
-			  org.apache.cxf:DEBUG,
-			  org.apache.cxf.jaxrs:ALL,
-			  org.apache.cxf.bus:WARNING" />
-		<property name="batchSize" value="10" />
-	</bean>
- 	-->
- 	
-	<jaxrs:server id="atomserver" address="/">
-		<jaxrs:serviceBeans>
-			<ref bean="atombean" />
-		</jaxrs:serviceBeans>
-		<jaxrs:providers>
-			<ref bean="feed" />
-			<ref bean="entry" />
-		</jaxrs:providers>
-	</jaxrs:server>
-
-	<!-- Mind the '$' instead of '.' for inner classes! -->
-	<bean id="atombean"
-		class="org.apache.cxf.systest.jaxrs.JAXRSLoggingAtomPushSpringTest$Resource" />
-	<bean id="feed" class="org.apache.cxf.jaxrs.provider.AtomFeedProvider" />
-	<bean id="entry" class="org.apache.cxf.jaxrs.provider.AtomEntryProvider" />
-
-</beans>
-	<!-- END SNIPPET: 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.
+	-->
+	<!-- START SNIPPET: beans -->
+	<!--
+		beans xmlns="http://www.springframework.org/schema/beans"
+		xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+		xmlns:simple="http://cxf.apache.org/simple" xsi:schemaLocation="
+		http://www.springframework.org/schema/beans
+		http://www.springframework.org/schema/beans/spring-beans.xsd
+		http://cxf.apache.org/simple http://cxf.apache.org/schemas/simple.xsd"
+	-->
+<beans xmlns="http://www.springframework.org/schema/beans"
+	xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xmlns:jaxrs="http://cxf.apache.org/jaxrs"
+	xmlns:aop="http://www.springframework.org/schema/aop"
+	xsi:schemaLocation="
+http://www.springframework.org/schema/beans 
+http://www.springframework.org/schema/beans/spring-beans.xsd
+http://cxf.apache.org/jaxrs
+http://cxf.apache.org/schemas/jaxrs.xsd">
+
+	<import resource="classpath:META-INF/cxf/cxf.xml" />
+	<import resource="classpath:META-INF/cxf/cxf-extension-jaxrs-binding.xml" />
+	<import resource="classpath:META-INF/cxf/cxf-servlet.xml" />
+
+	<bean class="org.apache.cxf.jaxrs.ext.logging.atom.AtomPushBean"
+		init-method="init">
+		<property name="url" value="http://localhost:9080/feed" />
+		<!-- Mind the '$' instead of '.' for inner classes! -->
+		<property name="loggers"
+			value="
+			org.apache.cxf.systest.jaxrs.JAXRSLoggingAtomPushSpringTest$Resource:ALL,
+			namedLogger:WARN" />
+	</bean>
+
+	<!--  
+	Other config samples:
+	
+	<bean class="org.apache.cxf.jaxrs.ext.logging.atom.AtomPushBean"
+		init-method="init">
+
+		<property name="url" value="http://localhost:9080/feed" />
+		<property name="level" value="ALL" />
+	</bean>
+
+	<bean id="soapDeliverer" ... />
+	<bean class="org.apache.cxf.jaxrs.ext.logging.atom.AtomPushBean"
+		init-method="init">
+		<property name="deliverer">
+			<ref bean="soapDeliverer" />
+		</property>
+		<property name="loggers"
+			value="
+			  org.apache.cxf:DEBUG,
+			  org.apache.cxf.jaxrs:ALL,
+			  org.apache.cxf.bus:WARNING" />
+		<property name="batchSize" value="10" />
+	</bean>
+ 	-->
+ 	
+	<jaxrs:server id="atomserver" address="/">
+		<jaxrs:serviceBeans>
+			<ref bean="atombean" />
+		</jaxrs:serviceBeans>
+		<jaxrs:providers>
+			<ref bean="feed" />
+			<ref bean="entry" />
+		</jaxrs:providers>
+	</jaxrs:server>
+
+	<!-- Mind the '$' instead of '.' for inner classes! -->
+	<bean id="atombean"
+		class="org.apache.cxf.systest.jaxrs.JAXRSLoggingAtomPushSpringTest$Resource" />
+	<bean id="feed" class="org.apache.cxf.jaxrs.provider.AtomFeedProvider" />
+	<bean id="entry" class="org.apache.cxf.jaxrs.provider.AtomEntryProvider" />
+
+</beans>
+	<!-- END SNIPPET: beans -->
+

Propchange: cxf/trunk/systests/jaxrs/src/test/resources/jaxrs_logging_atompush/WEB-INF/beans.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: cxf/trunk/systests/jaxrs/src/test/resources/jaxrs_logging_atompush/WEB-INF/beans.xml
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: cxf/trunk/systests/jaxrs/src/test/resources/jaxrs_logging_atompush/WEB-INF/beans.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Modified: cxf/trunk/systests/jaxrs/src/test/resources/jaxrs_logging_atompush/WEB-INF/web.xml
URL: http://svn.apache.org/viewvc/cxf/trunk/systests/jaxrs/src/test/resources/jaxrs_logging_atompush/WEB-INF/web.xml?rev=886957&r1=886956&r2=886957&view=diff
==============================================================================
--- cxf/trunk/systests/jaxrs/src/test/resources/jaxrs_logging_atompush/WEB-INF/web.xml (original)
+++ cxf/trunk/systests/jaxrs/src/test/resources/jaxrs_logging_atompush/WEB-INF/web.xml Thu Dec  3 22:26:58 2009
@@ -1,51 +1,51 @@
-<?xml version="1.0" encoding="ISO-8859-1"?>
-<!DOCTYPE web-app
-    PUBLIC "-//Sun Microsystems, Inc.//DTD Web Application 2.3//EN"
-    "http://java.sun.com/dtd/web-app_2_3.dtd">
-<!--
-	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.
--->
-<!-- START SNIPPET: webxml -->
-<web-app>
-	<context-param>
-		<param-name>contextConfigLocation</param-name>
-		<param-value>WEB-INF/beans.xml</param-value>
-	</context-param>
-
-	<listener>
-		<listener-class>
-			org.springframework.web.context.ContextLoaderListener
-		</listener-class>
-	</listener>
-
-	<servlet>
-		<servlet-name>CXFServlet</servlet-name>
-		<display-name>CXF Servlet</display-name>
-		<servlet-class>
-			org.apache.cxf.transport.servlet.CXFServlet
-		</servlet-class>
-		<load-on-startup>1</load-on-startup>
-	</servlet>
-	
-	<servlet-mapping>
-		<servlet-name>CXFServlet</servlet-name>
-		<url-pattern>/*</url-pattern>
-	</servlet-mapping>
-	
-</web-app>
-<!-- END SNIPPET: webxml -->
+<?xml version="1.0" encoding="ISO-8859-1"?>
+<!DOCTYPE web-app
+    PUBLIC "-//Sun Microsystems, Inc.//DTD Web Application 2.3//EN"
+    "http://java.sun.com/dtd/web-app_2_3.dtd">
+<!--
+	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.
+-->
+<!-- START SNIPPET: webxml -->
+<web-app>
+	<context-param>
+		<param-name>contextConfigLocation</param-name>
+		<param-value>WEB-INF/beans.xml</param-value>
+	</context-param>
+
+	<listener>
+		<listener-class>
+			org.springframework.web.context.ContextLoaderListener
+		</listener-class>
+	</listener>
+
+	<servlet>
+		<servlet-name>CXFServlet</servlet-name>
+		<display-name>CXF Servlet</display-name>
+		<servlet-class>
+			org.apache.cxf.transport.servlet.CXFServlet
+		</servlet-class>
+		<load-on-startup>1</load-on-startup>
+	</servlet>
+	
+	<servlet-mapping>
+		<servlet-name>CXFServlet</servlet-name>
+		<url-pattern>/*</url-pattern>
+	</servlet-mapping>
+	
+</web-app>
+<!-- END SNIPPET: webxml -->

Propchange: cxf/trunk/systests/jaxrs/src/test/resources/jaxrs_logging_atompush/WEB-INF/web.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: cxf/trunk/systests/jaxrs/src/test/resources/jaxrs_logging_atompush/WEB-INF/web.xml
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: cxf/trunk/systests/jaxrs/src/test/resources/jaxrs_logging_atompush/WEB-INF/web.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: cxf/trunk/systests/jaxws/src/test/java/org/apache/cxf/systest/jaxws/beanpostprocessor/BeanPostProcessorTest.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: cxf/trunk/systests/jaxws/src/test/java/org/apache/cxf/systest/jaxws/beanpostprocessor/CustomizedfBeanPostProcessorTest.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: cxf/trunk/systests/jaxws/src/test/java/org/apache/cxf/systest/jaxws/beanpostprocessor/IWebServiceRUs.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: cxf/trunk/systests/jaxws/src/test/java/org/apache/cxf/systest/jaxws/beanpostprocessor/WebServiceRUs.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: cxf/trunk/systests/jaxws/src/test/resources/org/apache/cxf/systest/jaxws/beanpostprocessor/context.xml
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: cxf/trunk/systests/jaxws/src/test/resources/org/apache/cxf/systest/jaxws/beanpostprocessor/customized-context.xml
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: cxf/trunk/systests/transports/src/test/java/org/apache/cxf/systest/servlet/SpringAutoPublishServletTest.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: cxf/trunk/systests/transports/src/test/java/org/apache/cxf/systest/servlet/spring-auto-launch.xml
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: cxf/trunk/systests/transports/src/test/java/org/apache/cxf/systest/servlet/web-spring-auto-launch.xml
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: cxf/trunk/systests/uncategorized/src/test/java/org/apache/cxf/systest/clustering/FailoverAddressOverrideTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: cxf/trunk/systests/uncategorized/src/test/java/org/apache/cxf/systest/clustering/FailoverAddressOverrideTest.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: cxf/trunk/systests/uncategorized/src/test/java/org/apache/cxf/systest/clustering/failover_address_override.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: cxf/trunk/systests/uncategorized/src/test/java/org/apache/cxf/systest/clustering/failover_address_override.xml
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: cxf/trunk/systests/uncategorized/src/test/java/org/apache/cxf/systest/clustering/failover_address_override.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: cxf/trunk/systests/uncategorized/src/test/java/org/apache/cxf/systest/management/persistent-id.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: cxf/trunk/systests/uncategorized/src/test/java/org/apache/cxf/systest/management/persistent-id.xml
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: cxf/trunk/systests/uncategorized/src/test/java/org/apache/cxf/systest/management/persistent-id.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Modified: cxf/trunk/systests/wsdl_maven/codegen/pom.xml
URL: http://svn.apache.org/viewvc/cxf/trunk/systests/wsdl_maven/codegen/pom.xml?rev=886957&r1=886956&r2=886957&view=diff
==============================================================================
--- cxf/trunk/systests/wsdl_maven/codegen/pom.xml (original)
+++ cxf/trunk/systests/wsdl_maven/codegen/pom.xml Thu Dec  3 22:26:58 2009
@@ -1,76 +1,76 @@
-<!--
-  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.
--->
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/maven-v4_0_0.xsd">
-    <modelVersion>4.0.0</modelVersion>
-    <groupId>org.apache.cxf.systests.wsdl_maven</groupId>
-    <artifactId>cxf-systests-codegen</artifactId>
-    <version>2.3.0-SNAPSHOT</version>
-    <name>Test for reading wsdl from repo and generating code from it</name>
-    <parent>
-        <groupId>org.apache.cxf</groupId>
-        <artifactId>cxf-parent</artifactId>
-        <version>2.3.0-SNAPSHOT</version>
-        <relativePath>../../../parent/pom.xml</relativePath>
-    </parent>
-    <build>
-        <plugins>
-            <plugin>
-                <artifactId>maven-compiler-plugin</artifactId>
-                <configuration>
-                    <source>1.5</source>
-                    <target>1.5</target>
-                </configuration>
-            </plugin>
-            <plugin>
-                <groupId>org.apache.cxf</groupId>
-                <artifactId>cxf-codegen-plugin</artifactId>
-                <version>${project.version}</version>
-                <executions>
-                    <execution>
-                        <id>generate-sources</id>
-                        <phase>generate-sources</phase>
-
-                        <goals>
-                            <goal>wsdl2java</goal>
-                        </goals>
-                    </execution>
-                </executions>
-            </plugin>
-        </plugins>
-    </build>
-    
-    <dependencies>
-        <dependency>
-            <groupId>org.apache.cxf.systests.wsdl_maven</groupId>
-            <artifactId>cxf-systests-java2ws</artifactId>
-            <version>${project.version}</version>
-	  <type>wsdl</type>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.cxf</groupId>
-            <artifactId>cxf-rt-frontend-jaxws</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.cxf.systests.wsdl_maven</groupId>
-            <artifactId>cxf-systests-java2ws</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-    </dependencies>
-</project>
+<!--
+  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.
+-->
+<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/maven-v4_0_0.xsd">
+    <modelVersion>4.0.0</modelVersion>
+    <groupId>org.apache.cxf.systests.wsdl_maven</groupId>
+    <artifactId>cxf-systests-codegen</artifactId>
+    <version>2.3.0-SNAPSHOT</version>
+    <name>Test for reading wsdl from repo and generating code from it</name>
+    <parent>
+        <groupId>org.apache.cxf</groupId>
+        <artifactId>cxf-parent</artifactId>
+        <version>2.3.0-SNAPSHOT</version>
+        <relativePath>../../../parent/pom.xml</relativePath>
+    </parent>
+    <build>
+        <plugins>
+            <plugin>
+                <artifactId>maven-compiler-plugin</artifactId>
+                <configuration>
+                    <source>1.5</source>
+                    <target>1.5</target>
+                </configuration>
+            </plugin>
+            <plugin>
+                <groupId>org.apache.cxf</groupId>
+                <artifactId>cxf-codegen-plugin</artifactId>
+                <version>${project.version}</version>
+                <executions>
+                    <execution>
+                        <id>generate-sources</id>
+                        <phase>generate-sources</phase>
+
+                        <goals>
+                            <goal>wsdl2java</goal>
+                        </goals>
+                    </execution>
+                </executions>
+            </plugin>
+        </plugins>
+    </build>
+    
+    <dependencies>
+        <dependency>
+            <groupId>org.apache.cxf.systests.wsdl_maven</groupId>
+            <artifactId>cxf-systests-java2ws</artifactId>
+            <version>${project.version}</version>
+	  <type>wsdl</type>
+        </dependency>
+        <dependency>
+            <groupId>org.apache.cxf</groupId>
+            <artifactId>cxf-rt-frontend-jaxws</artifactId>
+            <version>${project.version}</version>
+        </dependency>
+        <dependency>
+            <groupId>org.apache.cxf.systests.wsdl_maven</groupId>
+            <artifactId>cxf-systests-java2ws</artifactId>
+            <version>${project.version}</version>
+        </dependency>
+    </dependencies>
+</project>

Propchange: cxf/trunk/systests/wsdl_maven/codegen/pom.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: cxf/trunk/systests/wsdl_maven/codegen/pom.xml
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Propchange: cxf/trunk/systests/wsdl_maven/codegen/pom.xml
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Thu Dec  3 22:26:58 2009
@@ -1 +1 @@
-text/plain
+text/xml