You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@jena.apache.org by an...@apache.org on 2015/05/07 12:01:57 UTC

[1/4] jena git commit: Clean code.

Repository: jena
Updated Branches:
  refs/heads/master fa3bae848 -> 18aaf7dac


Clean code.

Project: http://git-wip-us.apache.org/repos/asf/jena/repo
Commit: http://git-wip-us.apache.org/repos/asf/jena/commit/e81ee641
Tree: http://git-wip-us.apache.org/repos/asf/jena/tree/e81ee641
Diff: http://git-wip-us.apache.org/repos/asf/jena/diff/e81ee641

Branch: refs/heads/master
Commit: e81ee641d7ee7dbb7e4dbde792d7e79af4a7df72
Parents: fa3bae8
Author: Andy Seaborne <an...@apache.org>
Authored: Thu May 7 10:29:00 2015 +0100
Committer: Andy Seaborne <an...@apache.org>
Committed: Thu May 7 10:29:00 2015 +0100

----------------------------------------------------------------------
 .../apache/jena/atlas/lib/cache/CacheGuava.java | 20 ++++++++------------
 1 file changed, 8 insertions(+), 12 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/jena/blob/e81ee641/jena-base/src/main/java/org/apache/jena/atlas/lib/cache/CacheGuava.java
----------------------------------------------------------------------
diff --git a/jena-base/src/main/java/org/apache/jena/atlas/lib/cache/CacheGuava.java b/jena-base/src/main/java/org/apache/jena/atlas/lib/cache/CacheGuava.java
index a25faa0..9beffaf 100644
--- a/jena-base/src/main/java/org/apache/jena/atlas/lib/cache/CacheGuava.java
+++ b/jena-base/src/main/java/org/apache/jena/atlas/lib/cache/CacheGuava.java
@@ -21,31 +21,28 @@ package org.apache.jena.atlas.lib.cache;
 import java.util.Iterator ;
 import java.util.concurrent.Callable ;
 import java.util.concurrent.ExecutionException ;
-import java.util.function.BiConsumer;
+import java.util.function.BiConsumer ;
 
 import org.apache.jena.atlas.lib.Cache ;
 import org.apache.jena.atlas.logging.Log ;
 import org.apache.jena.ext.com.google.common.cache.CacheBuilder ;
 import org.apache.jena.ext.com.google.common.cache.RemovalListener ;
-import org.apache.jena.ext.com.google.common.cache.RemovalNotification ;
 
-/** Wrapper around com.google.common.cache */
+/** Wrapper around a shaded com.google.common.cache */
 final
 public class CacheGuava<K,V> implements Cache<K, V>
 {
     private BiConsumer<K, V> dropHandler = null ;
-    /*private*/ org.apache.jena.ext.com.google.common.cache.Cache<K,V> cache ;
+    private org.apache.jena.ext.com.google.common.cache.Cache<K,V> cache ;
 
     public CacheGuava(int size)
     {
-        RemovalListener<K,V> drop = new RemovalListener<K, V>() {
-            @Override
-            public void onRemoval(RemovalNotification<K, V> notification) {
-                if ( dropHandler != null )
-                    dropHandler.accept(notification.getKey(),
-                                      notification.getValue()) ;
-            }
+        RemovalListener<K,V> drop = (notification)-> {
+            if ( dropHandler != null )
+                dropHandler.accept(notification.getKey(),
+                                   notification.getValue()) ;
         } ;
+            
         cache = CacheBuilder.newBuilder()
             .maximumSize(size)
             .removalListener(drop)
@@ -54,7 +51,6 @@ public class CacheGuava<K,V> implements Cache<K, V>
             .build() ;
     }
 
-    // Change the interface to be ...
     @Override
     public V getOrFill(K key, Callable<V> filler) {
         try {


[2/4] jena git commit: Delete old dev code.

Posted by an...@apache.org.
Delete old dev code.

Project: http://git-wip-us.apache.org/repos/asf/jena/repo
Commit: http://git-wip-us.apache.org/repos/asf/jena/commit/a55e1478
Tree: http://git-wip-us.apache.org/repos/asf/jena/tree/a55e1478
Diff: http://git-wip-us.apache.org/repos/asf/jena/diff/a55e1478

Branch: refs/heads/master
Commit: a55e14780ac58e5cc08dd64424ad8307195ed885
Parents: e81ee64
Author: Andy Seaborne <an...@apache.org>
Authored: Thu May 7 10:29:40 2015 +0100
Committer: Andy Seaborne <an...@apache.org>
Committed: Thu May 7 10:29:40 2015 +0100

----------------------------------------------------------------------
 jena-tdb/src-dev/dev/Tests.java             |  32 ----
 jena-tdb/src-dev/test/BPlusTreeRun.java     |  74 ---------
 jena-tdb/src-dev/test/ByteBufferTest.java   |  78 ---------
 jena-tdb/src-dev/test/ExtHashRun.java       | 200 -----------------------
 jena-tdb/src-dev/test/RunnerExecute.java    | 119 --------------
 jena-tdb/src-dev/test/RunnerRangeIndex.java | 149 -----------------
 6 files changed, 652 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/jena/blob/a55e1478/jena-tdb/src-dev/dev/Tests.java
----------------------------------------------------------------------
diff --git a/jena-tdb/src-dev/dev/Tests.java b/jena-tdb/src-dev/dev/Tests.java
deleted file mode 100644
index 8802761..0000000
--- a/jena-tdb/src-dev/dev/Tests.java
+++ /dev/null
@@ -1,32 +0,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.
- */
-
-package dev;
-
-import org.junit.runner.RunWith ;
-import org.junit.runners.Suite ;
-
-@RunWith(Suite.class)
-@Suite.SuiteClasses( {
-})
-
-public class Tests
-{
-
-}
-

http://git-wip-us.apache.org/repos/asf/jena/blob/a55e1478/jena-tdb/src-dev/test/BPlusTreeRun.java
----------------------------------------------------------------------
diff --git a/jena-tdb/src-dev/test/BPlusTreeRun.java b/jena-tdb/src-dev/test/BPlusTreeRun.java
deleted file mode 100644
index 5e65f41..0000000
--- a/jena-tdb/src-dev/test/BPlusTreeRun.java
+++ /dev/null
@@ -1,74 +0,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.
- */
-
-package test;
-
-import org.openjena.atlas.logging.Log ;
-
-import com.hp.hpl.jena.tdb.base.file.BlockAccessMem ;
-import com.hp.hpl.jena.tdb.index.RangeIndexMaker ;
-import com.hp.hpl.jena.tdb.index.bplustree.BPlusTree ;
-import com.hp.hpl.jena.tdb.index.bplustree.BPlusTreeMaker ;
-import com.hp.hpl.jena.tdb.index.bplustree.BPlusTreeParams ;
-import com.hp.hpl.jena.tdb.sys.SystemTDB ;
-
-public class BPlusTreeRun extends RunnerRangeIndex
-{
-    static { Log.setLog4j() ; }
-    
-    static public void main(String...a)
-    {
-        new BPlusTreeRun().perform(a) ;
-    }
-    
-    @Override
-    protected RangeIndexMaker makeRangeIndexMaker()
-    {
-        BPlusTreeMaker maker = new BPlusTreeMaker(order, order, trackingBlocks) ;
-        
-        BPlusTree bpt = (BPlusTree)(maker.makeIndex()) ;
-        BPlusTreeParams param = bpt.getParams() ;
-        System.out.println(bpt.getParams()) ;
-        System.out.println("Block size = "+bpt.getParams().getCalcBlockSize()) ;
-        return maker ;
-    }
-
-    @Override
-    protected void initialize(RunType runType)
-    {
-        switch (runType)
-        {
-            case test:
-                showProgress = true ;
-                //BPlusTreeParams.checkAll() ;
-                BPlusTreeParams.CheckingTree = true ;
-                BPlusTreeParams.CheckingNode = true ;
-                SystemTDB.NullOut = true ;
-                BlockAccessMem.SafeMode = true ;
-                break ;
-            case perf:  
-                showProgress = false ;
-                BPlusTreeParams.CheckingTree = false ;
-                BPlusTreeParams.CheckingNode = false ;
-                SystemTDB.NullOut = false ;
-                BlockAccessMem.SafeMode = false ;
-                break ;
-        } 
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/jena/blob/a55e1478/jena-tdb/src-dev/test/ByteBufferTest.java
----------------------------------------------------------------------
diff --git a/jena-tdb/src-dev/test/ByteBufferTest.java b/jena-tdb/src-dev/test/ByteBufferTest.java
deleted file mode 100644
index 7012530..0000000
--- a/jena-tdb/src-dev/test/ByteBufferTest.java
+++ /dev/null
@@ -1,78 +0,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.
- */
-
-package test ;
-import java.nio.ByteBuffer;
-
-import org.junit.Test;
-
-
-public class ByteBufferTest {
-    //@Test
-    public void direct0() {
-        testDirect("direct0");
-    }
-    @Test
-    public void heap1() {
-        testHeap("heap1");
-    }
-
-    @Test
-    public void direct1() {
-        testDirect("direct1");
-    }
-    
-    @Test
-    public void heap2() {
-        testHeap("heap2");
-    }
-
-    @Test
-    public void direct2() {
-        testDirect("direct2");
-    }
-
-    private void testHeap(String name) {
-        ByteBuffer buf = ByteBuffer.allocate(2048);
-        long startTime = System.currentTimeMillis();
-        for (int i = 1048576; i > 0; i --) {
-            buf.clear();
-            while (buf.hasRemaining()) {
-                buf.getInt(buf.position());
-                buf.putInt((byte) 0);
-            }
-        }
-        long endTime = System.currentTimeMillis();
-        System.out.println(name + ": " + (endTime - startTime));
-    }
-    
-    private void testDirect(String name) {
-        ByteBuffer buf = ByteBuffer.allocateDirect(2048);
-        long startTime = System.currentTimeMillis();
-        for (int i = 1048576; i > 0; i --) {
-            buf.clear();
-            while (buf.hasRemaining()) {
-                buf.getInt(buf.position());
-                buf.putInt((byte) 0);
-            }
-        }
-        long endTime = System.currentTimeMillis();
-        System.out.println(name + ": " + (endTime - startTime));
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/jena/blob/a55e1478/jena-tdb/src-dev/test/ExtHashRun.java
----------------------------------------------------------------------
diff --git a/jena-tdb/src-dev/test/ExtHashRun.java b/jena-tdb/src-dev/test/ExtHashRun.java
deleted file mode 100644
index 0f74037..0000000
--- a/jena-tdb/src-dev/test/ExtHashRun.java
+++ /dev/null
@@ -1,200 +0,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.
- */
-
-package test;
-
-import static org.openjena.atlas.lib.RandomLib.random;
-import static org.openjena.atlas.test.Gen.permute;
-import static org.openjena.atlas.test.Gen.rand;
-import static org.openjena.atlas.test.Gen.strings;
-
-import java.io.PrintStream;
-import java.util.ArrayList;
-import java.util.Arrays;
-import java.util.List;
-
-import org.openjena.atlas.logging.Log ;
-
-
-import com.hp.hpl.jena.tdb.index.ext.ExtHash;
-import com.hp.hpl.jena.tdb.index.ext.ExtHashTestBase;
-import com.hp.hpl.jena.tdb.sys.SystemTDB;
-
-
-//import tdb.Cmd;
-
-public abstract class ExtHashRun
-{
-    static boolean showProgress = true ;
-    
-    static { Log.setLog4j() ; }
-
-    static public void main(String...a)
-    {
-        List<String> args = new ArrayList<String>(Arrays.asList(a)) ;
-        if ( args.size() == 0 )
-        {
-            System.err.println("No subcommand") ;
-            System.exit(1) ;
-        }
-        String subCmd = args.remove(0) ;
-        if ( "test".equalsIgnoreCase(subCmd) )
-            new Test().exec(args) ;
-        else if ( "perf".equalsIgnoreCase(subCmd) )
-            new Perf().exec(args) ;
-        else
-        {
-            System.err.println("Unknown subcommand: "+subCmd) ;
-            System.exit(1) ;
-        }
-    }
-    
-    public void exec(List<String> args)
-    {
-        args = processArgs(args) ;
-        int numKeys = Integer.parseInt(args.get(0)) ;
-        int iterations = Integer.parseInt(args.get(1)) ;
-        exec(numKeys, iterations) ;
-    }        
-    
-    protected abstract void exec(int numKeys, int iterations) ;
-    
-    // ---- Test
-    public static class Test extends ExtHashRun
-    {
-        @Override
-        protected void exec(int numKeys, int iterations)
-        {
-            ExtHash.Checking = true ;
-            ExtHashTestBase.randTests(10*numKeys, numKeys, iterations, showProgress) ;
-        }
-    }
-
-    // ---- Perfromance
-    public static class Perf extends ExtHashRun
-    {
-        @Override
-        public void exec(List<String> args)
-        {
-            showProgress = true ;
-            ExtHash.Checking = false ;
-            ExtHash.Logging = false ;
-            SystemTDB.NullOut = false ;
-            super.exec(args) ;
-        }
-        
-        @Override
-        protected void exec(int numKeys, int iterations)
-        {
-            RandomGen rand = new RandomGen(100*numKeys, numKeys) ;
-            org.openjena.atlas.test.RepeatExecution.repeatExecutions(rand, iterations, showProgress) ;
-        }
-    }
-    
-    static class RandomGen implements org.openjena.atlas.test.ExecGenerator
-    {
-        int maxNumKeys ;
-        int maxValue ;
-
-        RandomGen(int maxValue, int maxNumKeys)
-        {
-            if ( maxValue <= maxNumKeys )
-                throw new IllegalArgumentException("ExtHash: Max value less than number of keys") ;
-            this.maxValue = maxValue ; 
-            this.maxNumKeys = maxNumKeys ;
-        }
-
-        @Override
-        public void executeOneTest()
-        {
-            int numKeys = random.nextInt(maxNumKeys)+1 ;
-            perfTest(maxValue, numKeys) ;
-        }
-        
-        /* Performance test : print the keys if there was a problem */ 
-        public static void perfTest(int maxValue, int numKeys)
-        {
-//            if ( numKeys >= 3000 )
-//                System.err.printf("Warning: a lot of keys\n") ;
-                
-            int[] keys1 = rand(numKeys, 0, maxValue) ;
-            int[] keys2 = permute(keys1, numKeys) ;
-            try {
-                ExtHash extHash = ExtHashTestBase.create(keys1) ;
-                ExtHashTestBase.delete(extHash, keys2) ;
-            } catch (RuntimeException ex)
-            {
-                System.err.printf("int[] keys1 = {%s} ;\n", strings(keys1)) ;
-                System.err.printf("int[] keys2 = {%s}; \n", strings(keys2)) ;
-                throw ex ;
-            }
-        }
-    }
-
-    List<String> processArgs(List<String> args)
-    {
-        
-        int i = 0 ;
-        while ( args.size()>0 )
-        {
-            if ( !args.get(0).startsWith("-") )
-                break ;
-
-            String a = args.remove(0) ;
-            if ( a.startsWith("--") )
-                a = a.substring(2) ;
-            else
-                a = a.substring(1) ;
-
-            if ( a.equals("h") || a.equals("help") )
-            {
-                usage(System.out) ;
-                System.exit(0) ;
-            }
-            else if ( a.equals("v") )
-            {}
-            else if ( a.equalsIgnoreCase("check") )
-            {
-                ExtHash.Checking = true ;
-            }
-            else if ( a.equalsIgnoreCase("display") )
-            {
-                showProgress = ! showProgress ;
-            }
-            else   
-            {
-                System.err.println("Unknown argument: "+a) ;
-                System.exit(1) ;
-            }
-        }
-
-        if ( args.size() != 2 )
-        {
-            usage(System.err) ;
-            System.exit(1) ;
-        }
-        return args ;
-    }
-
-    public static void usage(PrintStream printStream)
-    {
-        printStream.println("Usage: OPTIONS NumKeys Iterations") ;
-        printStream.println("Options:") ;
-        printStream.println("   --check") ;
-    }
-}

http://git-wip-us.apache.org/repos/asf/jena/blob/a55e1478/jena-tdb/src-dev/test/RunnerExecute.java
----------------------------------------------------------------------
diff --git a/jena-tdb/src-dev/test/RunnerExecute.java b/jena-tdb/src-dev/test/RunnerExecute.java
deleted file mode 100644
index cd37329..0000000
--- a/jena-tdb/src-dev/test/RunnerExecute.java
+++ /dev/null
@@ -1,119 +0,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.
- */
-
-package test;
-
-import static org.openjena.atlas.test.Gen.permute ;
-import static org.openjena.atlas.test.Gen.rand ;
-import static org.openjena.atlas.test.Gen.strings ;
-
-import java.io.PrintStream ;
-import java.util.ArrayList ;
-import java.util.Arrays ;
-import java.util.List ;
-
-import org.openjena.atlas.test.ExecGenerator ;
-import org.openjena.atlas.test.RepeatExecution ;
-
-import com.hp.hpl.jena.tdb.index.Index ;
-import com.hp.hpl.jena.tdb.index.IndexMaker ;
-import com.hp.hpl.jena.tdb.index.IndexTestLib ;
-import com.hp.hpl.jena.tdb.index.bplustree.BPlusTreeMaker ;
-
-
-public abstract class RunnerExecute
-{
-    static enum RunType { test , perf }
-
-    static boolean showProgress = true ;
-    
-    public void perform(String...a)
-    {
-        List<String> args = new ArrayList<String>(Arrays.asList(a)) ;
-        if ( args.size() == 0 )
-        {
-            System.err.println("No subcommand") ;
-            System.exit(1) ;
-        }
-        System.out.println(args) ;
-        String subCmd = args.remove(0) ;
-        RunType runType = null ;
-        
-        if ( "test".equalsIgnoreCase(subCmd) )
-            runType = RunType.test ;
-        else if ( "perf".equalsIgnoreCase(subCmd) )
-            runType = RunType.perf ;
-        else
-        {
-            System.err.println("Unknown subcommand: "+subCmd) ;
-            System.exit(1) ;
-        }
-        
-        initialize(runType) ;
-        
-        args = processArgs(args) ;
-        int iterations = startRun(args, runType) ;
-        
-        ExecGenerator gen = execGenerator() ;
-        RepeatExecution.repeatExecutions(gen, iterations, showProgress) ;
-        finishRun() ;
-    }
-    
-    protected abstract void initialize(RunType runType) ;
-    protected abstract List<String> processArgs(List<String> args) ;
-
-    protected abstract ExecGenerator execGenerator() ;
-    protected abstract int startRun(List<String> args, RunType runType) ;
-    protected abstract void finishRun() ;
-    
-    public static void usage(PrintStream printStream)
-    {
-        printStream.println("Usage: OPTIONS Order NumKeys Iterations") ;
-        printStream.println("Options:") ;
-        printStream.println("   --display") ;
-        printStream.println("   --check (same as btree:checknode)") ;
-        printStream.println("   --bptree:check") ;
-        printStream.println("   --bptree:track") ;
-        printStream.println("   --bptree:checknode (expensive)") ;
-        printStream.println("   --bptree:log") ;
-        printStream.println("   --bptree:safe") ;
-    }
-    
-    /* Performance test : print the keys if there was a problem */ 
-    
-    public static void perfTest(int order, int maxValue, int numKeys)
-    {
-        // UNUSED.
-//        if ( numKeys >= 3000 )
-//            System.err.printf("Warning: too many keys\n") ;
-       
-        int[] keys1 = rand(numKeys, 0, maxValue) ;
-        int[] keys2 = permute(keys1, numKeys) ;
-        try {
-            IndexMaker maker = new BPlusTreeMaker(order, order, false) ;
-            Index rIndex = IndexTestLib.buildIndex(maker, keys1);
-            IndexTestLib.delete(rIndex, keys2) ;
-        } catch (RuntimeException ex)
-        {
-            System.err.printf("int order=%d ;\n", order) ;
-            System.err.printf("int[] keys1 = {%s} ;\n", strings(keys1)) ;
-            System.err.printf("int[] keys2 = {%s} ; \n", strings(keys2)) ;
-            throw ex ;
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/jena/blob/a55e1478/jena-tdb/src-dev/test/RunnerRangeIndex.java
----------------------------------------------------------------------
diff --git a/jena-tdb/src-dev/test/RunnerRangeIndex.java b/jena-tdb/src-dev/test/RunnerRangeIndex.java
deleted file mode 100644
index 38fe57e..0000000
--- a/jena-tdb/src-dev/test/RunnerRangeIndex.java
+++ /dev/null
@@ -1,149 +0,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.
- */
-
-package test;
-import java.util.List ;
-
-import org.apache.log4j.Level ;
-import org.openjena.atlas.test.ExecGenerator ;
-
-import com.hp.hpl.jena.tdb.base.file.BlockAccessMem ;
-import com.hp.hpl.jena.tdb.index.IndexTestGenerator ;
-import com.hp.hpl.jena.tdb.index.RangeIndexMaker ;
-import com.hp.hpl.jena.tdb.index.bplustree.BPlusTreeParams ;
-import com.hp.hpl.jena.tdb.sys.SystemTDB ;
-
-public abstract class RunnerRangeIndex extends RunnerExecute
-{
-    int order ;
-    int maxValue ; 
-    int maxNumKeys ;
-    
-    static boolean trackingBlocks = false ;
-    
-    protected abstract RangeIndexMaker makeRangeIndexMaker() ;
-    
-    @Override
-    protected ExecGenerator execGenerator()
-    {
-        RangeIndexMaker maker = makeRangeIndexMaker() ;
-        //new RangeIndexTestGenerator(maker, numKeys*100, numKeys) ;
-        IndexTestGenerator test = new IndexTestGenerator(maker, maxValue, maxNumKeys) ;
-        return test ;
-    }
-
-    @Override
-    protected int startRun(List<String> args, RunType runType)
-    {
-        order = Integer.parseInt(args.get(0)) ;
-        int numKeys = Integer.parseInt(args.get(1)) ;
-        int iterations = Integer.parseInt(args.get(2)) ;
-
-        maxValue = 10*numKeys ;  
-        maxNumKeys = numKeys ;
-        return iterations ;
-    }
-
-    @Override
-    protected void finishRun()
-    {}
-    
-    /** Process the arguments - return any to be done later (positionals) */  
-    @Override
-    protected List<String> processArgs(List<String> args)
-    {
-        int i = 0 ;
-        while ( args.size()>0 )
-        {
-            if ( !args.get(0).startsWith("-") )
-                break ;
-
-            String a = args.remove(0) ;
-            if ( a.startsWith("--") )
-                a = a.substring(2) ;
-            else
-                a = a.substring(1) ;
-            
-            if ( a.equals("h") || a.equals("help") )
-            {
-                usage(System.out) ;
-                System.exit(0) ;
-            }
-            else if ( a.equals("v") )
-                BPlusTreeParams.DumpTree = true ;
-            else if ( a.equalsIgnoreCase("bptree:check") )
-            {
-                BPlusTreeParams.CheckingTree = true ;
-                BPlusTreeParams.CheckingNode = false ;
-                SystemTDB.NullOut = true ;
-                BlockAccessMem.SafeMode = true ;
-            }
-            else if ( a.equalsIgnoreCase("bptree:checknode") )
-            {
-                BPlusTreeParams.CheckingTree = true ;
-                BPlusTreeParams.CheckingNode = true ;
-                SystemTDB.NullOut = true ;
-                BlockAccessMem.SafeMode = true ;
-            }
-            else if ( a.equalsIgnoreCase("bptree:log") )
-            {
-                showProgress = false ;
-                org.apache.log4j.LogManager.getLogger("bptree").setLevel(Level.DEBUG) ;
-                org.apache.log4j.LogManager.getLogger("bptree.block").setLevel(Level.INFO) ;
-            }
-            else if ( a.equalsIgnoreCase("block:log") )
-            {
-                showProgress = false ;
-                org.apache.log4j.LogManager.getLogger("bptree.block").setLevel(Level.DEBUG) ;
-            }
-            else if ( a.equalsIgnoreCase("block:safe") )
-                BlockAccessMem.SafeMode = true ;
-            else if ( a.equalsIgnoreCase("check") )
-            {
-                BPlusTreeParams.CheckingNode = false;
-                BPlusTreeParams.CheckingTree = false ;
-//                SystemTDB.NullOut = true ;
-//                FileAccessMem.SafeMode = true ;
-            }
-            else if ( a.equalsIgnoreCase("display") )
-            {
-                showProgress = ! showProgress ;
-            }
-            else if ( a.equalsIgnoreCase("bptree:track") )
-            {
-                BPlusTreeParams.CheckingTree = false ;
-                BPlusTreeParams.CheckingNode = false ;
-                trackingBlocks = true ;
-            }
-            else   
-            {
-                System.err.println("Unknown argument: "+a) ;
-                System.exit(1) ;
-            }
-        }
-        
-        if ( args.size() != 3 )
-        {
-            usage(System.err) ;
-            System.exit(1) ;
-        }
-        
-        return args ;
-    }
-    
-}


[3/4] jena git commit: openjena -> apache.jena

Posted by an...@apache.org.
openjena -> apache.jena


Project: http://git-wip-us.apache.org/repos/asf/jena/repo
Commit: http://git-wip-us.apache.org/repos/asf/jena/commit/0ec61c85
Tree: http://git-wip-us.apache.org/repos/asf/jena/tree/0ec61c85
Diff: http://git-wip-us.apache.org/repos/asf/jena/diff/0ec61c85

Branch: refs/heads/master
Commit: 0ec61c8579af4c8cbfae8df85fc534d80fb4c9b0
Parents: a55e147
Author: Andy Seaborne <an...@apache.org>
Authored: Thu May 7 10:42:27 2015 +0100
Committer: Andy Seaborne <an...@apache.org>
Committed: Thu May 7 10:42:27 2015 +0100

----------------------------------------------------------------------
 .../org/apache/jena/atlas/data/ThresholdPolicyCount.java  | 10 ----------
 .../org/apache/jena/atlas/data/ThresholdPolicyMemory.java |  5 -----
 .../main/java/org/apache/jena/riot/lang/LangRDFJSON.java  |  2 +-
 jena-arq/src/test/resources/log4j-testing.properties      |  4 +---
 jena-arq/src/test/resources/log4j.properties              |  3 +--
 .../src/main/java/org/apache/jena/atlas/lib/Cache.java    |  2 +-
 .../main/java/org/apache/jena/atlas/logging/LogCtl.java   |  3 +--
 jena-core/testing/reasoners/bugs/layeredValidation.owl    |  2 +-
 jena-csv/src/test/resources/log4j.properties              |  3 +--
 .../src/test/resources/log4j.properties                   |  3 +--
 .../src/main/java/org/apache/jena/fuseki/FusekiCmd.java   |  1 -
 .../main/java/org/apache/jena/fuseki/FusekiLogging.java   |  1 -
 jena-maven-tools/README                                   |  2 +-
 jena-maven-tools/src/it/schemagen-integration-0/pom.xml   |  4 ++--
 jena-maven-tools/src/it/schemagen-integration-1/pom.xml   |  2 +-
 jena-maven-tools/src/it/schemagen-integration-2/pom.xml   |  2 +-
 jena-maven-tools/src/it/schemagen-integration-3/pom.xml   |  2 +-
 jena-spatial/src/test/resources/geoarq-query-1.rq         |  2 +-
 .../org/apache/jena/tdb/store/bulkloader/BulkLoader.java  |  6 +-----
 .../java/org/apache/jena/tdb/extra/T_TxnDeadlockTest.java |  8 ++++----
 20 files changed, 20 insertions(+), 47 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/jena/blob/0ec61c85/jena-arq/src/main/java/org/apache/jena/atlas/data/ThresholdPolicyCount.java
----------------------------------------------------------------------
diff --git a/jena-arq/src/main/java/org/apache/jena/atlas/data/ThresholdPolicyCount.java b/jena-arq/src/main/java/org/apache/jena/atlas/data/ThresholdPolicyCount.java
index 640bdd2..1612098 100644
--- a/jena-arq/src/main/java/org/apache/jena/atlas/data/ThresholdPolicyCount.java
+++ b/jena-arq/src/main/java/org/apache/jena/atlas/data/ThresholdPolicyCount.java
@@ -36,28 +36,18 @@ public class ThresholdPolicyCount<T> implements ThresholdPolicy<T>
         reset();
     }
 
-    /* (non-Javadoc)
-     * @see org.openjena.atlas.io.ThresholdPolicy#increment(java.lang.Object)
-     */
     @Override
     public void increment(T item)
     {
         count++;
     }
 
-    /* (non-Javadoc)
-     * @see org.openjena.atlas.io.ThresholdPolicy#isThresholdExceeded()
-     */
     @Override
     public boolean isThresholdExceeded()
     {
         return (count >= threshold);
     }
 
-    /*
-     * (non-Javadoc)
-     * @see org.openjena.atlas.data.ThresholdPolicy#reset()
-     */
     @Override
     public void reset()
     {

http://git-wip-us.apache.org/repos/asf/jena/blob/0ec61c85/jena-arq/src/main/java/org/apache/jena/atlas/data/ThresholdPolicyMemory.java
----------------------------------------------------------------------
diff --git a/jena-arq/src/main/java/org/apache/jena/atlas/data/ThresholdPolicyMemory.java b/jena-arq/src/main/java/org/apache/jena/atlas/data/ThresholdPolicyMemory.java
index 15af2c4..00ea7b8 100644
--- a/jena-arq/src/main/java/org/apache/jena/atlas/data/ThresholdPolicyMemory.java
+++ b/jena-arq/src/main/java/org/apache/jena/atlas/data/ThresholdPolicyMemory.java
@@ -61,11 +61,6 @@ public class ThresholdPolicyMemory<T> implements ThresholdPolicy<T> {
         return (size >= threshold) ;
     }
 
-    /*
-     * (non-Javadoc)
-     * 
-     * @see org.openjena.atlas.data.ThresholdPolicy#reset()
-     */
     @Override
     public void reset() {
         count = 0 ;

http://git-wip-us.apache.org/repos/asf/jena/blob/0ec61c85/jena-arq/src/main/java/org/apache/jena/riot/lang/LangRDFJSON.java
----------------------------------------------------------------------
diff --git a/jena-arq/src/main/java/org/apache/jena/riot/lang/LangRDFJSON.java b/jena-arq/src/main/java/org/apache/jena/riot/lang/LangRDFJSON.java
index d529763..d495e07 100644
--- a/jena-arq/src/main/java/org/apache/jena/riot/lang/LangRDFJSON.java
+++ b/jena-arq/src/main/java/org/apache/jena/riot/lang/LangRDFJSON.java
@@ -43,7 +43,7 @@ public class LangRDFJSON extends LangBase
 		super(tokenizer, profile, dest) ;
 		if (!(tokenizer instanceof TokenizerJSON))
 		{
-			throw new IllegalArgumentException("Tokenizer for the RDF/JSON parser must be an instance of org.openjena.atlas.json.io.parser.TokenizerJSON") ;
+			throw new IllegalArgumentException("Tokenizer for the RDF/JSON parser must be an instance of "+TokenizerJSON.class.getName()) ;
 		}
 	}
 

http://git-wip-us.apache.org/repos/asf/jena/blob/0ec61c85/jena-arq/src/test/resources/log4j-testing.properties
----------------------------------------------------------------------
diff --git a/jena-arq/src/test/resources/log4j-testing.properties b/jena-arq/src/test/resources/log4j-testing.properties
index 17c9cc6..8ff6f73 100644
--- a/jena-arq/src/test/resources/log4j-testing.properties
+++ b/jena-arq/src/test/resources/log4j-testing.properties
@@ -10,9 +10,7 @@ log4j.logger.com.hp.hpl.jena.arq.info=INFO
 log4j.logger.com.hp.hpl.jena.arq.exec=INFO
 
 # Everything else in Jena
-log4j.logger.com.hp.hpl.jena=WARN
-log4j.logger.org.openjena=WARN
-log4j.logger.org.openjena.riot=INFO
+log4j.logger.org.apache.jena.riot=INFO
 
 # Apache Commons HTTP
 # May be useful to switch to DEBUG if aiming to debug any HTTP communication issues

http://git-wip-us.apache.org/repos/asf/jena/blob/0ec61c85/jena-arq/src/test/resources/log4j.properties
----------------------------------------------------------------------
diff --git a/jena-arq/src/test/resources/log4j.properties b/jena-arq/src/test/resources/log4j.properties
index 247e450..5cedb50 100644
--- a/jena-arq/src/test/resources/log4j.properties
+++ b/jena-arq/src/test/resources/log4j.properties
@@ -11,8 +11,7 @@ log4j.logger.org.apache.jena.arq.exec=INFO
 
 # Everything else in Jena
 log4j.logger.org.apache.jena=WARN
-log4j.logger.org.openjena=WARN
-log4j.logger.org.openjena.riot=INFO
+log4j.logger.org.apache.jena.riot=INFO
 
 # Apache Commons HTTP
 # May be useful to turn up to DEBUG if debugging HTTP communication issues

http://git-wip-us.apache.org/repos/asf/jena/blob/0ec61c85/jena-base/src/main/java/org/apache/jena/atlas/lib/Cache.java
----------------------------------------------------------------------
diff --git a/jena-base/src/main/java/org/apache/jena/atlas/lib/Cache.java b/jena-base/src/main/java/org/apache/jena/atlas/lib/Cache.java
index 8ebf2d7..69d6544 100644
--- a/jena-base/src/main/java/org/apache/jena/atlas/lib/Cache.java
+++ b/jena-base/src/main/java/org/apache/jena/atlas/lib/Cache.java
@@ -33,7 +33,7 @@ public interface Cache<Key, Value>
     public Value getIfPresent(Key key) ;
     
     /** Get from cache, of not present, call the {@code callable}
-     *  to try to fill the cache.
+     *  to try to fill the cache. This operation should be atomic.
      */
     public Value getOrFill(Key key, Callable<Value> callable) ;
 

http://git-wip-us.apache.org/repos/asf/jena/blob/0ec61c85/jena-base/src/main/java/org/apache/jena/atlas/logging/LogCtl.java
----------------------------------------------------------------------
diff --git a/jena-base/src/main/java/org/apache/jena/atlas/logging/LogCtl.java b/jena-base/src/main/java/org/apache/jena/atlas/logging/LogCtl.java
index ad1adce..9e067bc 100644
--- a/jena-base/src/main/java/org/apache/jena/atlas/logging/LogCtl.java
+++ b/jena-base/src/main/java/org/apache/jena/atlas/logging/LogCtl.java
@@ -179,7 +179,6 @@ public class LogCtl {
     
      , "## Everything", "log4j.rootLogger=INFO, jena.plainlevel",
      "log4j.logger.com.hp.hpl.jena=WARN",
-     "log4j.logger.org.openjena=WARN",
      "log4j.logger.org.apache.jena=WARN",
      "log4j.logger.org.apache.jena.tdb.loader=INFO"
     
@@ -195,7 +194,7 @@ public class LogCtl {
          // "handlers=java.util.logging.ConsoleHandler,org.apache.jena.atlas.logging.java.ConsoleHandlerStdout",
     
          // Atlas.
-         "handlers=org.openjena.atlas.logging.java.ConsoleHandlerStdout",
+         "handlers=org.apache.jena.atlas.logging.java.ConsoleHandlerStdout",
          "org.apache.atlas.jena.logging.java.ConsoleHandlerStdout.level=INFO",
          "java.util.logging.ConsoleHandler.formatter=atlas.logging.java.TextFormatter"
     ) ;

http://git-wip-us.apache.org/repos/asf/jena/blob/0ec61c85/jena-core/testing/reasoners/bugs/layeredValidation.owl
----------------------------------------------------------------------
diff --git a/jena-core/testing/reasoners/bugs/layeredValidation.owl b/jena-core/testing/reasoners/bugs/layeredValidation.owl
index a177cf7..8c7964b 100644
--- a/jena-core/testing/reasoners/bugs/layeredValidation.owl
+++ b/jena-core/testing/reasoners/bugs/layeredValidation.owl
@@ -1,6 +1,6 @@
 <?xml version="1.0" encoding="UTF-8"?>
 <!DOCTYPE owl [
-     <!ENTITY eg    "http://www.openjena.org/bugs#" >
+     <!ENTITY eg    "http://example.jena.apache.org/bugs#" >
      <!ENTITY rdfs  "http://www.w3.org/2000/01/rdf-schema#" >
      <!ENTITY rdf  "http://www.w3.org/1999/02/22-rdf-syntax-ns#" >
      <!ENTITY owl  "http://www.w3.org/2002/07/owl#" >

http://git-wip-us.apache.org/repos/asf/jena/blob/0ec61c85/jena-csv/src/test/resources/log4j.properties
----------------------------------------------------------------------
diff --git a/jena-csv/src/test/resources/log4j.properties b/jena-csv/src/test/resources/log4j.properties
index 247e450..5cedb50 100644
--- a/jena-csv/src/test/resources/log4j.properties
+++ b/jena-csv/src/test/resources/log4j.properties
@@ -11,8 +11,7 @@ log4j.logger.org.apache.jena.arq.exec=INFO
 
 # Everything else in Jena
 log4j.logger.org.apache.jena=WARN
-log4j.logger.org.openjena=WARN
-log4j.logger.org.openjena.riot=INFO
+log4j.logger.org.apache.jena.riot=INFO
 
 # Apache Commons HTTP
 # May be useful to turn up to DEBUG if debugging HTTP communication issues

http://git-wip-us.apache.org/repos/asf/jena/blob/0ec61c85/jena-elephas/jena-elephas-common/src/test/resources/log4j.properties
----------------------------------------------------------------------
diff --git a/jena-elephas/jena-elephas-common/src/test/resources/log4j.properties b/jena-elephas/jena-elephas-common/src/test/resources/log4j.properties
index 247e450..5cedb50 100644
--- a/jena-elephas/jena-elephas-common/src/test/resources/log4j.properties
+++ b/jena-elephas/jena-elephas-common/src/test/resources/log4j.properties
@@ -11,8 +11,7 @@ log4j.logger.org.apache.jena.arq.exec=INFO
 
 # Everything else in Jena
 log4j.logger.org.apache.jena=WARN
-log4j.logger.org.openjena=WARN
-log4j.logger.org.openjena.riot=INFO
+log4j.logger.org.apache.jena.riot=INFO
 
 # Apache Commons HTTP
 # May be useful to turn up to DEBUG if debugging HTTP communication issues

http://git-wip-us.apache.org/repos/asf/jena/blob/0ec61c85/jena-fuseki1/src/main/java/org/apache/jena/fuseki/FusekiCmd.java
----------------------------------------------------------------------
diff --git a/jena-fuseki1/src/main/java/org/apache/jena/fuseki/FusekiCmd.java b/jena-fuseki1/src/main/java/org/apache/jena/fuseki/FusekiCmd.java
index 995c5d7..6e79cee 100644
--- a/jena-fuseki1/src/main/java/org/apache/jena/fuseki/FusekiCmd.java
+++ b/jena-fuseki1/src/main/java/org/apache/jena/fuseki/FusekiCmd.java
@@ -71,7 +71,6 @@ public class FusekiCmd extends CmdARQ
           , "## Everything"
           , "log4j.rootLogger=INFO, jena.plain"
           , "log4j.logger.com.hp.hpl.jena=WARN"
-          , "log4j.logger.org.openjena=WARN"
           , "log4j.logger.org.apache.jena=WARN"
           
           , "# Server log."

http://git-wip-us.apache.org/repos/asf/jena/blob/0ec61c85/jena-fuseki2/jena-fuseki-core/src/main/java/org/apache/jena/fuseki/FusekiLogging.java
----------------------------------------------------------------------
diff --git a/jena-fuseki2/jena-fuseki-core/src/main/java/org/apache/jena/fuseki/FusekiLogging.java b/jena-fuseki2/jena-fuseki-core/src/main/java/org/apache/jena/fuseki/FusekiLogging.java
index 003b38d..1810f1e 100644
--- a/jena-fuseki2/jena-fuseki-core/src/main/java/org/apache/jena/fuseki/FusekiLogging.java
+++ b/jena-fuseki2/jena-fuseki-core/src/main/java/org/apache/jena/fuseki/FusekiLogging.java
@@ -151,7 +151,6 @@ public class FusekiLogging
              "## Most things", 
              "log4j.rootLogger=INFO, jena.plainstdout",
              "log4j.logger.com.hp.hpl.jena=WARN",
-             "log4j.logger.org.openjena=WARN",
              "log4j.logger.org.apache.jena=WARN",
 
              "# Fuseki System logs.",

http://git-wip-us.apache.org/repos/asf/jena/blob/0ec61c85/jena-maven-tools/README
----------------------------------------------------------------------
diff --git a/jena-maven-tools/README b/jena-maven-tools/README
index ba8bbb6..e7f5f03 100644
--- a/jena-maven-tools/README
+++ b/jena-maven-tools/README
@@ -15,7 +15,7 @@ Changes
 
 Version 0.4
 
-  * Moved source code from org.openjena package tree to org.apache.jena
+  * Moved source code to org.apache.jena
   * Removed some obsolete project artefacts (e.g. src/site)
   * Added license headers to conform to Apache Software Foundation policy,
     and added a rat:check target to the pom file.

http://git-wip-us.apache.org/repos/asf/jena/blob/0ec61c85/jena-maven-tools/src/it/schemagen-integration-0/pom.xml
----------------------------------------------------------------------
diff --git a/jena-maven-tools/src/it/schemagen-integration-0/pom.xml b/jena-maven-tools/src/it/schemagen-integration-0/pom.xml
index 97ccf1c..732a38d 100644
--- a/jena-maven-tools/src/it/schemagen-integration-0/pom.xml
+++ b/jena-maven-tools/src/it/schemagen-integration-0/pom.xml
@@ -1,4 +1,4 @@
-<!--
+f<!--
  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
@@ -18,7 +18,7 @@
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
   xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/maven-v4_0_0.xsd">
   <modelVersion>4.0.0</modelVersion>
-  <groupId>org.openjena.tools</groupId>
+  <groupId>org.apache.jena.tools</groupId>
   <artifactId>schemagen-test</artifactId>
   <version>@project.version@</version>
   <packaging>jar</packaging>

http://git-wip-us.apache.org/repos/asf/jena/blob/0ec61c85/jena-maven-tools/src/it/schemagen-integration-1/pom.xml
----------------------------------------------------------------------
diff --git a/jena-maven-tools/src/it/schemagen-integration-1/pom.xml b/jena-maven-tools/src/it/schemagen-integration-1/pom.xml
index bc3c94d..858da18 100644
--- a/jena-maven-tools/src/it/schemagen-integration-1/pom.xml
+++ b/jena-maven-tools/src/it/schemagen-integration-1/pom.xml
@@ -18,7 +18,7 @@
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
   xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/maven-v4_0_0.xsd">
   <modelVersion>4.0.0</modelVersion>
-  <groupId>org.openjena.tools</groupId>
+  <groupId>org.apache.jena.tools</groupId>
   <artifactId>schemagen-test</artifactId>
   <version>@project.version@</version>
   <packaging>jar</packaging>

http://git-wip-us.apache.org/repos/asf/jena/blob/0ec61c85/jena-maven-tools/src/it/schemagen-integration-2/pom.xml
----------------------------------------------------------------------
diff --git a/jena-maven-tools/src/it/schemagen-integration-2/pom.xml b/jena-maven-tools/src/it/schemagen-integration-2/pom.xml
index 225ce2f..ef4cf8f 100644
--- a/jena-maven-tools/src/it/schemagen-integration-2/pom.xml
+++ b/jena-maven-tools/src/it/schemagen-integration-2/pom.xml
@@ -18,7 +18,7 @@
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
   xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/maven-v4_0_0.xsd">
   <modelVersion>4.0.0</modelVersion>
-  <groupId>org.openjena.tools</groupId>
+  <groupId>org.apache.jena.tools</groupId>
   <artifactId>schemagen-test</artifactId>
   <version>@project.version@</version>
   <packaging>jar</packaging>

http://git-wip-us.apache.org/repos/asf/jena/blob/0ec61c85/jena-maven-tools/src/it/schemagen-integration-3/pom.xml
----------------------------------------------------------------------
diff --git a/jena-maven-tools/src/it/schemagen-integration-3/pom.xml b/jena-maven-tools/src/it/schemagen-integration-3/pom.xml
index 890aafd..a746421 100644
--- a/jena-maven-tools/src/it/schemagen-integration-3/pom.xml
+++ b/jena-maven-tools/src/it/schemagen-integration-3/pom.xml
@@ -18,7 +18,7 @@
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
   xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/maven-v4_0_0.xsd">
   <modelVersion>4.0.0</modelVersion>
-  <groupId>org.openjena.tools</groupId>
+  <groupId>org.apache.jena.tools</groupId>
   <artifactId>schemagen-test</artifactId>
   <version>@project.version@</version>
   <packaging>jar</packaging>

http://git-wip-us.apache.org/repos/asf/jena/blob/0ec61c85/jena-spatial/src/test/resources/geoarq-query-1.rq
----------------------------------------------------------------------
diff --git a/jena-spatial/src/test/resources/geoarq-query-1.rq b/jena-spatial/src/test/resources/geoarq-query-1.rq
index a189da9..7f7bb64 100644
--- a/jena-spatial/src/test/resources/geoarq-query-1.rq
+++ b/jena-spatial/src/test/resources/geoarq-query-1.rq
@@ -1,6 +1,6 @@
 PREFIX : <http://example/>
 PREFIX rdfs: <http://www.w3.org/2000/01/rdf-schema#>
-PREFIX geoarq: <http://openjena.org/GeoARQ/property#>
+PREFIX geoarq: <http://jena.apache.org/GeoARQ/property#>
 
 SELECT ?airport {
     ?s geoarq:nearby (51.3000 -2.71000) .

http://git-wip-us.apache.org/repos/asf/jena/blob/0ec61c85/jena-tdb/src/main/java/org/apache/jena/tdb/store/bulkloader/BulkLoader.java
----------------------------------------------------------------------
diff --git a/jena-tdb/src/main/java/org/apache/jena/tdb/store/bulkloader/BulkLoader.java b/jena-tdb/src/main/java/org/apache/jena/tdb/store/bulkloader/BulkLoader.java
index 0d162d2..04b4108 100644
--- a/jena-tdb/src/main/java/org/apache/jena/tdb/store/bulkloader/BulkLoader.java
+++ b/jena-tdb/src/main/java/org/apache/jena/tdb/store/bulkloader/BulkLoader.java
@@ -52,11 +52,7 @@ public class BulkLoader {
     /** Number of ticks per super tick */
     public static int       superTick             = 10 ;
 
-    // Events.
-    // private static String baseNameGeneral = "http://openjena.org/TDB/event#"
-    // ;
-
-    private static String   baseName              = "http://openjena.org/TDB/bulkload/event#" ;
+    private static String   baseName              = "http://jena.apache.org/TDB/bulkload/event#" ;
 
     public static EventType evStartBulkload       = new EventType(baseName + "start-bulkload") ;
     public static EventType evFinishBulkload      = new EventType(baseName + "finish-bulkload") ;

http://git-wip-us.apache.org/repos/asf/jena/blob/0ec61c85/jena-tdb/src/test/java/org/apache/jena/tdb/extra/T_TxnDeadlockTest.java
----------------------------------------------------------------------
diff --git a/jena-tdb/src/test/java/org/apache/jena/tdb/extra/T_TxnDeadlockTest.java b/jena-tdb/src/test/java/org/apache/jena/tdb/extra/T_TxnDeadlockTest.java
index 269a498..a3f4413 100644
--- a/jena-tdb/src/test/java/org/apache/jena/tdb/extra/T_TxnDeadlockTest.java
+++ b/jena-tdb/src/test/java/org/apache/jena/tdb/extra/T_TxnDeadlockTest.java
@@ -81,13 +81,13 @@ public class T_TxnDeadlockTest {
                             DatasetGraphTxn txnGraph =
                                     storeConnection.begin(ReadWrite.WRITE);
                             txnGraph.add(new Quad(
-                                    NodeFactory.createURI("http://openjena.org/"
+                                    NodeFactory.createURI("http://jena-example.org/"
                                             + numberGenerator.nextInt()),
-                                    NodeFactory.createURI("http://openjena.org/"
+                                    NodeFactory.createURI("http://jena-example.org/"
                                             + numberGenerator.nextInt()),
-                                    NodeFactory.createURI("http://openjena.org/"
+                                    NodeFactory.createURI("http://jena-example.org/"
                                             + numberGenerator.nextInt()),
-                                    NodeFactory.createURI("http://openjena.org/"
+                                    NodeFactory.createURI("http://jena-example.org/"
                                             + numberGenerator.nextInt())));
                             txnGraph.commit();
                             txnGraph.end();


[4/4] jena git commit: com.hp.hpl.jena -> org.apache.jena in log4j files

Posted by an...@apache.org.
com.hp.hpl.jena -> org.apache.jena in log4j files


Project: http://git-wip-us.apache.org/repos/asf/jena/repo
Commit: http://git-wip-us.apache.org/repos/asf/jena/commit/18aaf7da
Tree: http://git-wip-us.apache.org/repos/asf/jena/tree/18aaf7da
Diff: http://git-wip-us.apache.org/repos/asf/jena/diff/18aaf7da

Branch: refs/heads/master
Commit: 18aaf7dac20e50d2ea3a1f4fb678a4b83812cd6d
Parents: 0ec61c8
Author: Andy Seaborne <an...@apache.org>
Authored: Thu May 7 10:44:32 2015 +0100
Committer: Andy Seaborne <an...@apache.org>
Committed: Thu May 7 10:44:32 2015 +0100

----------------------------------------------------------------------
 jena-arq/src/test/resources/log4j-testing.properties | 5 +++--
 1 file changed, 3 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/jena/blob/18aaf7da/jena-arq/src/test/resources/log4j-testing.properties
----------------------------------------------------------------------
diff --git a/jena-arq/src/test/resources/log4j-testing.properties b/jena-arq/src/test/resources/log4j-testing.properties
index 8ff6f73..5480f7b 100644
--- a/jena-arq/src/test/resources/log4j-testing.properties
+++ b/jena-arq/src/test/resources/log4j-testing.properties
@@ -6,10 +6,11 @@ log4j.appender.stdlog.layout=org.apache.log4j.PatternLayout
 log4j.appender.stdlog.layout.ConversionPattern=%d{HH:mm:ss} %-5p %-25c{1} :: %m%n
 
 # Execution logging
-log4j.logger.com.hp.hpl.jena.arq.info=INFO
-log4j.logger.com.hp.hpl.jena.arq.exec=INFO
+log4j.logger.org.apache.jena.arq.info=INFO
+log4j.logger.org.apache.jena.arq.exec=INFO
 
 # Everything else in Jena
+log4j.logger.org.apache.jena=WARN
 log4j.logger.org.apache.jena.riot=INFO
 
 # Apache Commons HTTP