You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@mina.apache.org by el...@apache.org on 2008/06/03 23:29:33 UTC

svn commit: r662897 - in /mina/trunk: core/src/main/java/org/apache/mina/common/ core/src/main/java/org/apache/mina/filter/codec/prefixedstring/ core/src/main/java/org/apache/mina/filter/stream/ core/src/main/java/org/apache/mina/transport/socket/ core...

Author: elecharny
Date: Tue Jun  3 14:29:32 2008
New Revision: 662897

URL: http://svn.apache.org/viewvc?rev=662897&view=rev
Log:
Added the missing ASL 2.0 headers

Modified:
    mina/trunk/core/src/main/java/org/apache/mina/common/CompositeIoFuture.java
    mina/trunk/core/src/main/java/org/apache/mina/common/DefaultFileRegion.java
    mina/trunk/core/src/main/java/org/apache/mina/common/FileRegion.java
    mina/trunk/core/src/main/java/org/apache/mina/filter/codec/prefixedstring/PrefixedStringCodecFactory.java
    mina/trunk/core/src/main/java/org/apache/mina/filter/codec/prefixedstring/PrefixedStringDecoder.java
    mina/trunk/core/src/main/java/org/apache/mina/filter/codec/prefixedstring/PrefixedStringEncoder.java
    mina/trunk/core/src/main/java/org/apache/mina/filter/stream/FileRegionWriteFilter.java
    mina/trunk/core/src/main/java/org/apache/mina/transport/socket/DatagramSession.java
    mina/trunk/core/src/main/java/org/apache/mina/transport/socket/SocketSession.java
    mina/trunk/core/src/main/java/org/apache/mina/transport/socket/nio/NioDatagramSessionConfig.java
    mina/trunk/core/src/main/java/org/apache/mina/util/Log4jXmlFormatter.java
    mina/trunk/core/src/main/java/org/apache/mina/util/Transform.java
    mina/trunk/core/src/test/java/org/apache/mina/filter/util/WrappingFilterTest.java
    mina/trunk/core/src/test/java/org/apache/mina/transport/AbstractFileRegionTest.java
    mina/trunk/core/src/test/java/org/apache/mina/transport/socket/nio/NioFileRegionTest.java
    mina/trunk/core/src/test/resources/log4j.properties
    mina/trunk/example/src/main/java/org/apache/mina/example/chat/client/ConnectDialog.java
    mina/trunk/example/src/main/java/org/apache/mina/example/gettingstarted/timeserver/MinaTimeServer.java
    mina/trunk/example/src/main/java/org/apache/mina/example/gettingstarted/timeserver/TimeServerHandler.java
    mina/trunk/example/src/main/resources/log4j.properties
    mina/trunk/example/src/main/resources/org/apache/mina/example/chat/serverContext.xml

Modified: mina/trunk/core/src/main/java/org/apache/mina/common/CompositeIoFuture.java
URL: http://svn.apache.org/viewvc/mina/trunk/core/src/main/java/org/apache/mina/common/CompositeIoFuture.java?rev=662897&r1=662896&r2=662897&view=diff
==============================================================================
--- mina/trunk/core/src/main/java/org/apache/mina/common/CompositeIoFuture.java (original)
+++ mina/trunk/core/src/main/java/org/apache/mina/common/CompositeIoFuture.java Tue Jun  3 14:29:32 2008
@@ -1,3 +1,22 @@
+/*
+ *  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.mina.common;
 
 import java.util.concurrent.atomic.AtomicInteger;

Modified: mina/trunk/core/src/main/java/org/apache/mina/common/DefaultFileRegion.java
URL: http://svn.apache.org/viewvc/mina/trunk/core/src/main/java/org/apache/mina/common/DefaultFileRegion.java?rev=662897&r1=662896&r2=662897&view=diff
==============================================================================
--- mina/trunk/core/src/main/java/org/apache/mina/common/DefaultFileRegion.java (original)
+++ mina/trunk/core/src/main/java/org/apache/mina/common/DefaultFileRegion.java Tue Jun  3 14:29:32 2008
@@ -1,3 +1,22 @@
+/*
+ *  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.mina.common;
 
 import java.io.IOException;

Modified: mina/trunk/core/src/main/java/org/apache/mina/common/FileRegion.java
URL: http://svn.apache.org/viewvc/mina/trunk/core/src/main/java/org/apache/mina/common/FileRegion.java?rev=662897&r1=662896&r2=662897&view=diff
==============================================================================
--- mina/trunk/core/src/main/java/org/apache/mina/common/FileRegion.java (original)
+++ mina/trunk/core/src/main/java/org/apache/mina/common/FileRegion.java Tue Jun  3 14:29:32 2008
@@ -1,3 +1,22 @@
+/*
+ *  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.mina.common;
 
 import java.nio.channels.FileChannel;

Modified: mina/trunk/core/src/main/java/org/apache/mina/filter/codec/prefixedstring/PrefixedStringCodecFactory.java
URL: http://svn.apache.org/viewvc/mina/trunk/core/src/main/java/org/apache/mina/filter/codec/prefixedstring/PrefixedStringCodecFactory.java?rev=662897&r1=662896&r2=662897&view=diff
==============================================================================
--- mina/trunk/core/src/main/java/org/apache/mina/filter/codec/prefixedstring/PrefixedStringCodecFactory.java (original)
+++ mina/trunk/core/src/main/java/org/apache/mina/filter/codec/prefixedstring/PrefixedStringCodecFactory.java Tue Jun  3 14:29:32 2008
@@ -1,3 +1,22 @@
+/*
+ *  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.mina.filter.codec.prefixedstring;
 
 import org.apache.mina.common.IoSession;

Modified: mina/trunk/core/src/main/java/org/apache/mina/filter/codec/prefixedstring/PrefixedStringDecoder.java
URL: http://svn.apache.org/viewvc/mina/trunk/core/src/main/java/org/apache/mina/filter/codec/prefixedstring/PrefixedStringDecoder.java?rev=662897&r1=662896&r2=662897&view=diff
==============================================================================
--- mina/trunk/core/src/main/java/org/apache/mina/filter/codec/prefixedstring/PrefixedStringDecoder.java (original)
+++ mina/trunk/core/src/main/java/org/apache/mina/filter/codec/prefixedstring/PrefixedStringDecoder.java Tue Jun  3 14:29:32 2008
@@ -1,3 +1,22 @@
+/*
+ *  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.mina.filter.codec.prefixedstring;
 
 import org.apache.mina.common.IoBuffer;

Modified: mina/trunk/core/src/main/java/org/apache/mina/filter/codec/prefixedstring/PrefixedStringEncoder.java
URL: http://svn.apache.org/viewvc/mina/trunk/core/src/main/java/org/apache/mina/filter/codec/prefixedstring/PrefixedStringEncoder.java?rev=662897&r1=662896&r2=662897&view=diff
==============================================================================
--- mina/trunk/core/src/main/java/org/apache/mina/filter/codec/prefixedstring/PrefixedStringEncoder.java (original)
+++ mina/trunk/core/src/main/java/org/apache/mina/filter/codec/prefixedstring/PrefixedStringEncoder.java Tue Jun  3 14:29:32 2008
@@ -1,3 +1,22 @@
+/*
+ *  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.mina.filter.codec.prefixedstring;
 
 import org.apache.mina.common.IoBuffer;

Modified: mina/trunk/core/src/main/java/org/apache/mina/filter/stream/FileRegionWriteFilter.java
URL: http://svn.apache.org/viewvc/mina/trunk/core/src/main/java/org/apache/mina/filter/stream/FileRegionWriteFilter.java?rev=662897&r1=662896&r2=662897&view=diff
==============================================================================
--- mina/trunk/core/src/main/java/org/apache/mina/filter/stream/FileRegionWriteFilter.java (original)
+++ mina/trunk/core/src/main/java/org/apache/mina/filter/stream/FileRegionWriteFilter.java Tue Jun  3 14:29:32 2008
@@ -1,3 +1,22 @@
+/*
+ *  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.mina.filter.stream;
 
 import java.io.IOException;

Modified: mina/trunk/core/src/main/java/org/apache/mina/transport/socket/DatagramSession.java
URL: http://svn.apache.org/viewvc/mina/trunk/core/src/main/java/org/apache/mina/transport/socket/DatagramSession.java?rev=662897&r1=662896&r2=662897&view=diff
==============================================================================
--- mina/trunk/core/src/main/java/org/apache/mina/transport/socket/DatagramSession.java (original)
+++ mina/trunk/core/src/main/java/org/apache/mina/transport/socket/DatagramSession.java Tue Jun  3 14:29:32 2008
@@ -1,3 +1,22 @@
+/*
+ *  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.mina.transport.socket;
 
 import java.net.InetSocketAddress;

Modified: mina/trunk/core/src/main/java/org/apache/mina/transport/socket/SocketSession.java
URL: http://svn.apache.org/viewvc/mina/trunk/core/src/main/java/org/apache/mina/transport/socket/SocketSession.java?rev=662897&r1=662896&r2=662897&view=diff
==============================================================================
--- mina/trunk/core/src/main/java/org/apache/mina/transport/socket/SocketSession.java (original)
+++ mina/trunk/core/src/main/java/org/apache/mina/transport/socket/SocketSession.java Tue Jun  3 14:29:32 2008
@@ -1,3 +1,22 @@
+/*
+ *  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.mina.transport.socket;
 
 import java.net.InetSocketAddress;

Modified: mina/trunk/core/src/main/java/org/apache/mina/transport/socket/nio/NioDatagramSessionConfig.java
URL: http://svn.apache.org/viewvc/mina/trunk/core/src/main/java/org/apache/mina/transport/socket/nio/NioDatagramSessionConfig.java?rev=662897&r1=662896&r2=662897&view=diff
==============================================================================
--- mina/trunk/core/src/main/java/org/apache/mina/transport/socket/nio/NioDatagramSessionConfig.java (original)
+++ mina/trunk/core/src/main/java/org/apache/mina/transport/socket/nio/NioDatagramSessionConfig.java Tue Jun  3 14:29:32 2008
@@ -1,5 +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.
+ *
  */
 package org.apache.mina.transport.socket.nio;
 

Modified: mina/trunk/core/src/main/java/org/apache/mina/util/Log4jXmlFormatter.java
URL: http://svn.apache.org/viewvc/mina/trunk/core/src/main/java/org/apache/mina/util/Log4jXmlFormatter.java?rev=662897&r1=662896&r2=662897&view=diff
==============================================================================
--- mina/trunk/core/src/main/java/org/apache/mina/util/Log4jXmlFormatter.java (original)
+++ mina/trunk/core/src/main/java/org/apache/mina/util/Log4jXmlFormatter.java Tue Jun  3 14:29:32 2008
@@ -1,3 +1,22 @@
+/*
+ *  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.mina.util;
 
 import org.slf4j.MDC;

Modified: mina/trunk/core/src/main/java/org/apache/mina/util/Transform.java
URL: http://svn.apache.org/viewvc/mina/trunk/core/src/main/java/org/apache/mina/util/Transform.java?rev=662897&r1=662896&r2=662897&view=diff
==============================================================================
--- mina/trunk/core/src/main/java/org/apache/mina/util/Transform.java (original)
+++ mina/trunk/core/src/main/java/org/apache/mina/util/Transform.java Tue Jun  3 14:29:32 2008
@@ -1,3 +1,22 @@
+/*
+ *  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.mina.util;
 
 import java.io.IOException;

Modified: mina/trunk/core/src/test/java/org/apache/mina/filter/util/WrappingFilterTest.java
URL: http://svn.apache.org/viewvc/mina/trunk/core/src/test/java/org/apache/mina/filter/util/WrappingFilterTest.java?rev=662897&r1=662896&r2=662897&view=diff
==============================================================================
--- mina/trunk/core/src/test/java/org/apache/mina/filter/util/WrappingFilterTest.java (original)
+++ mina/trunk/core/src/test/java/org/apache/mina/filter/util/WrappingFilterTest.java Tue Jun  3 14:29:32 2008
@@ -1,3 +1,22 @@
+/*
+ *  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.mina.filter.util;
 
 import java.util.ArrayList;

Modified: mina/trunk/core/src/test/java/org/apache/mina/transport/AbstractFileRegionTest.java
URL: http://svn.apache.org/viewvc/mina/trunk/core/src/test/java/org/apache/mina/transport/AbstractFileRegionTest.java?rev=662897&r1=662896&r2=662897&view=diff
==============================================================================
--- mina/trunk/core/src/test/java/org/apache/mina/transport/AbstractFileRegionTest.java (original)
+++ mina/trunk/core/src/test/java/org/apache/mina/transport/AbstractFileRegionTest.java Tue Jun  3 14:29:32 2008
@@ -1,3 +1,22 @@
+/*
+ *  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.mina.transport;
 
 import java.io.File;

Modified: mina/trunk/core/src/test/java/org/apache/mina/transport/socket/nio/NioFileRegionTest.java
URL: http://svn.apache.org/viewvc/mina/trunk/core/src/test/java/org/apache/mina/transport/socket/nio/NioFileRegionTest.java?rev=662897&r1=662896&r2=662897&view=diff
==============================================================================
--- mina/trunk/core/src/test/java/org/apache/mina/transport/socket/nio/NioFileRegionTest.java (original)
+++ mina/trunk/core/src/test/java/org/apache/mina/transport/socket/nio/NioFileRegionTest.java Tue Jun  3 14:29:32 2008
@@ -1,3 +1,22 @@
+/*
+ *  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.mina.transport.socket.nio;
 
 import org.apache.mina.common.IoAcceptor;

Modified: mina/trunk/core/src/test/resources/log4j.properties
URL: http://svn.apache.org/viewvc/mina/trunk/core/src/test/resources/log4j.properties?rev=662897&r1=662896&r2=662897&view=diff
==============================================================================
--- mina/trunk/core/src/test/resources/log4j.properties (original)
+++ mina/trunk/core/src/test/resources/log4j.properties Tue Jun  3 14:29:32 2008
@@ -1,3 +1,19 @@
+#############################################################################
+#    Licensed to the Apache Software Foundation (ASF) under one or more
+#    contributor license agreements.  See the NOTICE file distributed with
+#    this work for additional information regarding copyright ownership.
+#    The ASF licenses this file to You under the Apache License, Version 2.0
+#    (the "License"); you may not use this file except in compliance with
+#    the License.  You may obtain a copy of the License at
+#
+#       http://www.apache.org/licenses/LICENSE-2.0
+#
+#    Unless required by applicable law or agreed to in writing, software
+#    distributed under the License is distributed on an "AS IS" BASIS,
+#    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+#    See the License for the specific language governing permissions and
+#    limitations under the License.
+#############################################################################
 # Please don't modify the log level until we reach to acceptable test coverage.
 # It's very useful when I test examples manually.
 log4j.rootCategory=INFO, stdout

Modified: mina/trunk/example/src/main/java/org/apache/mina/example/chat/client/ConnectDialog.java
URL: http://svn.apache.org/viewvc/mina/trunk/example/src/main/java/org/apache/mina/example/chat/client/ConnectDialog.java?rev=662897&r1=662896&r2=662897&view=diff
==============================================================================
--- mina/trunk/example/src/main/java/org/apache/mina/example/chat/client/ConnectDialog.java (original)
+++ mina/trunk/example/src/main/java/org/apache/mina/example/chat/client/ConnectDialog.java Tue Jun  3 14:29:32 2008
@@ -1,19 +1,20 @@
 /*
- *   @(#) $Id$
- *
- *   Copyright 2006 The Apache Software Foundation
- *
- *   Licensed under the Apache License, Version 2.0 (the "License");
- *   you may not use this file except in compliance with the License.
- *   You may obtain a copy of the License at
- *
- *       http://www.apache.org/licenses/LICENSE-2.0
- *
- *   Unless required by applicable law or agreed to in writing, software
- *   distributed under the License is distributed on an "AS IS" BASIS,
- *   WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- *   See the License for the specific language governing permissions and
- *   limitations under the License.
+ *   Licensed to the Apache Software Foundation (ASF) under one
+ *   or more contributor license agreements.  See the NOTICE file
+ *   distributed with this work for additional information
+ *   regarding copyright ownership.  The ASF licenses this file
+ *   to you under the Apache License, Version 2.0 (the
+ *   "License"); you may not use this file except in compliance
+ *   with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ *   Unless required by applicable law or agreed to in writing,
+ *   software distributed under the License is distributed on an
+ *   "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ *   KIND, either express or implied.  See the License for the
+ *   specific language governing permissions and limitations
+ *   under the License.
  *
  */
 package org.apache.mina.example.chat.client;

Modified: mina/trunk/example/src/main/java/org/apache/mina/example/gettingstarted/timeserver/MinaTimeServer.java
URL: http://svn.apache.org/viewvc/mina/trunk/example/src/main/java/org/apache/mina/example/gettingstarted/timeserver/MinaTimeServer.java?rev=662897&r1=662896&r2=662897&view=diff
==============================================================================
--- mina/trunk/example/src/main/java/org/apache/mina/example/gettingstarted/timeserver/MinaTimeServer.java (original)
+++ mina/trunk/example/src/main/java/org/apache/mina/example/gettingstarted/timeserver/MinaTimeServer.java Tue Jun  3 14:29:32 2008
@@ -1,3 +1,22 @@
+/*
+ *   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.mina.example.gettingstarted.timeserver;
 
 import java.io.IOException;

Modified: mina/trunk/example/src/main/java/org/apache/mina/example/gettingstarted/timeserver/TimeServerHandler.java
URL: http://svn.apache.org/viewvc/mina/trunk/example/src/main/java/org/apache/mina/example/gettingstarted/timeserver/TimeServerHandler.java?rev=662897&r1=662896&r2=662897&view=diff
==============================================================================
--- mina/trunk/example/src/main/java/org/apache/mina/example/gettingstarted/timeserver/TimeServerHandler.java (original)
+++ mina/trunk/example/src/main/java/org/apache/mina/example/gettingstarted/timeserver/TimeServerHandler.java Tue Jun  3 14:29:32 2008
@@ -1,3 +1,22 @@
+/*
+ *   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.mina.example.gettingstarted.timeserver;
 
 import java.util.Date;

Modified: mina/trunk/example/src/main/resources/log4j.properties
URL: http://svn.apache.org/viewvc/mina/trunk/example/src/main/resources/log4j.properties?rev=662897&r1=662896&r2=662897&view=diff
==============================================================================
--- mina/trunk/example/src/main/resources/log4j.properties (original)
+++ mina/trunk/example/src/main/resources/log4j.properties Tue Jun  3 14:29:32 2008
@@ -1,3 +1,19 @@
+#############################################################################
+#    Licensed to the Apache Software Foundation (ASF) under one or more
+#    contributor license agreements.  See the NOTICE file distributed with
+#    this work for additional information regarding copyright ownership.
+#    The ASF licenses this file to You under the Apache License, Version 2.0
+#    (the "License"); you may not use this file except in compliance with
+#    the License.  You may obtain a copy of the License at
+#
+#       http://www.apache.org/licenses/LICENSE-2.0
+#
+#    Unless required by applicable law or agreed to in writing, software
+#    distributed under the License is distributed on an "AS IS" BASIS,
+#    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+#    See the License for the specific language governing permissions and
+#    limitations under the License.
+#############################################################################
 # Please don't modify the log level until we reach to acceptable test coverage.
 # It's very useful when I test examples manually.
 log4j.rootCategory=INFO, stdout

Modified: mina/trunk/example/src/main/resources/org/apache/mina/example/chat/serverContext.xml
URL: http://svn.apache.org/viewvc/mina/trunk/example/src/main/resources/org/apache/mina/example/chat/serverContext.xml?rev=662897&r1=662896&r2=662897&view=diff
==============================================================================
--- mina/trunk/example/src/main/resources/org/apache/mina/example/chat/serverContext.xml (original)
+++ mina/trunk/example/src/main/resources/org/apache/mina/example/chat/serverContext.xml Tue Jun  3 14:29:32 2008
@@ -1,5 +1,25 @@
 <?xml version="1.0" encoding="UTF-8"?>
 <!DOCTYPE beans PUBLIC "-//SPRING//DTD BEAN//EN" "http://www.springframework.org/dtd/spring-beans.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.
+-->
+
 <beans>
 
   <!-- This makes it possible to specify java.net.SocketAddress values