You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@rya.apache.org by mi...@apache.org on 2015/12/22 17:49:26 UTC

[02/56] [abbrv] incubator-rya git commit: RYA-7 POM and License Clean-up for Apache Move

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/utils/cloudbase.utils/src/main/java/mvm/rya/cloudbase/utils/scanner/RangesScanner.java
----------------------------------------------------------------------
diff --git a/utils/cloudbase.utils/src/main/java/mvm/rya/cloudbase/utils/scanner/RangesScanner.java b/utils/cloudbase.utils/src/main/java/mvm/rya/cloudbase/utils/scanner/RangesScanner.java
deleted file mode 100644
index 9de3893..0000000
--- a/utils/cloudbase.utils/src/main/java/mvm/rya/cloudbase/utils/scanner/RangesScanner.java
+++ /dev/null
@@ -1,236 +0,0 @@
-package mvm.rya.cloudbase.utils.scanner;
-
-import cloudbase.core.client.BatchScanner;
-import cloudbase.core.client.Connector;
-import cloudbase.core.client.Scanner;
-import cloudbase.core.data.Key;
-import cloudbase.core.data.Range;
-import cloudbase.core.data.Value;
-import cloudbase.core.security.Authorizations;
-import com.google.common.collect.Iterators;
-import org.apache.hadoop.io.Text;
-
-import java.io.IOException;
-import java.util.*;
-
-/**
- * This class will decorate a List of Scanners and treat it as one BatchScanner.
- * Each Scanner in the List corresponds to a separate Range.
- * The reason we are doing this and not just using BatchScanner is because,
- * the Scanner class will return information sorted and is more performant on
- * larger amounts of data.
- */
-public class RangesScanner implements BatchScanner, Scanner {
-
-    private List<Scanner> scanners = new ArrayList<Scanner>();
-    private Connector connector;
-    private String table;
-    private Authorizations authorizations;
-
-    public RangesScanner(Connector connector, String table, Authorizations authorizations) {
-        this.connector = connector;
-        this.table = table;
-        this.authorizations = authorizations;
-    }
-
-    @Override
-    public void setRanges(Collection<Range> ranges) {
-        try {
-            scanners.clear(); //no need to close them since Scanners do their own cleanup
-            for (Range range : ranges) {
-                Scanner scanner = connector.createScanner(table, authorizations);
-                scanner.setRange(range);
-            }
-        } catch (Exception e) {
-            throw new RuntimeException(e); //TODO: Better exception handling
-        }
-    }
-
-    @Override
-    public void setTimeOut(int i) {
-        if(scanners.size() == 0) {
-            throw new IllegalArgumentException("Set Ranges first to initalize underneath scanners"); //TODO: if we save this info we don't need this check
-        }
-        for(Scanner scanner: scanners) {
-            scanner.setTimeOut(i);
-        }
-    }
-
-    @Override
-    public int getTimeOut() {
-        return 0;
-    }
-
-    @Override
-    public void setRange(Range range) {
-        //TODO: How to set only one range
-    }
-
-    @Override
-    public Range getRange() {
-        return null; //TODO: How to get only one range
-    }
-
-    @Override
-    public void setBatchSize(int i) {
-        if(scanners.size() == 0) {
-            throw new IllegalArgumentException("Set Ranges first to initalize underneath scanners"); //TODO: if we save this info we don't need this check
-        }
-        for(Scanner scanner: scanners) {
-            scanner.setBatchSize(i);
-        }
-    }
-
-    @Override
-    public int getBatchSize() {
-        return 0; //TODO: What does this mean with multiple scanners?
-    }
-
-    @Override
-    public void enableIsolation() {
-        if(scanners.size() == 0) {
-            throw new IllegalArgumentException("Set Ranges first to initalize underneath scanners"); //TODO: if we save this info we don't need this check
-        }
-        for(Scanner scanner: scanners) {
-            scanner.enableIsolation();
-        }
-    }
-
-    @Override
-    public void disableIsolation() {
-        if(scanners.size() == 0) {
-            throw new IllegalArgumentException("Set Ranges first to initalize underneath scanners"); //TODO: if we save this info we don't need this check
-        }
-        for(Scanner scanner: scanners) {
-            scanner.disableIsolation();
-        }
-    }
-
-    @Override
-    public Iterator<Map.Entry<Key, Value>> iterator() {
-        //TODO: Lazy load iterator to only open the next scanner iterator after the first one is done
-        if(scanners.size() == 0) {
-            throw new IllegalArgumentException("Set Ranges first to initalize underneath scanners"); //TODO: if we save this info we don't need this check
-        }
-        List<Iterator<Map.Entry<Key,Value>>> iterators = new ArrayList<Iterator<Map.Entry<Key, Value>>>();
-        for(Scanner scanner: scanners) {
-            iterators.add(scanner.iterator());
-        }
-        return Iterators.concat(iterators.toArray(new Iterator[]{}));
-    }
-
-    @Override
-    public void close() {
-        //scanners do not close
-    }
-
-    @Override
-    public void setScanIterators(int i, String s, String s1) throws IOException {
-        if(scanners.size() == 0) {
-            throw new IllegalArgumentException("Set Ranges first to initalize underneath scanners"); //TODO: if we save this info we don't need this check
-        }
-        for(Scanner scanner: scanners) {
-            scanner.setScanIterators(i, s, s1);
-        }
-    }
-
-    @Override
-    public void setScanIteratorOption(String s, String s1, String s2) {
-        if(scanners.size() == 0) {
-            throw new IllegalArgumentException("Set Ranges first to initalize underneath scanners"); //TODO: if we save this info we don't need this check
-        }
-        for(Scanner scanner: scanners) {
-            scanner.setScanIteratorOption(s, s1, s2);
-        }
-    }
-
-    @Override
-    public void setupRegex(String s, int i) throws IOException {
-        if(scanners.size() == 0) {
-            throw new IllegalArgumentException("Set Ranges first to initalize underneath scanners"); //TODO: if we save this info we don't need this check
-        }
-        for(Scanner scanner: scanners) {
-            scanner.setupRegex(s, i);
-        }
-    }
-
-    @Override
-    public void setRowRegex(String s) {
-        if(scanners.size() == 0) {
-            throw new IllegalArgumentException("Set Ranges first to initalize underneath scanners"); //TODO: if we save this info we don't need this check
-        }
-        for(Scanner scanner: scanners) {
-            scanner.setRowRegex(s);
-        }
-    }
-
-    @Override
-    public void setColumnFamilyRegex(String s) {
-        if(scanners.size() == 0) {
-            throw new IllegalArgumentException("Set Ranges first to initalize underneath scanners"); //TODO: if we save this info we don't need this check
-        }
-        for(Scanner scanner: scanners) {
-            scanner.setColumnFamilyRegex(s);
-        }
-    }
-
-    @Override
-    public void setColumnQualifierRegex(String s) {
-        if(scanners.size() == 0) {
-            throw new IllegalArgumentException("Set Ranges first to initalize underneath scanners"); //TODO: if we save this info we don't need this check
-        }
-        for(Scanner scanner: scanners) {
-            scanner.setColumnQualifierRegex(s);
-        }
-    }
-
-    @Override
-    public void setValueRegex(String s) {
-        if(scanners.size() == 0) {
-            throw new IllegalArgumentException("Set Ranges first to initalize underneath scanners"); //TODO: if we save this info we don't need this check
-        }
-        for(Scanner scanner: scanners) {
-            scanner.setValueRegex(s);
-        }
-    }
-
-    @Override
-    public void fetchColumnFamily(Text text) {
-        if(scanners.size() == 0) {
-            throw new IllegalArgumentException("Set Ranges first to initalize underneath scanners"); //TODO: if we save this info we don't need this check
-        }
-        for(Scanner scanner: scanners) {
-            scanner.fetchColumnFamily(text);
-        }
-    }
-
-    @Override
-    public void fetchColumn(Text text, Text text1) {
-        if(scanners.size() == 0) {
-            throw new IllegalArgumentException("Set Ranges first to initalize underneath scanners"); //TODO: if we save this info we don't need this check
-        }
-        for(Scanner scanner: scanners) {
-            scanner.fetchColumn(text, text1);
-        }
-    }
-
-    @Override
-    public void clearColumns() {
-        if(scanners.size() == 0) {
-            throw new IllegalArgumentException("Set Ranges first to initalize underneath scanners"); //TODO: if we save this info we don't need this check
-        }
-        for(Scanner scanner: scanners) {
-            scanner.clearColumns();
-        }
-    }
-
-    @Override
-    public void clearScanIterators() {
-        if(scanners.size() == 0) {
-            throw new IllegalArgumentException("Set Ranges first to initalize underneath scanners"); //TODO: if we save this info we don't need this check
-        }
-        for(Scanner scanner: scanners) {
-            scanner.clearScanIterators();
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/utils/cloudbase.utils/src/main/java/mvm/rya/cloudbase/utils/shard/HashAlgorithm.java
----------------------------------------------------------------------
diff --git a/utils/cloudbase.utils/src/main/java/mvm/rya/cloudbase/utils/shard/HashAlgorithm.java b/utils/cloudbase.utils/src/main/java/mvm/rya/cloudbase/utils/shard/HashAlgorithm.java
deleted file mode 100644
index e4afe27..0000000
--- a/utils/cloudbase.utils/src/main/java/mvm/rya/cloudbase/utils/shard/HashAlgorithm.java
+++ /dev/null
@@ -1,9 +0,0 @@
-package mvm.rya.cloudbase.utils.shard;
-
-public interface HashAlgorithm {
-
-  /**
-   * @return a positive integer hash
-   */
-  long hash(final String k);
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/utils/cloudbase.utils/src/main/java/mvm/rya/cloudbase/utils/shard/HashCodeHashAlgorithm.java
----------------------------------------------------------------------
diff --git a/utils/cloudbase.utils/src/main/java/mvm/rya/cloudbase/utils/shard/HashCodeHashAlgorithm.java b/utils/cloudbase.utils/src/main/java/mvm/rya/cloudbase/utils/shard/HashCodeHashAlgorithm.java
deleted file mode 100644
index a43ea90..0000000
--- a/utils/cloudbase.utils/src/main/java/mvm/rya/cloudbase/utils/shard/HashCodeHashAlgorithm.java
+++ /dev/null
@@ -1,14 +0,0 @@
-package mvm.rya.cloudbase.utils.shard;
-
-/**
- * Created by IntelliJ IDEA.
- * Date: 4/18/12
- * Time: 10:28 AM
- * To change this template use File | Settings | File Templates.
- */
-public class HashCodeHashAlgorithm implements HashAlgorithm{
-    @Override
-    public long hash(String k) {
-        return Math.abs(k.hashCode());
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/utils/cloudbase.utils/src/main/java/mvm/rya/cloudbase/utils/shard/ShardedBatchWriter.java
----------------------------------------------------------------------
diff --git a/utils/cloudbase.utils/src/main/java/mvm/rya/cloudbase/utils/shard/ShardedBatchWriter.java b/utils/cloudbase.utils/src/main/java/mvm/rya/cloudbase/utils/shard/ShardedBatchWriter.java
deleted file mode 100644
index d1c0ec1..0000000
--- a/utils/cloudbase.utils/src/main/java/mvm/rya/cloudbase/utils/shard/ShardedBatchWriter.java
+++ /dev/null
@@ -1,51 +0,0 @@
-package mvm.rya.cloudbase.utils.shard;
-
-import cloudbase.core.client.MutationsRejectedException;
-import cloudbase.core.data.Mutation;
-import cloudbase.core.util.ArgumentChecker;
-
-/**
- * TODO: Think about what execption to use here
- * Created by IntelliJ IDEA.
- * Date: 4/18/12
- * Time: 10:27 AM
- * To change this template use File | Settings | File Templates.
- */
-public class ShardedBatchWriter {
-    private ShardedConnector shardedConnector;
-
-    public ShardedBatchWriter(ShardedConnector shardedConnector) {
-        ArgumentChecker.notNull(shardedConnector);
-        this.shardedConnector = shardedConnector;
-    }
-
-    //addMutation
-    public void addMutation(Mutation mutation, String key) throws MutationsRejectedException {
-        shardedConnector.addMutation(mutation, key);
-    }
-
-    public void addMutations(Iterable<Mutation> mutations, String key) throws MutationsRejectedException {
-        shardedConnector.addMutations(mutations, key);
-    }
-    //flush
-    public void flush() throws MutationsRejectedException {
-        shardedConnector.commitWriters();
-    }
-    public void flush(String key) throws MutationsRejectedException {
-        shardedConnector.retrieveBatchWriter(key).flush();
-    }
-    //close
-    public void close() throws MutationsRejectedException {
-        //commit?
-        flush();
-        //maybe do nothing here because the writers are in the connector
-    }
-
-    public ShardedConnector getShardedConnector() {
-        return shardedConnector;
-    }
-
-    public void setShardedConnector(ShardedConnector shardedConnector) {
-        this.shardedConnector = shardedConnector;
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/utils/cloudbase.utils/src/main/java/mvm/rya/cloudbase/utils/shard/ShardedConnector.java
----------------------------------------------------------------------
diff --git a/utils/cloudbase.utils/src/main/java/mvm/rya/cloudbase/utils/shard/ShardedConnector.java b/utils/cloudbase.utils/src/main/java/mvm/rya/cloudbase/utils/shard/ShardedConnector.java
deleted file mode 100644
index 40d513e..0000000
--- a/utils/cloudbase.utils/src/main/java/mvm/rya/cloudbase/utils/shard/ShardedConnector.java
+++ /dev/null
@@ -1,158 +0,0 @@
-package mvm.rya.cloudbase.utils.shard;
-
-import cloudbase.core.client.*;
-import cloudbase.core.client.admin.TableOperations;
-import cloudbase.core.data.Mutation;
-import cloudbase.core.security.Authorizations;
-import cloudbase.core.util.ArgumentChecker;
-import mvm.rya.cloudbase.utils.scanner.BatchScannerList;
-
-import java.util.ArrayList;
-import java.util.HashMap;
-import java.util.List;
-import java.util.Map;
-
-/**
- * Created by IntelliJ IDEA.
- * Date: 4/18/12
- * Time: 10:20 AM
- * To change this template use File | Settings | File Templates.
- */
-public class ShardedConnector {
-    //TODO: Use Ketema and perform proper Consistent Hashing
-    private Connector connector;
-    private int numShards;
-    private String tablePrefix;
-    private HashAlgorithm hashAlgorithm;
-
-    private Map<String, BatchWriter> writers = new HashMap<String, BatchWriter>();
-    private boolean initialized = false;
-
-    public ShardedConnector(Connector connector, int numShards, String tablePrefix, HashAlgorithm hashAlgorithm) {
-        ArgumentChecker.notNull(connector);
-        ArgumentChecker.notNull(tablePrefix);
-        if (numShards <= 0) {
-            throw new IllegalArgumentException("Number of shards cannot be 0");
-        }
-        if (hashAlgorithm == null) {
-            this.hashAlgorithm = new HashCodeHashAlgorithm();
-        }
-        this.connector = connector;
-        this.numShards = numShards;
-        this.tablePrefix = tablePrefix;
-    }
-
-    //createShardedBatchScanner
-    public BatchScanner createBatchScanner(String key, Authorizations authorizations, int numQueryThreads) throws TableNotFoundException {
-        List<BatchScanner> scanners = new ArrayList<BatchScanner>();
-        if (key != null) {
-            String shardTableName = buildShardTablename(key);
-            scanners.add(connector.createBatchScanner(shardTableName, authorizations, numQueryThreads));
-        } else {
-            //TODO: Use Ketema to do proper Consistent Hashing
-            for (int i = 0; i < numShards; i++) {
-                String shardTablename = buildShardTablename(i);
-                scanners.add(connector.createBatchScanner(shardTablename, authorizations, numQueryThreads)); //TODO: Will make scanner.size * numThreads = number of threads.
-            }
-        }
-        return new BatchScannerList(scanners);
-    }
-    //createShardedScanner
-
-    public ShardedBatchWriter createBatchWriter() throws TableNotFoundException {
-        return new ShardedBatchWriter(this);
-    }
-
-
-    protected void addMutation(Mutation mutation, String key) throws MutationsRejectedException {
-        retrieveBatchWriter(key).addMutation(mutation);
-    }
-
-    protected void addMutations(Iterable<Mutation> mutations, String key) throws MutationsRejectedException {
-        retrieveBatchWriter(key).addMutations(mutations);
-    }
-
-    public void init() throws Exception {
-        if (isInitialized()) {
-            throw new UnsupportedOperationException("ShardedConnector already initialized");
-        }
-        //init tables
-        TableOperations tableOperations = connector.tableOperations();
-        //create writers
-        //TODO: Use Ketema to do proper Consistent Hashing
-        for (int i = 0; i < numShards; i++) {
-            String shardTablename = buildShardTablename(i);
-            if (!tableOperations.exists(shardTablename)) {
-                tableOperations.create(shardTablename);
-            }
-            writers.put(shardTablename, connector.createBatchWriter(shardTablename, 1000000l, 60000l, 2)); //TODO: configurable
-        }
-
-        initialized = true;
-    }
-
-    public void close() throws Exception {
-        //close writers
-        for (Map.Entry<String, BatchWriter> entry : writers.entrySet()) {
-            entry.getValue().close();
-        }
-        initialized = false;
-    }
-
-    protected BatchWriter retrieveBatchWriter(String key) {
-        String tableName = buildShardTablename(key);
-        return writers.get(tableName);
-    }
-
-    protected void commitWriters() throws MutationsRejectedException {
-        for (Map.Entry<String, BatchWriter> entry : writers.entrySet()) {
-            entry.getValue().flush();
-        }
-    }
-
-    protected String buildShardTablename(String key) {
-        long shard = hashAlgorithm.hash(key) % numShards;
-        return buildShardTablename(shard);
-    }
-
-    protected String buildShardTablename(long shardId) {
-        return tablePrefix + shardId;
-    }
-
-
-    public Connector getConnector() {
-        return connector;
-    }
-
-    public void setConnector(Connector connector) {
-        this.connector = connector;
-    }
-
-    public int getNumShards() {
-        return numShards;
-    }
-
-    public void setNumShards(int numShards) {
-        this.numShards = numShards;
-    }
-
-    public String getTablePrefix() {
-        return tablePrefix;
-    }
-
-    public void setTablePrefix(String tablePrefix) {
-        this.tablePrefix = tablePrefix;
-    }
-
-    public HashAlgorithm getHashAlgorithm() {
-        return hashAlgorithm;
-    }
-
-    public void setHashAlgorithm(HashAlgorithm hashAlgorithm) {
-        this.hashAlgorithm = hashAlgorithm;
-    }
-
-    public boolean isInitialized() {
-        return initialized;
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/utils/cloudbase.utils/src/test/java/cloudbase/core/client/impl/DocumentTabletServerBatchReaderIteratorTest.java
----------------------------------------------------------------------
diff --git a/utils/cloudbase.utils/src/test/java/cloudbase/core/client/impl/DocumentTabletServerBatchReaderIteratorTest.java b/utils/cloudbase.utils/src/test/java/cloudbase/core/client/impl/DocumentTabletServerBatchReaderIteratorTest.java
deleted file mode 100644
index a795929..0000000
--- a/utils/cloudbase.utils/src/test/java/cloudbase/core/client/impl/DocumentTabletServerBatchReaderIteratorTest.java
+++ /dev/null
@@ -1,15 +0,0 @@
-package cloudbase.core.client.impl;
-
-import junit.framework.TestCase;
-
-/**
- * Class DocumentTabletServerBatchReaderIteratorTest
- * Date: Sep 8, 2011
- * Time: 9:11:00 AM
- */
-public class DocumentTabletServerBatchReaderIteratorTest extends TestCase {
-
-    public void testSomething() {
-        
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/utils/cloudbase.utils/src/test/java/mvm/rya/cloudbase/utils/filters/TimeRangeFilterTest.java
----------------------------------------------------------------------
diff --git a/utils/cloudbase.utils/src/test/java/mvm/rya/cloudbase/utils/filters/TimeRangeFilterTest.java b/utils/cloudbase.utils/src/test/java/mvm/rya/cloudbase/utils/filters/TimeRangeFilterTest.java
deleted file mode 100644
index 15cf731..0000000
--- a/utils/cloudbase.utils/src/test/java/mvm/rya/cloudbase/utils/filters/TimeRangeFilterTest.java
+++ /dev/null
@@ -1,53 +0,0 @@
-package mvm.rya.cloudbase.utils.filters;
-
-import cloudbase.core.data.Key;
-import junit.framework.TestCase;
-import org.apache.hadoop.io.Text;
-
-import java.util.HashMap;
-import java.util.Map;
-
-/**
- * Class TimeRangeFilterTest
- * Date: Mar 23, 2011
- * Time: 10:08:58 AM
- */
-public class TimeRangeFilterTest extends TestCase {
-
-    public void testTimeRange() throws Exception {
-        TimeRangeFilter filter = new TimeRangeFilter();
-        Map<String, String> map = new HashMap<String, String>();
-        map.put(TimeRangeFilter.TIME_RANGE_PROP, "10000");
-        map.put(TimeRangeFilter.START_TIME_PROP, "1010001");
-        filter.init(map);
-
-        assertFalse(filter.accept(new Key(new Text("row1"), 1000000), null));
-        assertTrue(filter.accept(new Key(new Text("row1"), 1000001), null));
-        assertTrue(filter.accept(new Key(new Text("row1"), 1000011), null));
-        assertTrue(filter.accept(new Key(new Text("row1"), 1010001), null));
-        assertFalse(filter.accept(new Key(new Text("row1"), 1010002), null));
-        assertFalse(filter.accept(new Key(new Text("row1"), 1010012), null));
-    }
-
-    public void testTimeRangeSetOptions() throws Exception {
-        try {
-            TimeRangeFilter filter = new TimeRangeFilter();
-            Map<String, String> map = new HashMap<String, String>();
-            filter.init(map);
-            fail();
-        } catch (Exception e) {
-        }
-    }
-
-    public void testTimeRangeCurrentTime() throws Exception {
-        long currentTime = System.currentTimeMillis();
-        TimeRangeFilter filter = new TimeRangeFilter();
-        Map<String, String> map = new HashMap<String, String>();
-        map.put(TimeRangeFilter.TIME_RANGE_PROP, "10000");
-        filter.init(map);
-
-        assertFalse(filter.accept(new Key(new Text("row1"), currentTime - 15000), null));
-        assertTrue(filter.accept(new Key(new Text("row1"), currentTime - 5000), null));
-        assertFalse(filter.accept(new Key(new Text("row1"), currentTime + 5000), null));
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/utils/cloudbase.utils/src/test/java/mvm/rya/cloudbase/utils/shard/ShardedConnectorTest.java
----------------------------------------------------------------------
diff --git a/utils/cloudbase.utils/src/test/java/mvm/rya/cloudbase/utils/shard/ShardedConnectorTest.java b/utils/cloudbase.utils/src/test/java/mvm/rya/cloudbase/utils/shard/ShardedConnectorTest.java
deleted file mode 100644
index 96afedb..0000000
--- a/utils/cloudbase.utils/src/test/java/mvm/rya/cloudbase/utils/shard/ShardedConnectorTest.java
+++ /dev/null
@@ -1,76 +0,0 @@
-package mvm.rya.cloudbase.utils.shard;
-
-import cloudbase.core.CBConstants;
-import cloudbase.core.client.BatchScanner;
-import cloudbase.core.client.Connector;
-import cloudbase.core.client.admin.TableOperations;
-import cloudbase.core.client.mock.MockInstance;
-import cloudbase.core.data.Key;
-import cloudbase.core.data.Mutation;
-import cloudbase.core.data.Range;
-import cloudbase.core.data.Value;
-import com.google.common.collect.Iterators;
-import junit.framework.TestCase;
-import org.apache.hadoop.io.Text;
-
-import java.util.*;
-
-/**
- * Created by IntelliJ IDEA.
- * Date: 4/18/12
- * Time: 11:59 AM
- * To change this template use File | Settings | File Templates.
- */
-public class ShardedConnectorTest extends TestCase {
-    public static final Text CF = new Text("cf");
-    public static final Text CQ = new Text("cq");
-    public static final Value EMPTY_VALUE = new Value(new byte[0]);
-    private ShardedConnector shardedConnector;
-    private Connector connector;
-
-    @Override
-    public void setUp() throws Exception {
-        super.setUp();
-        connector = new MockInstance("shardConnector").getConnector("", "".getBytes());
-        shardedConnector = new ShardedConnector(connector, 10, "tst_", null);
-        shardedConnector.init();
-    }
-
-    @Override
-    public void tearDown() throws Exception {
-        super.tearDown();
-        shardedConnector.close();
-    }
-
-    public void testTablesCreated() throws Exception {
-        TableOperations tableOperations = connector.tableOperations();
-        SortedSet<String> list = tableOperations.list();
-        assertTrue(list.containsAll(Arrays.asList("tst_0","tst_1","tst_2","tst_3","tst_4","tst_5","tst_6","tst_7","tst_8","tst_9")));
-    }
-    
-    public void testAddMutationByKey() throws Exception {
-        Mutation mutation = new Mutation(new Text("a"));
-        mutation.put(CF, CQ, EMPTY_VALUE);
-        ShardedBatchWriter batchWriter = shardedConnector.createBatchWriter();
-        batchWriter.addMutation(mutation, "1");
-        batchWriter.flush();
-
-        BatchScanner batchScanner = shardedConnector.createBatchScanner("1", CBConstants.NO_AUTHS, 1);
-        batchScanner.setRanges(Collections.singleton(new Range()));
-        Iterator<Map.Entry<Key,Value>> iterator = batchScanner.iterator();
-        assertEquals(1, Iterators.size(iterator));
-        batchScanner.close();
-
-        batchScanner = shardedConnector.createBatchScanner(null, CBConstants.NO_AUTHS, 1);
-        batchScanner.setRanges(Collections.singleton(new Range()));
-        iterator = batchScanner.iterator();
-        assertEquals(1, Iterators.size(iterator));
-        batchScanner.close();
-
-        batchScanner = shardedConnector.createBatchScanner("2", CBConstants.NO_AUTHS, 1);
-        batchScanner.setRanges(Collections.singleton(new Range()));
-        iterator = batchScanner.iterator();
-        assertEquals(0, Iterators.size(iterator));
-        batchScanner.close();
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/utils/pom.xml
----------------------------------------------------------------------
diff --git a/utils/pom.xml b/utils/pom.xml
deleted file mode 100644
index a10cbdb..0000000
--- a/utils/pom.xml
+++ /dev/null
@@ -1,22 +0,0 @@
-<?xml version="1.0" encoding="utf-8"?>
-<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/xsd/maven-4.0.0.xsd">
-
-    <modelVersion>4.0.0</modelVersion>
-    <parent>
-        <groupId>mvm.rya</groupId>
-        <artifactId>parent</artifactId>
-        <version>3.2.10-SNAPSHOT</version>
-    </parent>
-    <artifactId>rya.utils</artifactId>
-    <packaging>pom</packaging>
-    <name>${project.groupId}.${project.artifactId}</name>
-
-    <profiles>
-        <profile>
-            <id>cloudbase</id>
-            <modules>
-                <module>cloudbase.utils</module>
-            </modules>
-        </profile>
-    </profiles>
-</project>

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/web/pom.xml
----------------------------------------------------------------------
diff --git a/web/pom.xml b/web/pom.xml
index 1ef8e90..bcc7f7a 100644
--- a/web/pom.xml
+++ b/web/pom.xml
@@ -1,15 +1,37 @@
 <?xml version="1.0" encoding="utf-8"?>
-<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/xsd/maven-4.0.0.xsd">
 
+<!--
+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/xsd/maven-4.0.0.xsd">
     <modelVersion>4.0.0</modelVersion>
     <parent>
-        <groupId>mvm.rya</groupId>
-        <artifactId>parent</artifactId>
+        <groupId>org.apache.rya</groupId>
+        <artifactId>rya-project</artifactId>
         <version>3.2.10-SNAPSHOT</version>
     </parent>
+
     <artifactId>rya.web</artifactId>
+    <name>Apache Rya Web Projects</name>
+
     <packaging>pom</packaging>
-    <name>${project.groupId}.${project.artifactId}</name>
+
     <modules>
         <module>web.rya</module>
     </modules>

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/web/web.rya/pom.xml
----------------------------------------------------------------------
diff --git a/web/web.rya/pom.xml b/web/web.rya/pom.xml
index fdba91e..204bbef 100644
--- a/web/web.rya/pom.xml
+++ b/web/web.rya/pom.xml
@@ -1,66 +1,102 @@
+<?xml version='1.0'?>
+<!--
+Licensed to the Apache Software Foundation (ASF) under one
+or more contributor license agreements.  See the NOTICE file
+distributed with this work for additional information
+regarding copyright ownership.  The ASF licenses this file
+to you under the Apache License, Version 2.0 (the
+"License"); you may not use this file except in compliance
+with the License.  You may obtain a copy of the License at
+
+  http://www.apache.org/licenses/LICENSE-2.0
+
+Unless required by applicable law or agreed to in writing,
+software distributed under the License is distributed on an
+"AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+KIND, either express or implied.  See the License for the
+specific language governing permissions and limitations
+under the License.
+-->
+
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/maven-v4_0_0.xsd">
     <modelVersion>4.0.0</modelVersion>
     <parent>
-        <groupId>mvm.rya</groupId>
+        <groupId>org.apache.rya</groupId>
         <artifactId>rya.web</artifactId>
         <version>3.2.10-SNAPSHOT</version>
     </parent>
+
     <artifactId>web.rya</artifactId>
-    <name>${project.groupId}.${project.artifactId}</name>
+    <name>Apache Rya Web Implementation</name>
+
     <packaging>war</packaging>
-    <properties>
-        <spring.version>3.2.6.RELEASE</spring.version>
-    </properties>
+
     <dependencies>
         <dependency>
-            <groupId>junit</groupId>
-            <artifactId>junit</artifactId>
-            <scope>test</scope>
+            <groupId>org.apache.rya</groupId>
+            <artifactId>rya.api</artifactId>
         </dependency>
         <dependency>
-            <groupId>org.springframework.data</groupId>
-            <artifactId>spring-data-hadoop</artifactId>
-            <version>1.0.2.RELEASE</version>
+            <groupId>org.apache.rya</groupId>
+            <artifactId>rya.sail</artifactId>
+        </dependency>
+        <dependency>
+            <groupId>org.apache.rya</groupId>
+            <artifactId>accumulo.rya</artifactId>
+        </dependency>
+        <dependency>
+            <groupId>org.apache.rya</groupId>
+            <artifactId>rya.prospector</artifactId>
+        </dependency>
+        <dependency>
+            <groupId>org.apache.rya</groupId>
+            <artifactId>rya.indexing</artifactId>
         </dependency>
 
         <dependency>
-            <groupId>mvm.rya</groupId>
-            <artifactId>rya.api</artifactId>
+            <groupId>org.openrdf.sesame</groupId>
+            <artifactId>sesame-rio-rdfxml</artifactId>
         </dependency>
         <dependency>
-            <groupId>mvm.rya</groupId>
-            <artifactId>rya.sail.impl</artifactId>
+            <groupId>org.openrdf.sesame</groupId>
+            <artifactId>sesame-queryresultio-sparqljson</artifactId>
+        </dependency>
+
+        <dependency>
+            <groupId>org.springframework.data</groupId>
+            <artifactId>spring-data-hadoop</artifactId>
         </dependency>
+
         <dependency>
             <groupId>org.springframework</groupId>
             <artifactId>spring-context</artifactId>
-            <version>${spring.version}</version>
         </dependency>
         <dependency>
             <groupId>org.springframework</groupId>
             <artifactId>spring-core</artifactId>
-            <version>${spring.version}</version>
         </dependency>
         <dependency>
             <groupId>org.springframework</groupId>
             <artifactId>spring-web</artifactId>
-            <version>${spring.version}</version>
         </dependency>
         <dependency>
             <groupId>org.springframework</groupId>
             <artifactId>spring-webmvc</artifactId>
-            <version>${spring.version}</version>
         </dependency>
         <dependency>
             <groupId>org.springframework</groupId>
             <artifactId>spring-beans</artifactId>
-            <version>${spring.version}</version>
         </dependency>
         <dependency>
             <groupId>org.springframework</groupId>
             <artifactId>spring-test</artifactId>
-            <version>${spring.version}</version>
         </dependency>
+
+        <dependency>
+            <groupId>org.hamcrest</groupId>
+            <artifactId>hamcrest-all</artifactId>
+        </dependency>
+
         <dependency>
             <groupId>org.slf4j</groupId>
             <artifactId>slf4j-log4j12</artifactId>
@@ -68,40 +104,17 @@
         <dependency>
             <groupId>commons-pool</groupId>
             <artifactId>commons-pool</artifactId>
-            <version>1.5.1</version>
-        </dependency>
-        <dependency>
-            <groupId>mvm.rya</groupId>
-            <artifactId>accumulo.rya</artifactId>
-        </dependency>
-        <dependency>
-            <groupId>mvm.rya</groupId>
-            <artifactId>rya.prospector</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-       <dependency>
-            <groupId>org.openrdf.sesame</groupId>
-            <artifactId>sesame-rio-rdfxml</artifactId>
- 			<version>${openrdf.sesame.version}</version>
         </dependency>
+
         <dependency>
             <groupId>junit</groupId>
             <artifactId>junit</artifactId>
+            <scope>test</scope>
         </dependency>
-		<dependency>
-			<groupId>org.openrdf.sesame</groupId>
-			<artifactId>sesame-queryresultio-sparqljson</artifactId>
-			<version>${openrdf.sesame.version}</version>
-		</dependency>
         <dependency>
             <groupId>org.mockito</groupId>
-            <artifactId>mockito-core</artifactId>
-            <version>1.9.5</version>
-        </dependency>
-        <dependency>
-            <groupId>org.hamcrest</groupId>
-            <artifactId>hamcrest-all</artifactId>
-            <version>1.3</version>
+            <artifactId>mockito-all</artifactId>
+            <scope>test</scope>
         </dependency>
     </dependencies>
     <build>
@@ -118,60 +131,6 @@
                     </webAppConfig>
                 </configuration>
             </plugin>
-            <plugin>
-                <groupId>org.apache.maven.plugins</groupId>
-                <artifactId>maven-compiler-plugin</artifactId>
-                <configuration>
-                    <source>1.6</source>
-                    <target>1.6</target>
-                </configuration>
-            </plugin>
         </plugins>
     </build>
-
-    <profiles>
-        <profile>
-            <id>accumulo</id>
-            <activation>
-                <activeByDefault>true</activeByDefault>
-            </activation>
-            <dependencies>
-                <dependency>
-                    <groupId>org.apache.accumulo</groupId>
-                    <artifactId>accumulo-core</artifactId>
-                </dependency>
-                <dependency>
-                    <groupId>mvm.rya</groupId>
-                    <artifactId>accumulo.iterators</artifactId>
-                </dependency>
-            </dependencies>
-        </profile>
-        <profile>
-            <id>cloudbase</id>
-            <activation>
-                <activeByDefault>false</activeByDefault>
-            </activation>
-            <dependencies>
-                <dependency>
-                    <groupId>com.texeltek</groupId>
-                    <artifactId>accumulo-cloudbase-shim</artifactId>
-                </dependency>
-                <dependency>
-                    <groupId>mvm.rya</groupId>
-                    <artifactId>cloudbase.iterators</artifactId>
-                </dependency>
-            </dependencies>
-        </profile>
-        <profile>
-            <id>indexing</id>
-            <dependencies>
-                <dependency>
-                    <groupId>mvm.rya</groupId>
-                    <artifactId>rya.indexing</artifactId>
-                    <version>${project.version}</version>
-                </dependency>
-            </dependencies>
-        </profile>
-    </profiles>
-
 </project>

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/web/web.rya/resources/environment.properties
----------------------------------------------------------------------
diff --git a/web/web.rya/resources/environment.properties b/web/web.rya/resources/environment.properties
index 405f285..7848a4e 100644
--- a/web/web.rya/resources/environment.properties
+++ b/web/web.rya/resources/environment.properties
@@ -1,3 +1,20 @@
+# 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.
+
 instance.name=cloudbase
 instance.zk=localhost:2181
 instance.username=root
@@ -7,4 +24,4 @@ rya.displayqueryplan=true
 mongo.db.collectionprefix=rya_
 mongo.db.instance=localhost
 mongo.db.name=rya
-mongo.db.port=21017
\ No newline at end of file
+mongo.db.port=21017

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/web/web.rya/src/main/java/mvm/cloud/rdf/web/cloudbase/sail/AbstractRDFWebServlet.java
----------------------------------------------------------------------
diff --git a/web/web.rya/src/main/java/mvm/cloud/rdf/web/cloudbase/sail/AbstractRDFWebServlet.java b/web/web.rya/src/main/java/mvm/cloud/rdf/web/cloudbase/sail/AbstractRDFWebServlet.java
index 70dfc5b..313a3c3 100644
--- a/web/web.rya/src/main/java/mvm/cloud/rdf/web/cloudbase/sail/AbstractRDFWebServlet.java
+++ b/web/web.rya/src/main/java/mvm/cloud/rdf/web/cloudbase/sail/AbstractRDFWebServlet.java
@@ -1,24 +1,24 @@
-//package mvm.cloud.rdf.web.cloudbase.sail;
-
 /*
- * #%L
- * mvm.rya.web.rya
- * %%
- * Copyright (C) 2014 Rya
- * %%
- * 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
+ * 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
+ *   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.
- * #L%
+ * 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 mvm.cloud.rdf.web.cloudbase.sail;
+
 //
 //import cloudbase.core.client.Connector;
 //import cloudbase.core.client.ZooKeeperInstance;

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/web/web.rya/src/main/java/mvm/cloud/rdf/web/cloudbase/sail/DeleteDataServlet.java
----------------------------------------------------------------------
diff --git a/web/web.rya/src/main/java/mvm/cloud/rdf/web/cloudbase/sail/DeleteDataServlet.java b/web/web.rya/src/main/java/mvm/cloud/rdf/web/cloudbase/sail/DeleteDataServlet.java
index 5b922f7..661fe38 100644
--- a/web/web.rya/src/main/java/mvm/cloud/rdf/web/cloudbase/sail/DeleteDataServlet.java
+++ b/web/web.rya/src/main/java/mvm/cloud/rdf/web/cloudbase/sail/DeleteDataServlet.java
@@ -1,24 +1,24 @@
-//package mvm.cloud.rdf.web.cloudbase.sail;
-
 /*
- * #%L
- * mvm.rya.web.rya
- * %%
- * Copyright (C) 2014 Rya
- * %%
- * 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
+ * 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
+ *   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.
- * #L%
+ * 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 mvm.cloud.rdf.web.cloudbase.sail;
+
 //
 //import org.openrdf.query.QueryLanguage;
 //import org.openrdf.query.TupleQuery;

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/web/web.rya/src/main/java/mvm/cloud/rdf/web/cloudbase/sail/LoadDataServlet.java
----------------------------------------------------------------------
diff --git a/web/web.rya/src/main/java/mvm/cloud/rdf/web/cloudbase/sail/LoadDataServlet.java b/web/web.rya/src/main/java/mvm/cloud/rdf/web/cloudbase/sail/LoadDataServlet.java
index a557d57..175ef2a 100644
--- a/web/web.rya/src/main/java/mvm/cloud/rdf/web/cloudbase/sail/LoadDataServlet.java
+++ b/web/web.rya/src/main/java/mvm/cloud/rdf/web/cloudbase/sail/LoadDataServlet.java
@@ -1,24 +1,24 @@
-//package mvm.cloud.rdf.web.cloudbase.sail;
-
 /*
- * #%L
- * mvm.rya.web.rya
- * %%
- * Copyright (C) 2014 Rya
- * %%
- * 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
+ * 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
+ *   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.
- * #L%
+ * 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 mvm.cloud.rdf.web.cloudbase.sail;
+
 //
 //import org.openrdf.model.Resource;
 //import org.openrdf.repository.RepositoryConnection;

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/web/web.rya/src/main/java/mvm/cloud/rdf/web/cloudbase/sail/QueryDataServlet.java
----------------------------------------------------------------------
diff --git a/web/web.rya/src/main/java/mvm/cloud/rdf/web/cloudbase/sail/QueryDataServlet.java b/web/web.rya/src/main/java/mvm/cloud/rdf/web/cloudbase/sail/QueryDataServlet.java
index 8e4962c..dfcd035 100644
--- a/web/web.rya/src/main/java/mvm/cloud/rdf/web/cloudbase/sail/QueryDataServlet.java
+++ b/web/web.rya/src/main/java/mvm/cloud/rdf/web/cloudbase/sail/QueryDataServlet.java
@@ -1,24 +1,24 @@
-//package mvm.cloud.rdf.web.cloudbase.sail;
-
 /*
- * #%L
- * mvm.rya.web.rya
- * %%
- * Copyright (C) 2014 Rya
- * %%
- * 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
+ * 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
+ *   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.
- * #L%
+ * 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 mvm.cloud.rdf.web.cloudbase.sail;
+
 //
 //import RdfCloudTripleStoreConstants;
 //import RdfCloudTripleStoreConstants;

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/web/web.rya/src/main/java/mvm/cloud/rdf/web/cloudbase/sail/QuerySerqlDataServlet.java
----------------------------------------------------------------------
diff --git a/web/web.rya/src/main/java/mvm/cloud/rdf/web/cloudbase/sail/QuerySerqlDataServlet.java b/web/web.rya/src/main/java/mvm/cloud/rdf/web/cloudbase/sail/QuerySerqlDataServlet.java
index 11db0d6..b1eb5e3 100644
--- a/web/web.rya/src/main/java/mvm/cloud/rdf/web/cloudbase/sail/QuerySerqlDataServlet.java
+++ b/web/web.rya/src/main/java/mvm/cloud/rdf/web/cloudbase/sail/QuerySerqlDataServlet.java
@@ -1,24 +1,24 @@
-//package mvm.cloud.rdf.web.cloudbase.sail;
-
 /*
- * #%L
- * mvm.rya.web.rya
- * %%
- * Copyright (C) 2014 Rya
- * %%
- * 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
+ * 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
+ *   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.
- * #L%
+ * 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 mvm.cloud.rdf.web.cloudbase.sail;
+
 //
 //import org.openrdf.query.GraphQuery;
 //import org.openrdf.query.QueryLanguage;

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/web/web.rya/src/main/java/mvm/cloud/rdf/web/cloudbase/sail/RDFWebConstants.java
----------------------------------------------------------------------
diff --git a/web/web.rya/src/main/java/mvm/cloud/rdf/web/cloudbase/sail/RDFWebConstants.java b/web/web.rya/src/main/java/mvm/cloud/rdf/web/cloudbase/sail/RDFWebConstants.java
index 1bed3a7..16cfe71 100644
--- a/web/web.rya/src/main/java/mvm/cloud/rdf/web/cloudbase/sail/RDFWebConstants.java
+++ b/web/web.rya/src/main/java/mvm/cloud/rdf/web/cloudbase/sail/RDFWebConstants.java
@@ -1,24 +1,24 @@
-//package mvm.cloud.rdf.web.cloudbase.sail;
-
 /*
- * #%L
- * mvm.rya.web.rya
- * %%
- * Copyright (C) 2014 Rya
- * %%
- * 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
+ * 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
+ *   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.
- * #L%
+ * 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 mvm.cloud.rdf.web.cloudbase.sail;
+
 //
 ///**
 // * Interface RDFWebConstants

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/web/web.rya/src/main/java/mvm/cloud/rdf/web/sail/RdfController.java
----------------------------------------------------------------------
diff --git a/web/web.rya/src/main/java/mvm/cloud/rdf/web/sail/RdfController.java b/web/web.rya/src/main/java/mvm/cloud/rdf/web/sail/RdfController.java
index b3ff85f..bc6272a 100644
--- a/web/web.rya/src/main/java/mvm/cloud/rdf/web/sail/RdfController.java
+++ b/web/web.rya/src/main/java/mvm/cloud/rdf/web/sail/RdfController.java
@@ -1,25 +1,26 @@
 package mvm.cloud.rdf.web.sail;
 
 /*
- * #%L
- * mvm.rya.web.rya
- * %%
- * Copyright (C) 2014 Rya
- * %%
- * 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
+ * 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
+ *   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.
- * #L%
+ * 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.
  */
 
+
+
 import static mvm.rya.api.RdfCloudTripleStoreConstants.AUTH_NAMESPACE;
 import static mvm.rya.api.RdfCloudTripleStoreConstants.VALUE_FACTORY;
 

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/web/web.rya/src/main/java/mvm/cloud/rdf/web/sail/ResultFormat.java
----------------------------------------------------------------------
diff --git a/web/web.rya/src/main/java/mvm/cloud/rdf/web/sail/ResultFormat.java b/web/web.rya/src/main/java/mvm/cloud/rdf/web/sail/ResultFormat.java
index 2be1ec3..7e763d5 100644
--- a/web/web.rya/src/main/java/mvm/cloud/rdf/web/sail/ResultFormat.java
+++ b/web/web.rya/src/main/java/mvm/cloud/rdf/web/sail/ResultFormat.java
@@ -1,25 +1,26 @@
 package mvm.cloud.rdf.web.sail;
 
 /*
- * #%L
- * mvm.rya.web.rya
- * %%
- * Copyright (C) 2014 Rya
- * %%
- * 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
+ * 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
+ *   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.
- * #L%
+ * 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.
  */
 
+
+
 public enum ResultFormat {
     XML, JSON, JSONP
 

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/web/web.rya/src/main/java/mvm/cloud/rdf/web/sail/SecurityProviderImpl.java
----------------------------------------------------------------------
diff --git a/web/web.rya/src/main/java/mvm/cloud/rdf/web/sail/SecurityProviderImpl.java b/web/web.rya/src/main/java/mvm/cloud/rdf/web/sail/SecurityProviderImpl.java
index ab775d4..58fc0f4 100644
--- a/web/web.rya/src/main/java/mvm/cloud/rdf/web/sail/SecurityProviderImpl.java
+++ b/web/web.rya/src/main/java/mvm/cloud/rdf/web/sail/SecurityProviderImpl.java
@@ -1,5 +1,25 @@
 package mvm.cloud.rdf.web.sail;
 
+/*
+ * 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.
+ */
+
+
 import javax.servlet.http.HttpServletRequest;
 
 import mvm.rya.api.security.SecurityProvider;

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/web/web.rya/src/main/webapp/WEB-INF/spring/spring-accumulo.xml
----------------------------------------------------------------------
diff --git a/web/web.rya/src/main/webapp/WEB-INF/spring/spring-accumulo.xml b/web/web.rya/src/main/webapp/WEB-INF/spring/spring-accumulo.xml
index 0792e81..7f9caaf 100644
--- a/web/web.rya/src/main/webapp/WEB-INF/spring/spring-accumulo.xml
+++ b/web/web.rya/src/main/webapp/WEB-INF/spring/spring-accumulo.xml
@@ -1,4 +1,24 @@
 <?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.
+-->
+
 <beans xmlns="http://www.springframework.org/schema/beans"
 	xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xmlns:p="http://www.springframework.org/schema/p"
 	xmlns:context="http://www.springframework.org/schema/context"

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/web/web.rya/src/main/webapp/WEB-INF/spring/spring-cloudbase.xml
----------------------------------------------------------------------
diff --git a/web/web.rya/src/main/webapp/WEB-INF/spring/spring-cloudbase.xml b/web/web.rya/src/main/webapp/WEB-INF/spring/spring-cloudbase.xml
index e59b5f8..8d5ee69 100644
--- a/web/web.rya/src/main/webapp/WEB-INF/spring/spring-cloudbase.xml
+++ b/web/web.rya/src/main/webapp/WEB-INF/spring/spring-cloudbase.xml
@@ -1,4 +1,24 @@
 <?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.
+-->
+
 <beans xmlns="http://www.springframework.org/schema/beans"
        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xmlns:p="http://www.springframework.org/schema/p"
        xmlns:context="http://www.springframework.org/schema/context"

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/web/web.rya/src/main/webapp/WEB-INF/spring/spring-mongodb.xml
----------------------------------------------------------------------
diff --git a/web/web.rya/src/main/webapp/WEB-INF/spring/spring-mongodb.xml b/web/web.rya/src/main/webapp/WEB-INF/spring/spring-mongodb.xml
index 88094fe..85ea26e 100644
--- a/web/web.rya/src/main/webapp/WEB-INF/spring/spring-mongodb.xml
+++ b/web/web.rya/src/main/webapp/WEB-INF/spring/spring-mongodb.xml
@@ -1,4 +1,24 @@
 <?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.
+-->
+
 <beans xmlns="http://www.springframework.org/schema/beans"
 	xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xmlns:p="http://www.springframework.org/schema/p"
 	xmlns:context="http://www.springframework.org/schema/context"

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/web/web.rya/src/main/webapp/WEB-INF/spring/spring-root-extensions.xml
----------------------------------------------------------------------
diff --git a/web/web.rya/src/main/webapp/WEB-INF/spring/spring-root-extensions.xml b/web/web.rya/src/main/webapp/WEB-INF/spring/spring-root-extensions.xml
index fa31e21..67feae8 100644
--- a/web/web.rya/src/main/webapp/WEB-INF/spring/spring-root-extensions.xml
+++ b/web/web.rya/src/main/webapp/WEB-INF/spring/spring-root-extensions.xml
@@ -1,4 +1,24 @@
 <?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.
+-->
+
 <beans xmlns="http://www.springframework.org/schema/beans"
 	xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xmlns:p="http://www.springframework.org/schema/p"
 	xmlns:context="http://www.springframework.org/schema/context"

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/web/web.rya/src/main/webapp/WEB-INF/spring/spring-root.xml
----------------------------------------------------------------------
diff --git a/web/web.rya/src/main/webapp/WEB-INF/spring/spring-root.xml b/web/web.rya/src/main/webapp/WEB-INF/spring/spring-root.xml
index c354f99..b42a222 100644
--- a/web/web.rya/src/main/webapp/WEB-INF/spring/spring-root.xml
+++ b/web/web.rya/src/main/webapp/WEB-INF/spring/spring-root.xml
@@ -1,4 +1,24 @@
 <?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.
+-->
+
 <beans xmlns="http://www.springframework.org/schema/beans"
 	xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xmlns:p="http://www.springframework.org/schema/p"
 	xmlns:context="http://www.springframework.org/schema/context"

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/web/web.rya/src/main/webapp/WEB-INF/spring/spring-security.xml
----------------------------------------------------------------------
diff --git a/web/web.rya/src/main/webapp/WEB-INF/spring/spring-security.xml b/web/web.rya/src/main/webapp/WEB-INF/spring/spring-security.xml
index bd086f0..c15e9d3 100644
--- a/web/web.rya/src/main/webapp/WEB-INF/spring/spring-security.xml
+++ b/web/web.rya/src/main/webapp/WEB-INF/spring/spring-security.xml
@@ -1,4 +1,24 @@
 <?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.
+-->
+
 <beans xmlns="http://www.springframework.org/schema/beans"
 	xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xmlns:p="http://www.springframework.org/schema/p"
 	xmlns:context="http://www.springframework.org/schema/context"

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/web/web.rya/src/main/webapp/WEB-INF/web.xml
----------------------------------------------------------------------
diff --git a/web/web.rya/src/main/webapp/WEB-INF/web.xml b/web/web.rya/src/main/webapp/WEB-INF/web.xml
index 54e36ab..5f53e4b 100644
--- a/web/web.rya/src/main/webapp/WEB-INF/web.xml
+++ b/web/web.rya/src/main/webapp/WEB-INF/web.xml
@@ -1,3 +1,23 @@
+<?xml version='1.0'?>
+<!--
+Licensed to the Apache Software Foundation (ASF) under one
+or more contributor license agreements.  See the NOTICE file
+distributed with this work for additional information
+regarding copyright ownership.  The ASF licenses this file
+to you under the Apache License, Version 2.0 (the
+"License"); you may not use this file except in compliance
+with the License.  You may obtain a copy of the License at
+
+  http://www.apache.org/licenses/LICENSE-2.0
+
+Unless required by applicable law or agreed to in writing,
+software distributed under the License is distributed on an
+"AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+KIND, either express or implied.  See the License for the
+specific language governing permissions and limitations
+under the License.
+-->
+
 <!DOCTYPE web-app PUBLIC
         "-//Sun Microsystems, Inc.//DTD Web Application 2.3//EN"
         "http://java.sun.com/dtd/web-app_2_3.dtd" >

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/web/web.rya/src/main/webapp/crossdomain.xml
----------------------------------------------------------------------
diff --git a/web/web.rya/src/main/webapp/crossdomain.xml b/web/web.rya/src/main/webapp/crossdomain.xml
index c3b5339..cec91f6 100644
--- a/web/web.rya/src/main/webapp/crossdomain.xml
+++ b/web/web.rya/src/main/webapp/crossdomain.xml
@@ -1,5 +1,25 @@
 <?xml version="1.0"?>
+
+<!--
+Licensed to the Apache Software Foundation (ASF) under one
+or more contributor license agreements.  See the NOTICE file
+distributed with this work for additional information
+regarding copyright ownership.  The ASF licenses this file
+to you under the Apache License, Version 2.0 (the
+"License"); you may not use this file except in compliance
+with the License.  You may obtain a copy of the License at
+
+  http://www.apache.org/licenses/LICENSE-2.0
+
+Unless required by applicable law or agreed to in writing,
+software distributed under the License is distributed on an
+"AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+KIND, either express or implied.  See the License for the
+specific language governing permissions and limitations
+under the License.
+-->
+
 <!DOCTYPE cross-domain-policy SYSTEM "http://www.macromedia.com/xml/dtds/cross-domain-policy.dtd">
 <cross-domain-policy>
     <allow-access-from domain="*" secure="false"/>
-</cross-domain-policy>
\ No newline at end of file
+</cross-domain-policy>

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/web/web.rya/src/main/webapp/sparqlQuery.jsp
----------------------------------------------------------------------
diff --git a/web/web.rya/src/main/webapp/sparqlQuery.jsp b/web/web.rya/src/main/webapp/sparqlQuery.jsp
index 03a3c43..d026a50 100644
--- a/web/web.rya/src/main/webapp/sparqlQuery.jsp
+++ b/web/web.rya/src/main/webapp/sparqlQuery.jsp
@@ -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.
+-->
+
 <%@ page contentType="text/html; charset=iso-8859-1" language="java" %>
 <%@ page import="java.net.*" %>
 <%
@@ -57,4 +76,4 @@ Enter Sparql query here
 </table>
 </form>
 </body>
-</html>
\ No newline at end of file
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/web/web.rya/src/test/java/mvm/cloud/rdf/web/cloudbase/sail/DeleteDataServletRun.java
----------------------------------------------------------------------
diff --git a/web/web.rya/src/test/java/mvm/cloud/rdf/web/cloudbase/sail/DeleteDataServletRun.java b/web/web.rya/src/test/java/mvm/cloud/rdf/web/cloudbase/sail/DeleteDataServletRun.java
index 4520bd0..061bda9 100644
--- a/web/web.rya/src/test/java/mvm/cloud/rdf/web/cloudbase/sail/DeleteDataServletRun.java
+++ b/web/web.rya/src/test/java/mvm/cloud/rdf/web/cloudbase/sail/DeleteDataServletRun.java
@@ -1,25 +1,26 @@
 package mvm.cloud.rdf.web.cloudbase.sail;
 
 /*
- * #%L
- * mvm.rya.web.rya
- * %%
- * Copyright (C) 2014 Rya
- * %%
- * 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
+ * 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
+ *   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.
- * #L%
+ * 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.
  */
 
+
+
 import java.io.BufferedReader;
 import java.io.InputStreamReader;
 import java.net.URL;

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/web/web.rya/src/test/java/mvm/cloud/rdf/web/cloudbase/sail/LoadDataServletRun.java
----------------------------------------------------------------------
diff --git a/web/web.rya/src/test/java/mvm/cloud/rdf/web/cloudbase/sail/LoadDataServletRun.java b/web/web.rya/src/test/java/mvm/cloud/rdf/web/cloudbase/sail/LoadDataServletRun.java
index 13bd9ec..1bfc278 100644
--- a/web/web.rya/src/test/java/mvm/cloud/rdf/web/cloudbase/sail/LoadDataServletRun.java
+++ b/web/web.rya/src/test/java/mvm/cloud/rdf/web/cloudbase/sail/LoadDataServletRun.java
@@ -1,25 +1,26 @@
 package mvm.cloud.rdf.web.cloudbase.sail;
 
 /*
- * #%L
- * mvm.rya.web.rya
- * %%
- * Copyright (C) 2014 Rya
- * %%
- * 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
+ * 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
+ *   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.
- * #L%
+ * 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.
  */
 
+
+
 import java.io.BufferedReader;
 import java.io.InputStream;
 import java.io.InputStreamReader;

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/web/web.rya/src/test/java/mvm/cloud/rdf/web/cloudbase/sail/QueryDataServletRun.java
----------------------------------------------------------------------
diff --git a/web/web.rya/src/test/java/mvm/cloud/rdf/web/cloudbase/sail/QueryDataServletRun.java b/web/web.rya/src/test/java/mvm/cloud/rdf/web/cloudbase/sail/QueryDataServletRun.java
index 3e0049e..e9d918a 100644
--- a/web/web.rya/src/test/java/mvm/cloud/rdf/web/cloudbase/sail/QueryDataServletRun.java
+++ b/web/web.rya/src/test/java/mvm/cloud/rdf/web/cloudbase/sail/QueryDataServletRun.java
@@ -1,25 +1,26 @@
 package mvm.cloud.rdf.web.cloudbase.sail;
 
 /*
- * #%L
- * mvm.rya.web.rya
- * %%
- * Copyright (C) 2014 Rya
- * %%
- * 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
+ * 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
+ *   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.
- * #L%
+ * 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.
  */
 
+
+
 import java.io.BufferedReader;
 import java.io.InputStreamReader;
 import java.net.URL;

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/web/web.rya/src/test/java/mvm/cloud/rdf/web/sail/RdfControllerIntegrationTest.java
----------------------------------------------------------------------
diff --git a/web/web.rya/src/test/java/mvm/cloud/rdf/web/sail/RdfControllerIntegrationTest.java b/web/web.rya/src/test/java/mvm/cloud/rdf/web/sail/RdfControllerIntegrationTest.java
index 5265484..eea0bad 100644
--- a/web/web.rya/src/test/java/mvm/cloud/rdf/web/sail/RdfControllerIntegrationTest.java
+++ b/web/web.rya/src/test/java/mvm/cloud/rdf/web/sail/RdfControllerIntegrationTest.java
@@ -1,5 +1,25 @@
 package mvm.cloud.rdf.web.sail;
 
+/*
+ * 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.
+ */
+
+
 import org.junit.Before;
 import org.junit.Rule;
 import org.junit.Test;

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/web/web.rya/src/test/java/mvm/cloud/rdf/web/sail/RdfControllerTest.java
----------------------------------------------------------------------
diff --git a/web/web.rya/src/test/java/mvm/cloud/rdf/web/sail/RdfControllerTest.java b/web/web.rya/src/test/java/mvm/cloud/rdf/web/sail/RdfControllerTest.java
index 613bcfb..7888457 100644
--- a/web/web.rya/src/test/java/mvm/cloud/rdf/web/sail/RdfControllerTest.java
+++ b/web/web.rya/src/test/java/mvm/cloud/rdf/web/sail/RdfControllerTest.java
@@ -1,25 +1,26 @@
 package mvm.cloud.rdf.web.sail;
 
 /*
- * #%L
- * mvm.rya.web.rya
- * %%
- * Copyright (C) 2014 Rya
- * %%
- * 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
+ * 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
+ *   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.
- * #L%
+ * 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.
  */
 
+
+
 import static org.hamcrest.Matchers.equalToIgnoringWhiteSpace;
 import static org.junit.Assert.assertTrue;
 import static org.springframework.test.web.servlet.request.MockMvcRequestBuilders.get;

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/web/web.rya/src/test/resources/cdrdf.xml
----------------------------------------------------------------------
diff --git a/web/web.rya/src/test/resources/cdrdf.xml b/web/web.rya/src/test/resources/cdrdf.xml
index 0dbe6c2..96829f0 100644
--- a/web/web.rya/src/test/resources/cdrdf.xml
+++ b/web/web.rya/src/test/resources/cdrdf.xml
@@ -1,23 +1,24 @@
 <?xml version="1.0"?>
+
 <!--
-  #%L
-  mvm.rya.web.rya
-  %%
-  Copyright (C) 2014 Rya
-  %%
-  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.
-  #L%
-  -->
+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.
+-->
+
 
 <rdf:RDF xmlns:rdf="http://www.w3.org/1999/02/22-rdf-syntax-ns#"
 	xmlns:cd="http://www.recshop.fake/cd#">
@@ -37,4 +38,4 @@
 		<cd:price>9.90</cd:price>
 		<cd:year>1993</cd:year>
 	</rdf:Description>
-</rdf:RDF>
\ No newline at end of file
+</rdf:RDF>

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/web/web.rya/src/test/resources/controllerIntegrationTest-accumulo.xml
----------------------------------------------------------------------
diff --git a/web/web.rya/src/test/resources/controllerIntegrationTest-accumulo.xml b/web/web.rya/src/test/resources/controllerIntegrationTest-accumulo.xml
index 20120db..5b20d57 100644
--- a/web/web.rya/src/test/resources/controllerIntegrationTest-accumulo.xml
+++ b/web/web.rya/src/test/resources/controllerIntegrationTest-accumulo.xml
@@ -1,22 +1,23 @@
+<?xml version='1.0'?>
 <!--
-  #%L
-  mvm.rya.web.rya
-  %%
-  Copyright (C) 2014 Rya
-  %%
-  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.
-  #L%
-  -->
+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 xmlns="http://www.springframework.org/schema/beans"
        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
        xsi:schemaLocation="

http://git-wip-us.apache.org/repos/asf/incubator-rya/blob/80faf06d/web/web.rya/src/test/resources/controllerIntegrationTest-root.xml
----------------------------------------------------------------------
diff --git a/web/web.rya/src/test/resources/controllerIntegrationTest-root.xml b/web/web.rya/src/test/resources/controllerIntegrationTest-root.xml
index e49edb1..7fab80d 100644
--- a/web/web.rya/src/test/resources/controllerIntegrationTest-root.xml
+++ b/web/web.rya/src/test/resources/controllerIntegrationTest-root.xml
@@ -1,4 +1,25 @@
 <?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.
+-->
+
 <beans xmlns="http://www.springframework.org/schema/beans"
        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
        xmlns:context="http://www.springframework.org/schema/context"