You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@accumulo.apache.org by kt...@apache.org on 2011/10/18 19:51:11 UTC

svn commit: r1185770 [7/17] - in /incubator/accumulo/branches/1.3: ./ bin/ conf/ docs/ docs/src/developer_manual/ docs/src/user_manual/ docs/src/user_manual/appendices/ docs/src/user_manual/chapters/ src/assemble/ src/core/ src/core/src/main/java/org/a...

Modified: incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/zookeeper/ZooLock.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/zookeeper/ZooLock.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/zookeeper/ZooLock.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/zookeeper/ZooLock.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.zookeeper;
 
 import java.util.ArrayList;

Modified: incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/zookeeper/ZooSession.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/zookeeper/ZooSession.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/zookeeper/ZooSession.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/zookeeper/ZooSession.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.zookeeper;
 
 import java.io.IOException;

Modified: incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/zookeeper/ZooUtil.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/zookeeper/ZooUtil.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/zookeeper/ZooUtil.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/zookeeper/ZooUtil.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.zookeeper;
 
 import org.apache.accumulo.core.Constants;

Modified: incubator/accumulo/branches/1.3/src/core/src/main/thrift/client.thrift
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/main/thrift/client.thrift?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/main/thrift/client.thrift (original)
+++ incubator/accumulo/branches/1.3/src/core/src/main/thrift/client.thrift Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 namespace java org.apache.accumulo.core.client.impl.thrift
 
 include "security.thrift"

Modified: incubator/accumulo/branches/1.3/src/core/src/main/thrift/data.thrift
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/main/thrift/data.thrift?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/main/thrift/data.thrift (original)
+++ incubator/accumulo/branches/1.3/src/core/src/main/thrift/data.thrift Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 namespace java org.apache.accumulo.core.data.thrift
 
 typedef i64 ScanID

Modified: incubator/accumulo/branches/1.3/src/core/src/main/thrift/gc.thrift
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/main/thrift/gc.thrift?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/main/thrift/gc.thrift (original)
+++ incubator/accumulo/branches/1.3/src/core/src/main/thrift/gc.thrift Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 namespace java org.apache.accumulo.core.gc.thrift
 
 include "security.thrift"

Modified: incubator/accumulo/branches/1.3/src/core/src/main/thrift/master.thrift
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/main/thrift/master.thrift?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/main/thrift/master.thrift (original)
+++ incubator/accumulo/branches/1.3/src/core/src/main/thrift/master.thrift Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 namespace java org.apache.accumulo.core.master.thrift
 
 include "data.thrift"

Modified: incubator/accumulo/branches/1.3/src/core/src/main/thrift/security.thrift
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/main/thrift/security.thrift?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/main/thrift/security.thrift (original)
+++ incubator/accumulo/branches/1.3/src/core/src/main/thrift/security.thrift Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 namespace java org.apache.accumulo.core.security.thrift
 
 enum SecurityErrorCode {

Modified: incubator/accumulo/branches/1.3/src/core/src/main/thrift/tabletserver.thrift
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/main/thrift/tabletserver.thrift?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/main/thrift/tabletserver.thrift (original)
+++ incubator/accumulo/branches/1.3/src/core/src/main/thrift/tabletserver.thrift Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 namespace java org.apache.accumulo.core.tabletserver.thrift
 
 include "data.thrift"

Modified: incubator/accumulo/branches/1.3/src/core/src/main/thrift/thrift.sh
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/main/thrift/thrift.sh?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/main/thrift/thrift.sh (original)
+++ incubator/accumulo/branches/1.3/src/core/src/main/thrift/thrift.sh Tue Oct 18 17:50:01 2011
@@ -1,5 +1,21 @@
 #! /usr/bin/env bash
 
+# 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.
+
+
 # test to see if we have thrift installed
 VERSION=`thrift -version 2>/dev/null | grep "0.3" |	wc -l`
 if [ "$VERSION" -ne 1 ] ; then 

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/client/RangeTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/client/RangeTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/client/RangeTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/client/RangeTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.client;
 
 import java.util.Arrays;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/client/impl/TabletLocatorImplTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/client/impl/TabletLocatorImplTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/client/impl/TabletLocatorImplTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/client/impl/TabletLocatorImplTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.client.impl;
 
 import java.util.ArrayList;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/client/mapreduce/AccumuloInputFormatTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/client/mapreduce/AccumuloInputFormatTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/client/mapreduce/AccumuloInputFormatTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/client/mapreduce/AccumuloInputFormatTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.client.mapreduce;
 
 import static org.junit.Assert.assertEquals;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/client/mapreduce/lib/partition/RangePartitionerTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/client/mapreduce/lib/partition/RangePartitionerTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/client/mapreduce/lib/partition/RangePartitionerTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/client/mapreduce/lib/partition/RangePartitionerTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.client.mapreduce.lib.partition;
 
 import static org.junit.Assert.assertTrue;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/client/mock/MockConnectorTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/client/mock/MockConnectorTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/client/mock/MockConnectorTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/client/mock/MockConnectorTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.client.mock;
 
 import static junit.framework.Assert.assertEquals;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/conf/PropertyTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/conf/PropertyTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/conf/PropertyTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/conf/PropertyTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.conf;
 
 import static org.junit.Assert.assertFalse;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/data/ColumnTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/data/ColumnTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/data/ColumnTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/data/ColumnTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.data;
 
 import org.apache.accumulo.core.data.Column;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/data/KeyExtentTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/data/KeyExtentTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/data/KeyExtentTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/data/KeyExtentTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.data;
 
 import java.util.SortedMap;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/data/KeyTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/data/KeyTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/data/KeyTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/data/KeyTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.data;
 
 import org.apache.accumulo.core.data.Key;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/data/MapFileTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/data/MapFileTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/data/MapFileTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/data/MapFileTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.data;
 
 import java.io.IOException;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/data/MutationTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/data/MutationTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/data/MutationTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/data/MutationTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.data;
 
 import java.io.ByteArrayInputStream;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/file/rfile/RFileTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/file/rfile/RFileTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/file/rfile/RFileTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/file/rfile/RFileTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.file.rfile;
 
 import java.io.ByteArrayInputStream;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/AggregatingIteratorTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/AggregatingIteratorTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/AggregatingIteratorTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/AggregatingIteratorTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.iterators;
 
 import java.io.IOException;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/ColumnFamilySkippingIteratorTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/ColumnFamilySkippingIteratorTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/ColumnFamilySkippingIteratorTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/ColumnFamilySkippingIteratorTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.iterators;
 
 import java.util.Collection;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/DeletingIteratorTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/DeletingIteratorTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/DeletingIteratorTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/DeletingIteratorTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.iterators;
 
 import java.io.IOException;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/FamilyIntersectingIteratorTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/FamilyIntersectingIteratorTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/FamilyIntersectingIteratorTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/FamilyIntersectingIteratorTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.iterators;
 
 import java.io.IOException;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/FilteringIteratorTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/FilteringIteratorTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/FilteringIteratorTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/FilteringIteratorTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.iterators;
 
 import java.io.IOException;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/IntersectingIteratorTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/IntersectingIteratorTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/IntersectingIteratorTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/IntersectingIteratorTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.iterators;
 
 import java.io.IOException;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/IterUtilTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/IterUtilTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/IterUtilTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/IterUtilTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.iterators;
 
 import java.io.IOException;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/LargeRowFilterTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/LargeRowFilterTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/LargeRowFilterTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/LargeRowFilterTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.iterators;
 
 import java.io.IOException;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/MultiIteratorTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/MultiIteratorTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/MultiIteratorTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/MultiIteratorTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.iterators;
 
 import java.io.IOException;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/RegExIteratorTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/RegExIteratorTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/RegExIteratorTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/RegExIteratorTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.iterators;
 
 import java.io.IOException;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/RowDeletingIteratorTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/RowDeletingIteratorTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/RowDeletingIteratorTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/RowDeletingIteratorTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.iterators;
 
 import java.io.IOException;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/SourceSwitchingIteratorTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/SourceSwitchingIteratorTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/SourceSwitchingIteratorTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/SourceSwitchingIteratorTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.iterators;
 
 import java.util.ArrayList;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/VersioningIteratorTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/VersioningIteratorTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/VersioningIteratorTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/VersioningIteratorTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.iterators;
 
 import java.io.IOException;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/WholeRowIteratorTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/WholeRowIteratorTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/WholeRowIteratorTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/WholeRowIteratorTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.iterators;
 
 import java.io.IOException;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/aggregation/NumSummationTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/aggregation/NumSummationTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/aggregation/NumSummationTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/aggregation/NumSummationTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.iterators.aggregation;
 
 import org.apache.accumulo.core.data.Value;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfigurationTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfigurationTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfigurationTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfigurationTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.iterators.aggregation.conf;
 
 import junit.framework.TestCase;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/filter/ColumnFilterTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/filter/ColumnFilterTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/filter/ColumnFilterTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/iterators/filter/ColumnFilterTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.iterators.filter;
 
 import java.util.HashSet;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/security/AuthorizationsTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/security/AuthorizationsTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/security/AuthorizationsTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/security/AuthorizationsTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.security;
 
 import static org.junit.Assert.*;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/security/VisibilityEvaluatorTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/security/VisibilityEvaluatorTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/security/VisibilityEvaluatorTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/security/VisibilityEvaluatorTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.security;
 
 import static org.junit.Assert.assertFalse;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/util/AddressUtilTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/util/AddressUtilTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/util/AddressUtilTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/util/AddressUtilTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.util;
 
 import java.net.InetSocketAddress;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/util/EscapeTokenizerTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/util/EscapeTokenizerTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/util/EscapeTokenizerTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/util/EscapeTokenizerTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.util;
 
 import java.util.Iterator;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/util/LocalityGroupUtilTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/util/LocalityGroupUtilTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/util/LocalityGroupUtilTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/util/LocalityGroupUtilTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.util;
 
 import java.util.HashSet;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/util/MetadataTableTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/util/MetadataTableTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/util/MetadataTableTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/util/MetadataTableTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.util;
 
 import java.util.SortedSet;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/util/TestStringUtil.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/util/TestStringUtil.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/util/TestStringUtil.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/util/TestStringUtil.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.util;
 
 import static org.junit.Assert.*;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/util/TestVersion.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/util/TestVersion.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/util/TestVersion.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/util/TestVersion.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.util;
 
 import org.apache.accumulo.core.util.Version;

Modified: incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/util/TextUtilTest.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/util/TextUtilTest.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/util/TextUtilTest.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/test/java/org/apache/accumulo/core/util/TextUtilTest.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.core.util;
 
 import junit.framework.TestCase;

Modified: incubator/accumulo/branches/1.3/src/examples/pom.xml
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/examples/pom.xml?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/examples/pom.xml (original)
+++ incubator/accumulo/branches/1.3/src/examples/pom.xml Tue Oct 18 17:50:01 2011
@@ -1,4 +1,20 @@
 <?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.
+-->
 <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">

Modified: incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/aggregation/SortedSetAggregator.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/aggregation/SortedSetAggregator.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/aggregation/SortedSetAggregator.java (original)
+++ incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/aggregation/SortedSetAggregator.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.examples.aggregation;
 
 import java.util.TreeSet;

Modified: incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/client/Flush.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/client/Flush.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/client/Flush.java (original)
+++ incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/client/Flush.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.examples.client;
 
 import org.apache.accumulo.core.client.Connector;

Modified: incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/client/RandomBatchScanner.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/client/RandomBatchScanner.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/client/RandomBatchScanner.java (original)
+++ incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/client/RandomBatchScanner.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.examples.client;
 
 import java.util.Arrays;

Modified: incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/client/RandomBatchWriter.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/client/RandomBatchWriter.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/client/RandomBatchWriter.java (original)
+++ incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/client/RandomBatchWriter.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.examples.client;
 
 import java.util.HashSet;

Modified: incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/client/ReadWriteExample.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/client/ReadWriteExample.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/client/ReadWriteExample.java (original)
+++ incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/client/ReadWriteExample.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.examples.client;
 
 import java.util.Map.Entry;

Modified: incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/client/RowOperations.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/client/RowOperations.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/client/RowOperations.java (original)
+++ incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/client/RowOperations.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.examples.client;
 
 import java.io.IOException;

Modified: incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/client/SequentialBatchWriter.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/client/SequentialBatchWriter.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/client/SequentialBatchWriter.java (original)
+++ incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/client/SequentialBatchWriter.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.examples.client;
 
 import org.apache.accumulo.core.client.AccumuloException;

Modified: incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/constraints/AlphaNumKeyConstraint.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/constraints/AlphaNumKeyConstraint.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/constraints/AlphaNumKeyConstraint.java (original)
+++ incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/constraints/AlphaNumKeyConstraint.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.examples.constraints;
 
 import java.util.ArrayList;

Modified: incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/constraints/NumericValueConstraint.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/constraints/NumericValueConstraint.java?rev=1185770&r1=1185769&r2=1185770&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/constraints/NumericValueConstraint.java (original)
+++ incubator/accumulo/branches/1.3/src/examples/src/main/java/org/apache/accumulo/examples/constraints/NumericValueConstraint.java Tue Oct 18 17:50:01 2011
@@ -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.
+*/
 package org.apache.accumulo.examples.constraints;
 
 import java.util.ArrayList;