You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@shiro.apache.org by ad...@apache.org on 2010/05/26 20:34:49 UTC

svn commit: r948527 [38/38] - in /incubator/shiro: branches/shiro-root-1.0.x/ branches/shiro-root-1.0.x/all/ branches/shiro-root-1.0.x/core/src/main/java/org/apache/shiro/ branches/shiro-root-1.0.x/core/src/main/java/org/apache/shiro/aop/ branches/shir...

Modified: incubator/shiro/trunk/web/src/test/java/org/apache/shiro/web/filter/mgt/PathMatchingFilterChainResolverTest.java
URL: http://svn.apache.org/viewvc/incubator/shiro/trunk/web/src/test/java/org/apache/shiro/web/filter/mgt/PathMatchingFilterChainResolverTest.java?rev=948527&r1=948526&r2=948527&view=diff
==============================================================================
--- incubator/shiro/trunk/web/src/test/java/org/apache/shiro/web/filter/mgt/PathMatchingFilterChainResolverTest.java (original)
+++ incubator/shiro/trunk/web/src/test/java/org/apache/shiro/web/filter/mgt/PathMatchingFilterChainResolverTest.java Wed May 26 18:34:28 2010
@@ -1,128 +1,128 @@
-/*
- * 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.shiro.web.filter.mgt;
-
-import org.apache.shiro.util.AntPathMatcher;
-import org.apache.shiro.web.WebTest;
-import org.apache.shiro.web.util.WebUtils;
-import org.junit.Before;
-import org.junit.Test;
-
-import javax.servlet.FilterChain;
-import javax.servlet.FilterConfig;
-import javax.servlet.ServletRequest;
-import javax.servlet.ServletResponse;
-import javax.servlet.http.HttpServletRequest;
-import javax.servlet.http.HttpServletResponse;
-
-import static org.easymock.EasyMock.*;
-import static org.junit.Assert.*;
-
-/**
- * Tests for {@link org.apache.shiro.web.filter.mgt.PathMatchingFilterChainResolver}.
- *
- * @since 1.0
- */
-public class PathMatchingFilterChainResolverTest extends WebTest {
-
-    private PathMatchingFilterChainResolver resolver;
-
-    @Before
-    public void setUp() {
-        resolver = new PathMatchingFilterChainResolver();
-    }
-
-    @Test
-    public void testNewInstance() {
-        assertNotNull(resolver.getPathMatcher());
-        assertTrue(resolver.getPathMatcher() instanceof AntPathMatcher);
-        assertNotNull(resolver.getFilterChainManager());
-        assertTrue(resolver.getFilterChainManager() instanceof DefaultFilterChainManager);
-    }
-
-    @Test
-    public void testNewInstanceWithFilterConfig() {
-        FilterConfig mock = createNiceMockFilterConfig();
-        replay(mock);
-        resolver = new PathMatchingFilterChainResolver(mock);
-        assertNotNull(resolver.getPathMatcher());
-        assertTrue(resolver.getPathMatcher() instanceof AntPathMatcher);
-        assertNotNull(resolver.getFilterChainManager());
-        assertTrue(resolver.getFilterChainManager() instanceof DefaultFilterChainManager);
-        assertEquals(((DefaultFilterChainManager) resolver.getFilterChainManager()).getFilterConfig(), mock);
-        verify(mock);
-    }
-
-    @Test
-    public void testSetters() {
-        resolver.setPathMatcher(new AntPathMatcher());
-        assertNotNull(resolver.getPathMatcher());
-        assertTrue(resolver.getPathMatcher() instanceof AntPathMatcher);
-        resolver.setFilterChainManager(new DefaultFilterChainManager());
-        assertNotNull(resolver.getFilterChainManager());
-        assertTrue(resolver.getFilterChainManager() instanceof DefaultFilterChainManager);
-    }
-
-    @Test
-    public void testGetChainsWithoutChains() {
-        ServletRequest request = createNiceMock(HttpServletRequest.class);
-        ServletResponse response = createNiceMock(HttpServletResponse.class);
-        FilterChain chain = createNiceMock(FilterChain.class);
-        FilterChain resolved = resolver.getChain(request, response, chain);
-        assertNull(resolved);
-    }
-
-    @Test
-    public void testGetChainsWithMatch() {
-        HttpServletRequest request = createNiceMock(HttpServletRequest.class);
-        HttpServletResponse response = createNiceMock(HttpServletResponse.class);
-        FilterChain chain = createNiceMock(FilterChain.class);
-
-        //ensure at least one chain is defined:
-        resolver.getFilterChainManager().addToChain("/index.html", "authcBasic");
-
-        expect(request.getAttribute(WebUtils.INCLUDE_CONTEXT_PATH_ATTRIBUTE)).andReturn(null).anyTimes();
-        expect(request.getContextPath()).andReturn("");
-        expect(request.getRequestURI()).andReturn("/index.html");
-        replay(request);
-
-        FilterChain resolved = resolver.getChain(request, response, chain);
-        assertNotNull(resolved);
-        verify(request);
-    }
-
-    @Test
-    public void testGetChainsWithoutMatch() {
-        HttpServletRequest request = createNiceMock(HttpServletRequest.class);
-        HttpServletResponse response = createNiceMock(HttpServletResponse.class);
-        FilterChain chain = createNiceMock(FilterChain.class);
-
-        //ensure at least one chain is defined:
-        resolver.getFilterChainManager().addToChain("/index.html", "authcBasic");
-
-        expect(request.getAttribute(WebUtils.INCLUDE_CONTEXT_PATH_ATTRIBUTE)).andReturn(null).anyTimes();
-        expect(request.getContextPath()).andReturn("");
-        expect(request.getRequestURI()).andReturn("/");
-        replay(request);
-
-        FilterChain resolved = resolver.getChain(request, response, chain);
-        assertNull(resolved);
-        verify(request);
-    }
-}
+/*
+ * 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.shiro.web.filter.mgt;
+
+import org.apache.shiro.util.AntPathMatcher;
+import org.apache.shiro.web.WebTest;
+import org.apache.shiro.web.util.WebUtils;
+import org.junit.Before;
+import org.junit.Test;
+
+import javax.servlet.FilterChain;
+import javax.servlet.FilterConfig;
+import javax.servlet.ServletRequest;
+import javax.servlet.ServletResponse;
+import javax.servlet.http.HttpServletRequest;
+import javax.servlet.http.HttpServletResponse;
+
+import static org.easymock.EasyMock.*;
+import static org.junit.Assert.*;
+
+/**
+ * Tests for {@link org.apache.shiro.web.filter.mgt.PathMatchingFilterChainResolver}.
+ *
+ * @since 1.0
+ */
+public class PathMatchingFilterChainResolverTest extends WebTest {
+
+    private PathMatchingFilterChainResolver resolver;
+
+    @Before
+    public void setUp() {
+        resolver = new PathMatchingFilterChainResolver();
+    }
+
+    @Test
+    public void testNewInstance() {
+        assertNotNull(resolver.getPathMatcher());
+        assertTrue(resolver.getPathMatcher() instanceof AntPathMatcher);
+        assertNotNull(resolver.getFilterChainManager());
+        assertTrue(resolver.getFilterChainManager() instanceof DefaultFilterChainManager);
+    }
+
+    @Test
+    public void testNewInstanceWithFilterConfig() {
+        FilterConfig mock = createNiceMockFilterConfig();
+        replay(mock);
+        resolver = new PathMatchingFilterChainResolver(mock);
+        assertNotNull(resolver.getPathMatcher());
+        assertTrue(resolver.getPathMatcher() instanceof AntPathMatcher);
+        assertNotNull(resolver.getFilterChainManager());
+        assertTrue(resolver.getFilterChainManager() instanceof DefaultFilterChainManager);
+        assertEquals(((DefaultFilterChainManager) resolver.getFilterChainManager()).getFilterConfig(), mock);
+        verify(mock);
+    }
+
+    @Test
+    public void testSetters() {
+        resolver.setPathMatcher(new AntPathMatcher());
+        assertNotNull(resolver.getPathMatcher());
+        assertTrue(resolver.getPathMatcher() instanceof AntPathMatcher);
+        resolver.setFilterChainManager(new DefaultFilterChainManager());
+        assertNotNull(resolver.getFilterChainManager());
+        assertTrue(resolver.getFilterChainManager() instanceof DefaultFilterChainManager);
+    }
+
+    @Test
+    public void testGetChainsWithoutChains() {
+        ServletRequest request = createNiceMock(HttpServletRequest.class);
+        ServletResponse response = createNiceMock(HttpServletResponse.class);
+        FilterChain chain = createNiceMock(FilterChain.class);
+        FilterChain resolved = resolver.getChain(request, response, chain);
+        assertNull(resolved);
+    }
+
+    @Test
+    public void testGetChainsWithMatch() {
+        HttpServletRequest request = createNiceMock(HttpServletRequest.class);
+        HttpServletResponse response = createNiceMock(HttpServletResponse.class);
+        FilterChain chain = createNiceMock(FilterChain.class);
+
+        //ensure at least one chain is defined:
+        resolver.getFilterChainManager().addToChain("/index.html", "authcBasic");
+
+        expect(request.getAttribute(WebUtils.INCLUDE_CONTEXT_PATH_ATTRIBUTE)).andReturn(null).anyTimes();
+        expect(request.getContextPath()).andReturn("");
+        expect(request.getRequestURI()).andReturn("/index.html");
+        replay(request);
+
+        FilterChain resolved = resolver.getChain(request, response, chain);
+        assertNotNull(resolved);
+        verify(request);
+    }
+
+    @Test
+    public void testGetChainsWithoutMatch() {
+        HttpServletRequest request = createNiceMock(HttpServletRequest.class);
+        HttpServletResponse response = createNiceMock(HttpServletResponse.class);
+        FilterChain chain = createNiceMock(FilterChain.class);
+
+        //ensure at least one chain is defined:
+        resolver.getFilterChainManager().addToChain("/index.html", "authcBasic");
+
+        expect(request.getAttribute(WebUtils.INCLUDE_CONTEXT_PATH_ATTRIBUTE)).andReturn(null).anyTimes();
+        expect(request.getContextPath()).andReturn("");
+        expect(request.getRequestURI()).andReturn("/");
+        replay(request);
+
+        FilterChain resolved = resolver.getChain(request, response, chain);
+        assertNull(resolved);
+        verify(request);
+    }
+}

Propchange: incubator/shiro/trunk/web/src/test/java/org/apache/shiro/web/filter/mgt/PathMatchingFilterChainResolverTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/shiro/trunk/web/src/test/java/org/apache/shiro/web/filter/mgt/SimpleNamedFilterListTest.java
URL: http://svn.apache.org/viewvc/incubator/shiro/trunk/web/src/test/java/org/apache/shiro/web/filter/mgt/SimpleNamedFilterListTest.java?rev=948527&r1=948526&r2=948527&view=diff
==============================================================================
--- incubator/shiro/trunk/web/src/test/java/org/apache/shiro/web/filter/mgt/SimpleNamedFilterListTest.java (original)
+++ incubator/shiro/trunk/web/src/test/java/org/apache/shiro/web/filter/mgt/SimpleNamedFilterListTest.java Wed May 26 18:34:28 2010
@@ -1,154 +1,154 @@
-/*
- * 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.shiro.web.filter.mgt;
-
-import org.apache.shiro.util.CollectionUtils;
-import org.apache.shiro.web.filter.authc.UserFilter;
-import org.apache.shiro.web.filter.authz.PermissionsAuthorizationFilter;
-import org.apache.shiro.web.filter.authz.PortFilter;
-import org.apache.shiro.web.filter.authz.RolesAuthorizationFilter;
-import org.apache.shiro.web.filter.authz.SslFilter;
-import org.junit.Test;
-
-import javax.servlet.Filter;
-import javax.servlet.FilterChain;
-import java.util.*;
-
-import static org.easymock.EasyMock.createNiceMock;
-import static org.junit.Assert.*;
-
-/**
- * Test case for the {@link SimpleNamedFilterList} implementation.
- *
- * @since 1.0
- */
-public class SimpleNamedFilterListTest {
-
-    @Test
-    public void testNewInstance() {
-        @SuppressWarnings({"MismatchedQueryAndUpdateOfCollection"})
-        SimpleNamedFilterList list = new SimpleNamedFilterList("test");
-        assertNotNull(list.getName());
-        assertEquals("test", list.getName());
-    }
-
-    @Test(expected = IllegalArgumentException.class)
-    public void testNewInstanceNameless() {
-        new SimpleNamedFilterList(null);
-    }
-
-    @Test
-    public void testNewInstanceBackingList() {
-        new SimpleNamedFilterList("test", new ArrayList<Filter>());
-    }
-
-    @Test(expected = NullPointerException.class)
-    public void testNewInstanceNullBackingList() {
-        new SimpleNamedFilterList("test", null);
-    }
-
-    /**
-     * Exists mainly to increase code coverage as the SimpleNamedFilterList
-     * implementation is a direct pass through.
-     */
-    @Test
-    public void testListMethods() {
-        FilterChain mock = createNiceMock(FilterChain.class);
-        Filter filter = createNiceMock(Filter.class);
-
-        NamedFilterList list = new SimpleNamedFilterList("test");
-        list.add(filter);
-        FilterChain chain = list.proxy(mock);
-        assertNotNull(chain);
-        assertNotSame(mock, chain);
-
-        Filter singleFilter = new SslFilter();
-        List<? extends Filter> multipleFilters = CollectionUtils.asList(new PortFilter(), new UserFilter());
-
-        list.add(0, singleFilter);
-        assertEquals(2, list.size());
-        assertTrue(list.get(0) instanceof SslFilter);
-        assertTrue(Arrays.equals(list.toArray(), new Object[]{singleFilter, filter}));
-
-        list.addAll(multipleFilters);
-        assertEquals(4, list.size());
-        assertTrue(list.get(2) instanceof PortFilter);
-        assertTrue(list.get(3) instanceof UserFilter);
-
-        list.addAll(0, CollectionUtils.asList(new PermissionsAuthorizationFilter(), new RolesAuthorizationFilter()));
-        assertEquals(6, list.size());
-        assertTrue(list.get(0) instanceof PermissionsAuthorizationFilter);
-        assertTrue(list.get(1) instanceof RolesAuthorizationFilter);
-        assertEquals(2, list.indexOf(singleFilter));
-        assertEquals(multipleFilters, list.subList(4, list.size()));
-
-        assertTrue(list.contains(singleFilter));
-        assertTrue(list.containsAll(multipleFilters));
-
-        assertFalse(list.isEmpty());
-        list.clear();
-        assertTrue(list.isEmpty());
-
-        list.add(singleFilter);
-        Iterator i = list.iterator();
-        assertTrue(i.hasNext());
-        assertEquals(i.next(), singleFilter);
-
-        ListIterator li = list.listIterator();
-        assertTrue(li.hasNext());
-        assertEquals(li.next(), singleFilter);
-
-        li = list.listIterator(0);
-        assertTrue(li.hasNext());
-        assertEquals(li.next(), singleFilter);
-
-        list.set(0, singleFilter);
-        assertEquals(list.get(0), singleFilter);
-
-        Filter[] filters = new Filter[list.size()];
-        filters = list.toArray(filters);
-        assertEquals(1, filters.length);
-        assertEquals(filters[0], singleFilter);
-
-        assertEquals(0, list.lastIndexOf(singleFilter));
-
-        list.remove(singleFilter);
-        assertTrue(list.isEmpty());
-
-        list.add(singleFilter);
-        list.remove(0);
-        assertTrue(list.isEmpty());
-
-        list.add(singleFilter);
-        list.addAll(multipleFilters);
-        assertEquals(3, list.size());
-        list.removeAll(multipleFilters);
-        assertEquals(1, list.size());
-        assertEquals(list.get(0), singleFilter);
-
-        list.addAll(multipleFilters);
-        assertEquals(3, list.size());
-        list.retainAll(multipleFilters);
-        assertEquals(2, list.size());
-        //noinspection unchecked
-        assertEquals(new ArrayList(list), multipleFilters);
-    }
-
-
-}
+/*
+ * 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.shiro.web.filter.mgt;
+
+import org.apache.shiro.util.CollectionUtils;
+import org.apache.shiro.web.filter.authc.UserFilter;
+import org.apache.shiro.web.filter.authz.PermissionsAuthorizationFilter;
+import org.apache.shiro.web.filter.authz.PortFilter;
+import org.apache.shiro.web.filter.authz.RolesAuthorizationFilter;
+import org.apache.shiro.web.filter.authz.SslFilter;
+import org.junit.Test;
+
+import javax.servlet.Filter;
+import javax.servlet.FilterChain;
+import java.util.*;
+
+import static org.easymock.EasyMock.createNiceMock;
+import static org.junit.Assert.*;
+
+/**
+ * Test case for the {@link SimpleNamedFilterList} implementation.
+ *
+ * @since 1.0
+ */
+public class SimpleNamedFilterListTest {
+
+    @Test
+    public void testNewInstance() {
+        @SuppressWarnings({"MismatchedQueryAndUpdateOfCollection"})
+        SimpleNamedFilterList list = new SimpleNamedFilterList("test");
+        assertNotNull(list.getName());
+        assertEquals("test", list.getName());
+    }
+
+    @Test(expected = IllegalArgumentException.class)
+    public void testNewInstanceNameless() {
+        new SimpleNamedFilterList(null);
+    }
+
+    @Test
+    public void testNewInstanceBackingList() {
+        new SimpleNamedFilterList("test", new ArrayList<Filter>());
+    }
+
+    @Test(expected = NullPointerException.class)
+    public void testNewInstanceNullBackingList() {
+        new SimpleNamedFilterList("test", null);
+    }
+
+    /**
+     * Exists mainly to increase code coverage as the SimpleNamedFilterList
+     * implementation is a direct pass through.
+     */
+    @Test
+    public void testListMethods() {
+        FilterChain mock = createNiceMock(FilterChain.class);
+        Filter filter = createNiceMock(Filter.class);
+
+        NamedFilterList list = new SimpleNamedFilterList("test");
+        list.add(filter);
+        FilterChain chain = list.proxy(mock);
+        assertNotNull(chain);
+        assertNotSame(mock, chain);
+
+        Filter singleFilter = new SslFilter();
+        List<? extends Filter> multipleFilters = CollectionUtils.asList(new PortFilter(), new UserFilter());
+
+        list.add(0, singleFilter);
+        assertEquals(2, list.size());
+        assertTrue(list.get(0) instanceof SslFilter);
+        assertTrue(Arrays.equals(list.toArray(), new Object[]{singleFilter, filter}));
+
+        list.addAll(multipleFilters);
+        assertEquals(4, list.size());
+        assertTrue(list.get(2) instanceof PortFilter);
+        assertTrue(list.get(3) instanceof UserFilter);
+
+        list.addAll(0, CollectionUtils.asList(new PermissionsAuthorizationFilter(), new RolesAuthorizationFilter()));
+        assertEquals(6, list.size());
+        assertTrue(list.get(0) instanceof PermissionsAuthorizationFilter);
+        assertTrue(list.get(1) instanceof RolesAuthorizationFilter);
+        assertEquals(2, list.indexOf(singleFilter));
+        assertEquals(multipleFilters, list.subList(4, list.size()));
+
+        assertTrue(list.contains(singleFilter));
+        assertTrue(list.containsAll(multipleFilters));
+
+        assertFalse(list.isEmpty());
+        list.clear();
+        assertTrue(list.isEmpty());
+
+        list.add(singleFilter);
+        Iterator i = list.iterator();
+        assertTrue(i.hasNext());
+        assertEquals(i.next(), singleFilter);
+
+        ListIterator li = list.listIterator();
+        assertTrue(li.hasNext());
+        assertEquals(li.next(), singleFilter);
+
+        li = list.listIterator(0);
+        assertTrue(li.hasNext());
+        assertEquals(li.next(), singleFilter);
+
+        list.set(0, singleFilter);
+        assertEquals(list.get(0), singleFilter);
+
+        Filter[] filters = new Filter[list.size()];
+        filters = list.toArray(filters);
+        assertEquals(1, filters.length);
+        assertEquals(filters[0], singleFilter);
+
+        assertEquals(0, list.lastIndexOf(singleFilter));
+
+        list.remove(singleFilter);
+        assertTrue(list.isEmpty());
+
+        list.add(singleFilter);
+        list.remove(0);
+        assertTrue(list.isEmpty());
+
+        list.add(singleFilter);
+        list.addAll(multipleFilters);
+        assertEquals(3, list.size());
+        list.removeAll(multipleFilters);
+        assertEquals(1, list.size());
+        assertEquals(list.get(0), singleFilter);
+
+        list.addAll(multipleFilters);
+        assertEquals(3, list.size());
+        list.retainAll(multipleFilters);
+        assertEquals(2, list.size());
+        //noinspection unchecked
+        assertEquals(new ArrayList(list), multipleFilters);
+    }
+
+
+}

Propchange: incubator/shiro/trunk/web/src/test/java/org/apache/shiro/web/filter/mgt/SimpleNamedFilterListTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/shiro/trunk/web/src/test/java/org/apache/shiro/web/mgt/AbstractWebSecurityManagerTest.java
URL: http://svn.apache.org/viewvc/incubator/shiro/trunk/web/src/test/java/org/apache/shiro/web/mgt/AbstractWebSecurityManagerTest.java?rev=948527&r1=948526&r2=948527&view=diff
==============================================================================
--- incubator/shiro/trunk/web/src/test/java/org/apache/shiro/web/mgt/AbstractWebSecurityManagerTest.java (original)
+++ incubator/shiro/trunk/web/src/test/java/org/apache/shiro/web/mgt/AbstractWebSecurityManagerTest.java Wed May 26 18:34:28 2010
@@ -1,33 +1,33 @@
-/*
- * 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.shiro.web.mgt;
-
-import org.apache.shiro.util.ThreadContext;
-import org.junit.After;
-
-/**
- * @since 1.0
- */
-public abstract class AbstractWebSecurityManagerTest {
-
-    @After
-    public void tearDown() {
-        ThreadContext.remove();
-    }
-}
+/*
+ * 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.shiro.web.mgt;
+
+import org.apache.shiro.util.ThreadContext;
+import org.junit.After;
+
+/**
+ * @since 1.0
+ */
+public abstract class AbstractWebSecurityManagerTest {
+
+    @After
+    public void tearDown() {
+        ThreadContext.remove();
+    }
+}

Propchange: incubator/shiro/trunk/web/src/test/java/org/apache/shiro/web/mgt/AbstractWebSecurityManagerTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/shiro/trunk/web/src/test/java/org/apache/shiro/web/mgt/CookieRememberMeManagerTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/shiro/trunk/web/src/test/java/org/apache/shiro/web/mgt/DefaultWebSecurityManagerTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/shiro/trunk/web/src/test/java/org/apache/shiro/web/servlet/IniShiroFilterTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/shiro/trunk/web/src/test/java/org/apache/shiro/web/servlet/SimpleCookieTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/shiro/trunk/web/src/test/java/org/apache/shiro/web/session/mgt/DefaultWebSessionManagerTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/shiro/trunk/web/src/test/resources/IniShiroFilterTest.ini
URL: http://svn.apache.org/viewvc/incubator/shiro/trunk/web/src/test/resources/IniShiroFilterTest.ini?rev=948527&r1=948526&r2=948527&view=diff
==============================================================================
--- incubator/shiro/trunk/web/src/test/resources/IniShiroFilterTest.ini (original)
+++ incubator/shiro/trunk/web/src/test/resources/IniShiroFilterTest.ini Wed May 26 18:34:28 2010
@@ -1,21 +1,21 @@
-#
-# 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.
-#
-[filters]
-authc.successUrl = /index.jsp
-
+#
+# 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.
+#
+[filters]
+authc.successUrl = /index.jsp
+

Propchange: incubator/shiro/trunk/web/src/test/resources/IniShiroFilterTest.ini
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/shiro/trunk/web/src/test/resources/log4j.properties
URL: http://svn.apache.org/viewvc/incubator/shiro/trunk/web/src/test/resources/log4j.properties?rev=948527&r1=948526&r2=948527&view=diff
==============================================================================
--- incubator/shiro/trunk/web/src/test/resources/log4j.properties (original)
+++ incubator/shiro/trunk/web/src/test/resources/log4j.properties Wed May 26 18:34:28 2010
@@ -1,38 +1,38 @@
-#
-# 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.
-#
-log4j.rootLogger=TRACE, stdout
-
-log4j.appender.stdout=org.apache.log4j.ConsoleAppender
-log4j.appender.stdout.layout=org.apache.log4j.PatternLayout
-log4j.appender.stdout.layout.ConversionPattern=%d %p [%c] - %m %n
-
-# Pattern to output: date priority [category] - message
-log4j.appender.logfile.layout=org.apache.log4j.PatternLayout
-log4j.appender.logfile.layout.ConversionPattern=%d %p [%c] - %m%n
-
-# Spring logging level is WARN
-log4j.logger.org.springframework=WARN
-
-# General Apache libraries is WARN
-log4j.logger.org.apache=WARN
-
-log4j.logger.net.sf.ehcache=WARN
-
-log4j.logger.org.apache.shiro=TRACE
+#
+# 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.
+#
+log4j.rootLogger=TRACE, stdout
+
+log4j.appender.stdout=org.apache.log4j.ConsoleAppender
+log4j.appender.stdout.layout=org.apache.log4j.PatternLayout
+log4j.appender.stdout.layout.ConversionPattern=%d %p [%c] - %m %n
+
+# Pattern to output: date priority [category] - message
+log4j.appender.logfile.layout=org.apache.log4j.PatternLayout
+log4j.appender.logfile.layout.ConversionPattern=%d %p [%c] - %m%n
+
+# Spring logging level is WARN
+log4j.logger.org.springframework=WARN
+
+# General Apache libraries is WARN
+log4j.logger.org.apache=WARN
+
+log4j.logger.net.sf.ehcache=WARN
+
+log4j.logger.org.apache.shiro=TRACE
 log4j.logger.org.apache.shiro.util.ThreadContext=WARN
\ No newline at end of file

Propchange: incubator/shiro/trunk/web/src/test/resources/log4j.properties
------------------------------------------------------------------------------
    svn:eol-style = native