You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by je...@apache.org on 2015/12/28 16:24:36 UTC

[7/8] incubator-geode git commit: GEODE-14: Fix Rat (license header) issues for the Hibernate module

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/ed3be77d/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/HibernatePrms.java
----------------------------------------------------------------------
diff --git a/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/HibernatePrms.java b/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/HibernatePrms.java
deleted file mode 100644
index 0e4c26f..0000000
--- a/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/HibernatePrms.java
+++ /dev/null
@@ -1,44 +0,0 @@
-/*=========================================================================
- * Copyright (c) 2010-2014 Pivotal Software, Inc. All Rights Reserved.
- * This product is protected by U.S. and international copyright
- * and intellectual property laws. Pivotal products are covered by
- * one or more patents listed at http://www.pivotal.io/patents.
- *=========================================================================
- */
-package hibe;
-
-import hydra.*;
-
-public class HibernatePrms extends BasePrms {
-
-/** (boolean) True if the test execute operations within a single transaction
- *  Defaults to false
- */
-public static Long useTransactions;  
-public static boolean useTransactions() {
-  Long key = useTransactions;
-  return tasktab().booleanAt( key, tab().booleanAt( key, false ));
-}
-
-
-public static Long persistenceXml;  
-public static String getPersistenceXml() {
-  Long key = persistenceXml;
-  return tasktab().stringAt( key, tab().stringAt( key, null ));
-}
-
-
-
-public static Long cachingStrategy;  
-public static String getCachingStrategy() {
-  Long key = cachingStrategy;
-  return tasktab().stringAt( key, tab().stringAt( key, null ));
-}
-
-
-// ================================================================================
-static {
-   BasePrms.setValues(HibernatePrms.class);
-}
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/ed3be77d/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/HibernateTest.java
----------------------------------------------------------------------
diff --git a/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/HibernateTest.java b/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/HibernateTest.java
deleted file mode 100644
index 5c00063..0000000
--- a/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/HibernateTest.java
+++ /dev/null
@@ -1,418 +0,0 @@
-/*=========================================================================
- * Copyright (c) 2002-2014, Pivotal Software, Inc. All Rights Reserved.
- * This product is protected by U.S. and international copyright
- * and intellectual property laws. Pivotal products are covered by
- * more patents listed at http://www.pivotal.io/patents.
- *=========================================================================
- */
-package hibe;
-
-import hydra.*;
-
-import java.util.*;
-import java.sql.*;
-import java.io.*;
-import com.gemstone.gemfire.*;
-import com.gemstone.gemfire.cache.*;
-import com.gemstone.gemfire.internal.OSProcess;
-import com.gemstone.gemfire.internal.cache.*;
-
-import org.hibernate.FlushMode;
-import org.hibernate.Query;
-import org.hibernate.Session;
-import org.hibernate.SessionFactory;
-import org.hibernate.cfg.Configuration;
-
-/**
- * A Hydra test interacts with Hiberate APIs.
- *
- * @see HibernatePrms
- *
- * @author lhughes
- * @since 6.5
- */
-public class HibernateTest {
-    
-    /* The singleton instance of EventTest in this VM */
-    static protected HibernateTest testInstance;
-    
-    protected boolean useTransactions;
-    // cache whether this instance should perform all operations in one invocation
-    // as a single transaction.
-    protected boolean isSerialExecution;
-
-    /**
-     * STARTTASK for Hibernate (one time execution)
-     */
-    public synchronized static void HydraTask_startTask() {
-       long counter = HibernateBB.getBB().getSharedCounters().incrementAndRead(HibernateBB.STARTTASK);
-       Log.getLogWriter().info("invoked HydraTask_startTask(), STARTTASK counter = " + counter);
-    }
-    
-    /**
-     * Creates and {@linkplain #initialize initializes} the singleton
-     * instance of <code>HibernateTest</code> in this VM.
-     */
-    public synchronized static void HydraTask_initialize() throws Exception {
-       if (testInstance == null) {
-           testInstance = new HibernateTest();
-           testInstance.initialize();
-       }
-    }
-    
-    /**
-     * @see #HydraTask_initialize
-     */
-    protected void initialize() throws Exception{
-        String clientName = System.getProperty( "clientName" );
-        useTransactions = HibernatePrms.useTransactions();
-        isSerialExecution = TestConfig.tab().booleanAt(Prms.serialExecution, false);
-        long counter = HibernateBB.getBB().getSharedCounters().incrementAndRead(HibernateBB.INITTASK);
-
-
-        StringBuffer aStr = new StringBuffer();
-        aStr.append("invoked initialize() in " + clientName + "\n");
-        aStr.append("useTransactions = " + useTransactions + "\n");
-        aStr.append("isSerialExecution = " + isSerialExecution + "\n");
-        aStr.append("INITTASK counter = " + counter);
-        Log.getLogWriter().info(aStr.toString());
-        Log.getLogWriter().info("Creating DB");
-	createDatabase();
-        Log.getLogWriter().info("Created DB");
-    }
-   
-    /**
-     * Initializes the test region in the peer VMs
-     */
-    public static void createPeerCache() {
-       Cache c = CacheHelper.createCache(ConfigPrms.getCacheConfig());
-       DiskStoreFactory dsf = c.createDiskStoreFactory();
-       File f = new File("member"+RemoteTestModule.getMyVmid());
-       f.mkdir();
-       dsf.setDiskDirs(new File[] { f});
-       dsf.create(DiskStoreFactory.DEFAULT_DISK_STORE_NAME);
-    }
-    
-    /**
-     * TASK for hibernate test ... MasterController will continually
-     * assign until totalTaskTimeSec.
-     */
-    public static synchronized void HydraTask_doOps() {
-       testInstance.doOps();
-    }
-
-
-static LogWriter log = null;
-
- public static void doNothing() throws Exception { }
-
- public static void testBasic() throws Exception {
-    log = Log.getLogWriter();
-    log.info("SWAP:creating session factory In hibernateTestCase");
-    Session session = getSessionFactory().openSession();
-    log.info("SWAP:session opened");
-    // session.setFlushMode(FlushMode.COMMIT);
-    session.beginTransaction();
-    Event theEvent = new Event();
-    theEvent.setTitle("title");
-    theEvent.setDate(new java.util.Date());
-    session.save(theEvent);
-    Long id = theEvent.getId();
-    session.getTransaction().commit();
-    log.info("commit complete...doing load");
-    session.beginTransaction();
-    Event ev = (Event)session.load(Event.class, id);
-    log.info("load complete: " + ev);
-    log.info("SWAP");
-    ev.setTitle("newTitle");
-    session.save(ev);
-    log.info("commit");
-    session.getTransaction().commit();
-    log.info("save complete " + ev);
-
-    session.beginTransaction();
-    ev = (Event)session.load(Event.class, id);
-    log.info("load complete: " + ev);
-    ev.setTitle("newTitle2");
-    session.save(ev);
-    log.info("commit");
-    session.getTransaction().commit();
-    log.info("save complete " + ev);
-
-    ev = (Event)session.load(Event.class, id);
-    log.info("second load " + ev);
-    session.flush();
-    session.disconnect();
-    log.info("flush complete session:" + session);
-
-    session = getSessionFactory().openSession();
-    // ev = (Event) session.load(Event.class, id);
-    ev = (Event)session.get(Event.class, id);
-    log.info("third load " + ev);
-    //printExistingDB();
-    // System.in.read();
-    // try direct data
-
-  }
-    private void doOps() {
-       long counter = HibernateBB.getBB().getSharedCounters().incrementAndRead(HibernateBB.TASK);
-       Log.getLogWriter().info("invoked doOps(), TASK counter = " + counter);
-    }
-    
-    /**
-     * CLOSETASK for hibernate test ... 
-     */
-    public static synchronized void HydraTask_closeTask() {
-      if(testInstance!=null) {
-       testInstance.closeTask();
-      }
-    }
-
-    private void closeTask() {
-       long counter = HibernateBB.getBB().getSharedCounters().incrementAndRead(HibernateBB.CLOSETASK);
-       Log.getLogWriter().info("invoked closeTask(), CLOSETASK counter = " + counter);
-    }
-    
-    /**
-     * ENDTASK for hibernate test ... time to check BB counters!
-     */
-    public static synchronized void HydraTask_endTask() throws Exception {
-       testInstance = new HibernateTest();
-       testInstance.initialize();
-       testInstance.endTask();
-    }
-
-    private void endTask() {
-       HibernateBB.getBB().printSharedCounters();
-    }
-
-    private static SessionFactory getSessionFactory() throws Exception {
-      Configuration cfg = new Configuration();
-    cfg.setProperty("hibernate.dialect", "org.hibernate.dialect.DerbyDialect");
-    cfg.setProperty("hibernate.connection.driver_class",
-        "org.apache.derby.jdbc.EmbeddedDriver");
-    cfg.setProperty("hibernate.connection.url", "jdbc:derby:sup;create=true");
-    cfg.setProperty("hibernate.connection.pool_size", "1");
-    cfg.setProperty("hibernate.connection.autocommit", "true");
-    cfg.setProperty("hibernate.hbm2ddl.auto", "update");
-    cfg.setProperty("hibernate.cache.region.factory_class",
-        "com.gemstone.gemfire.modules.hibernate.GemFireRegionFactory");
-    cfg.setProperty("hibernate.show_sql", "true");
-    cfg.setProperty("hibernate.cache.use_query_cache", "true");
-    cfg.setProperty("gemfire.locators", getLocatorString());
-    cfg.setProperty("gemfire.mcast-port", "0");
-    String strategy = HibernatePrms.getCachingStrategy();
-    if(strategy!=null) {
-      cfg.setProperty("gemfire.default-region-attributes-id",strategy);
-    }
-    //cfg.setProperty("gemfire.log-level", "fine");
-    // cfg.setProperty("", "");
-    cfg.addClass(Person.class);
-    cfg.addClass(Event.class);
-    return cfg.buildSessionFactory();
-    }
-    
-    public static void validateQueryCacheRegion() throws Exception {
-      Cache c = CacheHelper.getCache(); 
-      Set regions = c.rootRegions();
-      Region r = c.getRegion("/gemfire.hibernateQueryResults");
-      if(r==null) {
-        throw new Exception("query cache region not found!");
-      }
-    }
-      
-   public static void validateEventPersonRegions() throws Exception {
-      validateEventPersonRegions(true);
-    }
-    public static void validateEventPersonRegionsOnPeers() throws Exception {
-      validateEventPersonRegions(false);
-    }
-    private static void validateEventPersonRegions(boolean expectLocal) throws Exception { 
-      Cache c = CacheHelper.getCache(); 
-      Set regions = c.rootRegions();
-      for (Object object : regions) {
-        System.out.println("REGION BURGER:"+((Region)object).getFullPath());
-      }
-      
-   
-      Region r = c.getRegion("/__regionConfigurationMetadata");
-      if(r==null) {
-        throw new Exception ("Metadata region is null");
-      }
-      validateRegion("/hibe.Event", expectLocal);
-      validateRegion("/hibe.Person", expectLocal);
-      validateRegion("/hibe.Person.events", expectLocal);
-      
-    }
-
-  private static void validateRegion(String regionName, boolean expectLocal) throws Exception {
-    /*
-     * REPLICATE,
-     * REPLICATE_PERSISTENT,
-     * REPLICATE_PROXY,
-     * PARTITION,
-     * PARTITION_PERSISTENT,
-     * PARTITION_REDUNDANT, 
-     * PARTITION_REDUNDANT_PERSISTENT, 
-     * PARTITION_PROXY_REDUNDANT,
-     * PARTITION_PROXY, 
-     * LOCAL, 
-     * LOCAL_PERSISTENT
-     * 
-     * HEAP_LRU
-     * 
-     */
-    String strategy = HibernatePrms.getCachingStrategy();
-    boolean isLocal = strategy.contains("LOCAL");
-    Cache c = CacheHelper.getCache(); 
-    Region r = c.getRegion(regionName);
-    if(!isLocal && r == null) {
-      throw new Exception(regionName+" region not found!");
-    } else if (isLocal) {
-      if (expectLocal && r == null) {
-        throw new Exception("expected region:"+ regionName+" to be null");
-      } else {
-        return;
-      }
-    }
-    boolean partition = false;
-    boolean persistent = false;
-    boolean overflow = false;
-    boolean heapLru = false;
-    boolean local = false;
-    boolean redundant = false;
-    
-    
-    System.out.println("VALIDATIN STRAT:"+strategy+" Regger:"+r.getClass());
-    if(strategy.indexOf("PARTITION")>-1) {
-      partition = true;
-    }
-    if(strategy.indexOf("PERSISTENT")>-1) {
-      persistent = true;
-    }
-    
-    
-    if(strategy.indexOf("OVERFLOW")>-1) {
-      overflow = true;
-    }
-    
-    
-    if(strategy.indexOf("HEAP")>-1) {
-      heapLru = true;
-    }
-
-    if(strategy.indexOf("LOCAL")>-1) {
-      local = true;
-    }
-    
-    if(strategy.indexOf("REDUNDANT")>-1) {
-      redundant = true;
-    }
-    
-    
-    
-      RegionAttributes ra = r.getAttributes();
-      if(ra.getPartitionAttributes()==null && partition) {
-        throw new Exception("Supposed to be partition, but no partition attributes");
-      } else if(!partition && ra.getPartitionAttributes()!=null) {
-        throw new Exception("Supposed to be !partition but partition attributes exist");
-      } else if(!partition) {
-        if(local) {
-          if(ra.getScope()!=Scope.LOCAL) {
-            throw new Exception("Scope should have been LOCAL, but it is:"+ra.getScope());
-          }
-        } else if(ra.getScope()!=Scope.DISTRIBUTED_ACK) {
-          throw new Exception("Scope should have been D_ACK, but it is:"+ra.getScope());
-        }
-      } else if(partition && redundant) {
-        //ok we are chill and partitioned
-        if(ra.getPartitionAttributes().getRedundantCopies()==0) {
-          throw new Exception("Redundant copies should have been greater than 0");
-        }
-      }
-      
-      if(ra.getPersistBackup() && !persistent) {
-        throw new Exception("Was supposed to be !persistent, but it is!");
-      } else if(!ra.getPersistBackup() && persistent) {
-        throw new Exception("Was supposed to be persistent, but it isn't!");
-      }
-
-      if(overflow) {
-        EvictionAttributes ea = ra.getEvictionAttributes();
-        if(ea.getAlgorithm()==EvictionAlgorithm.NONE || ea.getAction()!=EvictionAction.OVERFLOW_TO_DISK) {
-          throw new Exception("Overflow should have been on, but wasn't");
-        } 
-      } else if(!heapLru) {
-        EvictionAttributes ea = ra.getEvictionAttributes();
-        if(ea.getAlgorithm()!=EvictionAlgorithm.NONE) {
-          throw new Exception("EvictionAttributes should have been null");
-        }
-      }
-      
-      if(heapLru) {
-        EvictionAttributes ea = ra.getEvictionAttributes();
-        if(ea.getAlgorithm()==EvictionAlgorithm.NONE) {
-          throw new Exception("Eviction should have been on, but wasn't");
-        }
-        EvictionAlgorithm eaa = ea.getAlgorithm();
-        
-        if(eaa==null || eaa!=EvictionAlgorithm.LRU_HEAP) {
-          throw new Exception("heap lru should have been on, but wasn't");
-        } 
-      } else if(!overflow) {
-        EvictionAttributes ea = ra.getEvictionAttributes();
-        if(ea.getAlgorithm()!=EvictionAlgorithm.NONE) {
-          throw new Exception("EvictionAttributes should have been null");
-        }
-      }
-      
-      
-      
-      
-    }
-
-  /**
-   * Finds the locator endpoint for this VM from the shared {@link
-   * DistributedSystemBlackboard} map, if it exists.  Caches the result.
-   */
-  private static synchronized String getLocatorString() {
-      Integer vmid = new Integer(5);
-      DistributedSystemHelper.Endpoint TheLocatorEndpoint = (DistributedSystemHelper.Endpoint)DistributedSystemBlackboard.getInstance()
-                                    .getSharedMap().get(vmid);
-    return TheLocatorEndpoint.getAddress()+"["+TheLocatorEndpoint.getPort()+"]";
-  }
-
-        private static void createDatabase() throws Exception {
-                // Extract all the persistence unit properties:
-                final Properties properties = new Properties();
- 		properties.put("javax.persistence.jdbc.driver","org.apache.derby.jdbc.EmbeddedDriver");
- 		properties.put("javax.persistence.jdbc.url","jdbc:derby:/export/monaco1/users/lhughes/jpa/jpab/temp/work/derby/jpab1379523664;create=true");
-                // Load the JDBC driver:
-                String driver = properties.getProperty("javax.persistence.jdbc.driver");
-                if (driver == null) {
-                        return; // cannot connect to the server
-                }
-                Class.forName(driver).newInstance();
-
-                // Build the connection url:
-                String url = properties.getProperty("javax.persistence.jdbc.url");
-                int dbNamePos = url.lastIndexOf('/') + 1;
-                int dbNameEndPos = url.lastIndexOf(';');
-                String dbName = (dbNameEndPos < 0) ?
-                        url.substring(dbNamePos) : url.substring(dbNamePos, dbNameEndPos);
-                url = url.substring(0, dbNamePos - 1);
-                url += "?user=" + properties.getProperty("javax.persistence.jdbc.user");
-                url += "&password=" + properties.getProperty(
-                        "javax.persistence.jdbc.password");
-
-                // Try to create the database:
-                try {
-                        Connection con = DriverManager.getConnection(url);
-                        Statement s = con.createStatement();
-                        s.executeUpdate("CREATE DATABASE " + dbName);
-                }
-                catch (Exception e) {
-                        // silently ignored - database may be created automatically
-                }
-        }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/ed3be77d/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/HibernateTest2.java
----------------------------------------------------------------------
diff --git a/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/HibernateTest2.java b/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/HibernateTest2.java
deleted file mode 100644
index 686730c..0000000
--- a/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/HibernateTest2.java
+++ /dev/null
@@ -1,155 +0,0 @@
-/*=========================================================================
- * Copyright (c) 2002-2014, Pivotal Software, Inc. All Rights Reserved.
- * This product is protected by U.S. and international copyright
- * and intellectual property laws. Pivotal products are covered by
- * more patents listed at http://www.pivotal.io/patents.
- *=========================================================================
- */
-package hibe;
-
-import hydra.*;
-
-import java.util.*;
-import com.gemstone.gemfire.cache.*;
-
-/**
- * A Hydra test interacts with Hiberate APIs.
- *
- * @see HibernatePrms
- *
- * @author lhughes
- * @since 6.5
- */
-public class HibernateTest2 {
-    
-    /* The singleton instance of EventTest in this VM */
-    static protected HibernateTest2 testInstance;
-    
-    protected boolean useTransactions;
-    // cache whether this instance should perform all operations in one invocation
-    // as a single transaction.
-    protected boolean isSerialExecution;
-
-    /**
-     * STARTTASK for Hibernate (one time execution)
-     */
-    public synchronized static void HydraTask_startTask() {
-       long counter = HibernateBB.getBB().getSharedCounters().incrementAndRead(HibernateBB.STARTTASK);
-       Log.getLogWriter().info("invoked HydraTask_startTask(), STARTTASK counter = " + counter);
-    }
-
-    /**
-     * Creates and {@linkplain #initialize initializes} the singleton
-     * instance of <code>HibernateTest2</code> in this VM.
-     */
-    public synchronized static void HydraTask_initialize() {
-       if (testInstance == null) {
-           testInstance = new HibernateTest2();
-           testInstance.initialize();
-       }
-    }
-    
-    /**
-     * @see #HydraTask_initialize
-     */
-    protected void initialize() {
-        String clientName = System.getProperty( "clientName" );
-        useTransactions = HibernatePrms.useTransactions();
-        isSerialExecution = TestConfig.tab().booleanAt(Prms.serialExecution, false);
-        long counter = HibernateBB.getBB().getSharedCounters().incrementAndRead(HibernateBB.INITTASK);
-
-
-        StringBuffer aStr = new StringBuffer();
-        aStr.append("invoked initialize() in " + clientName + "\n");
-        aStr.append("useTransactions = " + useTransactions + "\n");
-        aStr.append("isSerialExecution = " + isSerialExecution + "\n");
-        aStr.append("INITTASK counter = " + counter);
-
-        Log.getLogWriter().info(aStr.toString());
-    }
-
-    /**
-     * Initializes the test region in the peer VMs
-     */
-    public static void createPeerCache() {
-       CacheHelper.createCache(ConfigPrms.getCacheConfig());
-    }
-
-    /**
-     * Initializes the test region in the bridge server VM
-     */
-    public static void initBridgeServer() {
-       // create cache from xml
-       String cacheXmlFile = "$JTESTS/gemfirePlugins/server.xml";
-       CacheHelper.createCacheFromXml(cacheXmlFile);
-       //BridgeHelper.startBridgeServer(ConfigPrms.getBridgeConfig());
-    }
-    
-    /**
-     * TASK for hibernate test ... MasterController will continually
-     * assign until totalTaskTimeSec.
-     */
-    public static synchronized void HydraTask_doOps() {
-       testInstance.doOps();
-    }
-
-    private void doOps() {
-       long counter = HibernateBB.getBB().getSharedCounters().incrementAndRead(HibernateBB.TASK);
-       Log.getLogWriter().info("invoked doOps(), TASK counter = " + counter);
-    }
-
-    /** 
-     * TASK for jpab (benchmark) test.  Simply wait for client 
-     * to publish data.
-     */
-    public static synchronized void HydraTask_waitForJPAB() {
-      MasterController.sleepForMs(10000);
-      testInstance.displayRegions();
-    }
-    
-    /**
-     * CLOSETASK for validate regions/region sizes
-     */
-    public static synchronized void HydraTask_displayRegions() {
-       testInstance.displayRegions();
-    }
-
-    private void displayRegions() {
-       long counter = HibernateBB.getBB().getSharedCounters().incrementAndRead(HibernateBB.CLOSETASK);
-
-       StringBuffer aStr = new StringBuffer();
-       Set<Region<?,?>> rootRegions = CacheHelper.getCache().rootRegions();
-       aStr.append("There are " + rootRegions.size() + " rootRegions:\n");
-
-       for (Iterator i = rootRegions.iterator(); i.hasNext(); ) {
-          Region r = (Region)i.next();
-          aStr.append(r.getName() + " has " + r.entrySet().size() + " entries\n");
-       }
-       Log.getLogWriter().info(aStr.toString());
-    }
-    
-    /**
-     * CLOSETASK for hibernate test ... 
-     */
-    public static synchronized void HydraTask_closeTask() {
-       testInstance.closeTask();
-    }
-
-    private void closeTask() {
-       long counter = HibernateBB.getBB().getSharedCounters().incrementAndRead(HibernateBB.CLOSETASK);
-       Log.getLogWriter().info("invoked closeTask(), CLOSETASK counter = " + counter);
-    }
-    
-    /**
-     * ENDTASK for hibernate test ... time to check BB counters!
-     */
-    public static synchronized void HydraTask_endTask() {
-       testInstance = new HibernateTest2();
-       testInstance.initialize();
-       testInstance.endTask();
-    }
-
-    private void endTask() {
-       HibernateBB.getBB().printSharedCounters();
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/ed3be77d/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/Person.hbm.xml
----------------------------------------------------------------------
diff --git a/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/Person.hbm.xml b/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/Person.hbm.xml
deleted file mode 100644
index b3ac67b..0000000
--- a/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/Person.hbm.xml
+++ /dev/null
@@ -1,21 +0,0 @@
-<?xml version="1.0"?>
-<!DOCTYPE hibernate-mapping PUBLIC
-        "-//Hibernate/Hibernate Mapping DTD 3.0//EN"
-        "http://hibernate.sourceforge.net/hibernate-mapping-3.0.dtd">
-
-<hibernate-mapping package="hibe">
-    <class name="Person" table="PERSON">
-        <cache usage="read-write"/>
-        <id name="id" column="PERSON_ID">
-            <generator class="native"/>
-        </id>
-        <property name="age"/>
-        <property name="firstname"/>
-        <property name="lastname"/>
-        <set name="events" table="PERSON_EVENT">
-          <cache usage="read-write"/>
-          <key column="PERSON_ID"/>
-          <many-to-many column="EVENT_ID" class="Event"/>
-        </set>
-    </class>
-</hibernate-mapping>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/ed3be77d/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/Person.java
----------------------------------------------------------------------
diff --git a/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/Person.java b/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/Person.java
deleted file mode 100644
index ad6e6a0..0000000
--- a/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/Person.java
+++ /dev/null
@@ -1,63 +0,0 @@
-/*=========================================================================
- * Copyright (c) 2010-2014 Pivotal Software, Inc. All Rights Reserved.
- * This product is protected by U.S. and international copyright
- * and intellectual property laws. Pivotal products are covered by
- * one or more patents listed at http://www.pivotal.io/patents.
- *=========================================================================
- */
-package hibe;
-
-import java.util.HashSet;
-import java.util.Set;
-
-public class Person {
-  private Long id;
-  private int age;
-  private String firstname;
-  private String lastname;
-
-  private Set<Event> events = new HashSet<Event>();
-  
-  public Person() {}
-
-  private void setId(Long id) {
-    this.id = id;
-  }
-
-  public Long getId() {
-    return id;
-  }
-
-  public void setAge(int age) {
-    this.age = age;
-  }
-
-  public int getAge() {
-    return age;
-  }
-
-  public void setFirstname(String firstname) {
-    this.firstname = firstname;
-  }
-
-  public String getFirstname() {
-    return firstname;
-  }
-
-  public void setLastname(String lastname) {
-    this.lastname = lastname;
-  }
-
-  public String getLastname() {
-    return lastname;
-  }
-
-  public void setEvents(Set<Event> events) {
-    this.events = events;
-  }
-
-  public Set<Event> getEvents() {
-    return events;
-  }
-  
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/ed3be77d/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/hibe.bt
----------------------------------------------------------------------
diff --git a/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/hibe.bt b/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/hibe.bt
deleted file mode 100644
index a6408d4..0000000
--- a/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/hibe.bt
+++ /dev/null
@@ -1,33 +0,0 @@
-  /**
-Test each RegionShortcut config possibility.
-
-These ones won't work, so they are left out:
-
-  PARTITION_PROXY,
-  PARTITION_PROXY_REDUNDANT,
-  REPLICATE_PROXY
-
-*/
-
-hibe/hibe1.conf locatorHosts=1 locatorVMsPerHost=1 locatorThreadsPerVM=1 A=client clientHosts=1 clientVMsPerHost=4 clientThreadsPerVM=1 B=hibernate hibernateHosts=1 hibernateVMsPerHost=1 hibernateThreadsPerVM=1
-   region=
-  PARTITION,
-  PARTITION_REDUNDANT,
-  PARTITION_PERSISTENT,
-  PARTITION_REDUNDANT_PERSISTENT,
-  PARTITION_OVERFLOW,
-  PARTITION_REDUNDANT_OVERFLOW,
-  PARTITION_PERSISTENT_OVERFLOW,
-  PARTITION_REDUNDANT_PERSISTENT_OVERFLOW,
-  PARTITION_HEAP_LRU,
-  PARTITION_REDUNDANT_HEAP_LRU,
-  REPLICATE,
-  REPLICATE_PERSISTENT,
-  REPLICATE_OVERFLOW,
-  REPLICATE_PERSISTENT_OVERFLOW,
-  REPLICATE_HEAP_LRU,
-  LOCAL,
-  LOCAL_PERSISTENT,
-  LOCAL_HEAP_LRU,
-  LOCAL_OVERFLOW,
-  LOCAL_PERSISTENT_OVERFLOW

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/ed3be77d/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/hibe.inc
----------------------------------------------------------------------
diff --git a/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/hibe.inc b/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/hibe.inc
deleted file mode 100644
index e724405..0000000
--- a/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/hibe.inc
+++ /dev/null
@@ -1,128 +0,0 @@
-hydra.Prms-testRequirement = "Starts a locator and p2p clients in a single DS";
-hydra.Prms-testDescription = " TBD ";
-
-INCLUDE $JTESTS/hydraconfig/hydraparams1.inc;
-INCLUDE $JTESTS/hydraconfig/topology_p2p_2_locator.inc;
-
-/**
- * Start the locators and connect them to distributed system.
- */
-INITTASK     taskClass = hydra.DistributedSystemHelper taskMethod = createLocator
-             threadGroups = locator;
-
-INITTASK     taskClass = hydra.DistributedSystemHelper taskMethod = startLocatorAndDS
-             threadGroups = locator;
-
-INITTASK     taskClass   = hibe.HibernateTest taskMethod  = HydraTask_initialize
-             threadGroups = hibernate
-             ;
-
-INITTASK     taskClass   = hibe.HibernateTest taskMethod  = createPeerCache
-             threadGroups = locator,clients
-             ;
-
-TASK         taskClass   = hibe.HibernateTest taskMethod  = doNothing
-	     threadGroups = clients,locator
-	     maxTimesToRun = 1
-             ;
-
-
-CLOSETASK    taskClass   = hibe.HibernateTest taskMethod  = validateEventPersonRegions 
-             threadGroups = hibernate
-             ;
-             
-CLOSETASK    taskClass   = hibe.HibernateTest taskMethod  = validateEventPersonRegionsOnPeers 
-             threadGroups = clients
-             ;
-
-CLOSETASK    taskClass   = hibe.HibernateTest taskMethod  = validateQueryCacheRegion 
-             threadGroups = hibernate
-             ;       
-             
-             
-             
-CLOSETASK    taskClass   = hibe.HibernateTest taskMethod  = HydraTask_closeTask 
-             threadGroups = clients
-             ;
-
-CLOSETASK    taskClass   = hydra.DistributedSystemHelper taskMethod  = stopLocator
-             threadGroups = locator;
-             ;
-
-
-hydra.Prms-totalTaskTimeSec = 600;
-hydra.Prms-maxResultWaitSec = 180;
-
-// test controls the locator (create/start/stop)
-hydra.Prms-manageLocatorAgents = false; // turn off master-managed locators
-
-// define a cache (no regions)
-hydra.ConfigPrms-cacheConfig = gemfireCache;
-hydra.CachePrms-names        = gemfireCache;
-
-// all are peers in a single DS
-hydra.GemFirePrms-distributedSystem = ds;
-
-THREADGROUP locator
-    totalThreads = fcn ${locatorHosts} * ${locatorVMsPerHost}
-                                       * ${locatorThreadsPerVM}
-                   ncf     
-    clientNames  = fcn "hydra.TestConfigFcns.generateNames
-                        (\"locator\", ${locatorHosts}, true)"
-                   ncf;    
-THREADGROUP clients
-    totalThreads = fcn ${clientHosts} * ${clientVMsPerHost}
-                                    * ${clientThreadsPerVM}
-                   ncf     
-    clientNames  = fcn "hydra.TestConfigFcns.generateNames
-                        (\"client\", ${clientHosts}, true)"
-                   ncf;
-
-THREADGROUP hibernate
-    totalThreads = fcn ${hibernateHosts} * ${hibernateVMsPerHost}
-                                    * ${hibernateThreadsPerVM}
-                   ncf
-    clientNames  = fcn "hydra.TestConfigFcns.generateNames
-                        (\"hibernate\", ${hibernateHosts}, true)"
-                   ncf;
-
-
-
-
-// Control logging in hydra controlled portion of test
-//hydra.log.LogPrms-file_logLevel = fine;
-hydra.GemFirePrms-logLevel = fine;
-//hydra.VmPrms-extraVMArgs += "-DDistributionManager.VERBOSE=true";
-//hydra.VmPrms-extraVMArgs += "-DDistributionManager.DEBUG_JAVAGROUPS=true";
-
-
-// need same jars as the jpab (jpa benchmark) 
-hydra.VmPrms-extraClassPaths += /export/java/users/java_share/jpa/jpab/lib/antlr-2.7.6.jar;
-hydra.VmPrms-extraClassPaths += /export/java/users/java_share/jpa/jpab/lib/c3p0-0.9.1.jar;
-hydra.VmPrms-extraClassPaths += /export/java/users/java_share/jpa/jpab/lib/cglib-2.2.jar;
-hydra.VmPrms-extraClassPaths += /export/java/users/java_share/jpa/jpab/lib/commons-collections-3.1.jar;
-hydra.VmPrms-extraClassPaths += /export/java/users/java_share/jpa/jpab/lib/dom4j-1.6.1.jar;
-hydra.VmPrms-extraClassPaths += /export/java/users/java_share/jpa/jpab/lib/ehcache-core-2.2.0.jar;
-hydra.VmPrms-extraClassPaths += /export/mclaren1/users/sbawaska/gemfireModules/gemfire-modules/target/gemfire-modules-2.1.jar;
-hydra.VmPrms-extraClassPaths += /home/sbawaska/.m2/repository/org/hibernate/hibernate-core/3.5.0-Final/hibernate-core-3.5.0-Final.jar;
-hydra.VmPrms-extraClassPaths += /export/java/users/java_share/jpa/jpab/lib/hibernate-index-annotation.jar;
-hydra.VmPrms-extraClassPaths += /export/java/users/java_share/jpa/jpab/lib/hibernate-jpa-2.0-api-1.0.0.Final.jar;
-hydra.VmPrms-extraClassPaths += /export/java/users/java_share/jpa/jpab/lib/infinispan-core-4.0.0.FINAL.jar;
-hydra.VmPrms-extraClassPaths += /export/java/users/java_share/jpa/jpab/lib/javassist-3.9.0.GA.jar;
-hydra.VmPrms-extraClassPaths += /export/java/users/java_share/jpa/jpab/lib/jbosscache-core-3.2.1.GA.jar;
-hydra.VmPrms-extraClassPaths += /export/java/users/java_share/jpa/jpab/lib/jdo2-index.jar;
-hydra.VmPrms-extraClassPaths += /export/java/users/java_share/jpa/jpab/lib/jpa2.jar;
-hydra.VmPrms-extraClassPaths += /export/java/users/java_share/jpa/jpab/lib/jta-1.1.jar;
-hydra.VmPrms-extraClassPaths += /export/java/users/java_share/jpa/jpab/lib/openjpa-index-annotation.jar;
-hydra.VmPrms-extraClassPaths += /export/java/users/java_share/jpa/jpab/lib/oscache-2.1.jar;
-hydra.VmPrms-extraClassPaths += /export/java/users/java_share/jpa/jpab/lib/proxool-0.8.3.jar;
-hydra.VmPrms-extraClassPaths += /export/java/users/java_share/jpa/jpab/lib/slf4j-api-1.5.8.jar;
-hydra.VmPrms-extraClassPaths += /export/java/users/java_share/jpa/jpab/lib/slf4j-jdk14-1.5.8.jar;
-hydra.VmPrms-extraClassPaths += /export/java/users/java_share/jpa/jpab/lib/swarmcache-1.0RC2.jar;
-
-// jpa test classes
-hydra.VmPrms-extraClassPaths += /export/java/users/java_share/jpa/jpab/jpab.jar;
-
-// hibernate jar from jpa/Hibernate/lib
-hydra.VmPrms-extraClassPaths += /export/java/users/java_share/jpa/jpab/jpa/Hibernate/lib/hibernate3.jar;
-hydra.VmPrms-extraClassPaths += /export/gcm/where/java/derby/derby-10.4.2.0/jars/insane/derby.jar;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/ed3be77d/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/hibe1.conf
----------------------------------------------------------------------
diff --git a/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/hibe1.conf b/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/hibe1.conf
deleted file mode 100644
index 5467a4e..0000000
--- a/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/hibe1.conf
+++ /dev/null
@@ -1,12 +0,0 @@
-hydra.Prms-testRequirement = "Basic setup for a concurrent hibernate test";
-hydra.Prms-testDescription = " TBD ";
-
-INCLUDE $JTESTS/hibe/hibe.inc;
-
-hibe.HibernatePrms-cachingStrategy = ${region};
-
-INITTASK         taskClass   = hibe.HibernateTest taskMethod  = testBasic
-             threadGroups = hibernate
-             ;
-
-             
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/ed3be77d/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/hibernate.bt
----------------------------------------------------------------------
diff --git a/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/hibernate.bt b/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/hibernate.bt
deleted file mode 100644
index 11c510e..0000000
--- a/extensions/gemfire-modules-hibernate/src/test/hydra/hibe/hibernate.bt
+++ /dev/null
@@ -1,8 +0,0 @@
-gemfirePlugins/p2pJPAB.conf 
-   locatorHosts=1 locatorVMsPerHost=1 locatorThreadsPerVM=1
-
-gemfirePlugins/hctJPAB.conf 
-   locatorHosts=1 locatorVMsPerHost=1 locatorThreadsPerVM=1
-   A=client clientHosts=1 clientVMsPerHost=4 clientThreadsPerVM=1
-   B=hibernate hibernateHosts=1 hibernateVMsPerHost=1 hibernateThreadsPerVM=1
-

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/ed3be77d/extensions/gemfire-modules-hibernate/src/test/hydra/readme.txt
----------------------------------------------------------------------
diff --git a/extensions/gemfire-modules-hibernate/src/test/hydra/readme.txt b/extensions/gemfire-modules-hibernate/src/test/hydra/readme.txt
deleted file mode 100644
index 7a12e6b..0000000
--- a/extensions/gemfire-modules-hibernate/src/test/hydra/readme.txt
+++ /dev/null
@@ -1,48 +0,0 @@
-To run and compile these tests, you need a gemfire checkout 6.5+
-In that gemfire checkout, cd to the tests directory, and create a symbolic link to the "hibe" directory in here. eg: ln -s /Users/gregp/plugins/gemfire-plugins/src/test/hydra/hibe
-
-Then apply the following patch to build.xml:
-Index: build.xml
-===================================================================
---- build.xml	(revision 34744)
-+++ build.xml	(working copy)
-@@ -866,6 +866,7 @@
-         <pathelement location="${jetty.dir}/jsp-2.1.jar"/>
-         <pathelement location="${bcel.dir}/bcel.jar"/>
-       	<pathelement location="${osgi.core.jar}"/>
-+	<pathelement
-location="/home/sbawaska/.m2/repository/org/hibernate/hibernate-core/3.5.0-Final/hibernate-core-3.5.0-Final.jar"/>
-       </classpath>
-     </javac>
- 
-@@ -936,6 +937,7 @@
-         <pathelement location="${ant.home}/lib/ant.jar"/>
-         <pathelement location="${jetty.dir}/core-3.1.1.jar"/>
-         <pathelement location="${jetty.dir}/jsp-2.1.jar"/>
-+        <pathelement
-location="/home/sbawaska/.m2/repository/org/hibernate/hibernate-core/3.5.0-Final/hibernate-core-3.5.0-Final.jar"/>
-       </classpath>
-     </javac>
- 
-@@ -996,6 +998,7 @@
-       	<include name="hyperictest/lib/*.jar"/>
-       	<include name="hyperictest/config/*.properties"/>
-         <include name="jta/*.xml"/>
-+        <include name="hibe/*.xml"/>
-         <include name="junit/runner/excluded.properties"/>
-         <include name="**/*.bt"/>
-         <include name="**/*.conf"/>
-@@ -2901,6 +2904,7 @@
-           <pathelement location="${jetty.dir}/core-3.1.1.jar"/>
-           <pathelement location="${jetty.dir}/jsp-2.1.jar"/>
- 	        <pathelement location="cobertura.jar"/>
-+          <pathelement
-location="/home/sbawaska/.m2/repository/org/hibernate/hibernate-core/3.5.0-Final/hibernate-core-3.5.0-Final.jar"/>
-         </classpath>
- 
-         <env key="GEMFIRE" value="${product.dir}"/>
-
-
-
-In hibe/hibe.inc , there are references to the modules jar in /Users/gregp that need to be changed, also, there are also references to /export/monaco1 , so those need to be reachable. 
-In gemfire checkout main dir, run ./build.sh compile-tests execute-battery -Dbt.file=`pwd`/tests/hibe/hibe.bt

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/ed3be77d/extensions/gemfire-modules-hibernate/src/test/java/com/gemstone/gemfire/modules/Event.java
----------------------------------------------------------------------
diff --git a/extensions/gemfire-modules-hibernate/src/test/java/com/gemstone/gemfire/modules/Event.java b/extensions/gemfire-modules-hibernate/src/test/java/com/gemstone/gemfire/modules/Event.java
index ed80f08..962c083 100644
--- a/extensions/gemfire-modules-hibernate/src/test/java/com/gemstone/gemfire/modules/Event.java
+++ b/extensions/gemfire-modules-hibernate/src/test/java/com/gemstone/gemfire/modules/Event.java
@@ -1,10 +1,19 @@
-/*=========================================================================
- * Copyright (c) 2010-2014 Pivotal Software, Inc. All Rights Reserved.
- * This product is protected by U.S. and international copyright
- * and intellectual property laws. Pivotal products are covered by
- * one or more patents listed at http://www.pivotal.io/patents.
- *=========================================================================
- */
+/*
+* 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 com.gemstone.gemfire.modules;
 
 import java.util.Date;
@@ -55,4 +64,4 @@ public class Event {
     	b.append("Event:id:"+id+" title:"+title+" date:"+date);
     	return b.toString();
     }
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/ed3be77d/extensions/gemfire-modules-hibernate/src/test/java/com/gemstone/gemfire/modules/HibernateJUnitTest.java
----------------------------------------------------------------------
diff --git a/extensions/gemfire-modules-hibernate/src/test/java/com/gemstone/gemfire/modules/HibernateJUnitTest.java b/extensions/gemfire-modules-hibernate/src/test/java/com/gemstone/gemfire/modules/HibernateJUnitTest.java
index 2566515..9a86f10 100644
--- a/extensions/gemfire-modules-hibernate/src/test/java/com/gemstone/gemfire/modules/HibernateJUnitTest.java
+++ b/extensions/gemfire-modules-hibernate/src/test/java/com/gemstone/gemfire/modules/HibernateJUnitTest.java
@@ -1,10 +1,19 @@
-/*=========================================================================
- * Copyright (c) 2010-2014 Pivotal Software, Inc. All Rights Reserved.
- * This product is protected by U.S. and international copyright
- * and intellectual property laws. Pivotal products are covered by
- * one or more patents listed at http://www.pivotal.io/patents.
- *=========================================================================
- */
+/*
+* 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 com.gemstone.gemfire.modules;
 
 import com.gemstone.gemfire.cache.Region;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/ed3be77d/extensions/gemfire-modules-hibernate/src/test/java/com/gemstone/gemfire/modules/Owner.java
----------------------------------------------------------------------
diff --git a/extensions/gemfire-modules-hibernate/src/test/java/com/gemstone/gemfire/modules/Owner.java b/extensions/gemfire-modules-hibernate/src/test/java/com/gemstone/gemfire/modules/Owner.java
index 3701711..92ef56f 100644
--- a/extensions/gemfire-modules-hibernate/src/test/java/com/gemstone/gemfire/modules/Owner.java
+++ b/extensions/gemfire-modules-hibernate/src/test/java/com/gemstone/gemfire/modules/Owner.java
@@ -1,10 +1,19 @@
-/*=========================================================================
- * Copyright (c) 2010-2014 Pivotal Software, Inc. All Rights Reserved.
- * This product is protected by U.S. and international copyright
- * and intellectual property laws. Pivotal products are covered by
- * one or more patents listed at http://www.pivotal.io/patents.
- *=========================================================================
- */
+/*
+* 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 com.gemstone.gemfire.modules;
 
 import java.util.ArrayList;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/ed3be77d/extensions/gemfire-modules-hibernate/src/test/java/com/gemstone/gemfire/modules/Person.java
----------------------------------------------------------------------
diff --git a/extensions/gemfire-modules-hibernate/src/test/java/com/gemstone/gemfire/modules/Person.java b/extensions/gemfire-modules-hibernate/src/test/java/com/gemstone/gemfire/modules/Person.java
index 14e6294..559363d 100644
--- a/extensions/gemfire-modules-hibernate/src/test/java/com/gemstone/gemfire/modules/Person.java
+++ b/extensions/gemfire-modules-hibernate/src/test/java/com/gemstone/gemfire/modules/Person.java
@@ -1,10 +1,19 @@
-/*=========================================================================
- * Copyright (c) 2010-2014 Pivotal Software, Inc. All Rights Reserved.
- * This product is protected by U.S. and international copyright
- * and intellectual property laws. Pivotal products are covered by
- * one or more patents listed at http://www.pivotal.io/patents.
- *=========================================================================
- */
+/*
+* 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 com.gemstone.gemfire.modules;
 
 import java.util.HashSet;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/ed3be77d/extensions/gemfire-modules-hibernate/src/test/java/com/gemstone/gemfire/modules/SecondVMTest.java
----------------------------------------------------------------------
diff --git a/extensions/gemfire-modules-hibernate/src/test/java/com/gemstone/gemfire/modules/SecondVMTest.java b/extensions/gemfire-modules-hibernate/src/test/java/com/gemstone/gemfire/modules/SecondVMTest.java
index 1eb164b..9459acc 100644
--- a/extensions/gemfire-modules-hibernate/src/test/java/com/gemstone/gemfire/modules/SecondVMTest.java
+++ b/extensions/gemfire-modules-hibernate/src/test/java/com/gemstone/gemfire/modules/SecondVMTest.java
@@ -1,10 +1,19 @@
-/*=========================================================================
- * Copyright (c) 2010-2014 Pivotal Software, Inc. All Rights Reserved.
- * This product is protected by U.S. and international copyright
- * and intellectual property laws. Pivotal products are covered by
- * one or more patents listed at http://www.pivotal.io/patents.
- *=========================================================================
- */
+/*
+* 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 com.gemstone.gemfire.modules;
 
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/ed3be77d/extensions/gemfire-modules-hibernate/src/test/resources/com/gemstone/gemfire/modules/Event.hbm.xml
----------------------------------------------------------------------
diff --git a/extensions/gemfire-modules-hibernate/src/test/resources/com/gemstone/gemfire/modules/Event.hbm.xml b/extensions/gemfire-modules-hibernate/src/test/resources/com/gemstone/gemfire/modules/Event.hbm.xml
index 17faf29..3ec08c9 100644
--- a/extensions/gemfire-modules-hibernate/src/test/resources/com/gemstone/gemfire/modules/Event.hbm.xml
+++ b/extensions/gemfire-modules-hibernate/src/test/resources/com/gemstone/gemfire/modules/Event.hbm.xml
@@ -1,4 +1,20 @@
 <?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 hibernate-mapping PUBLIC
         "-//Hibernate/Hibernate Mapping DTD 3.0//EN"
         "http://hibernate.sourceforge.net/hibernate-mapping-3.0.dtd">

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/ed3be77d/extensions/gemfire-modules-hibernate/src/test/resources/com/gemstone/gemfire/modules/Person.hbm.xml
----------------------------------------------------------------------
diff --git a/extensions/gemfire-modules-hibernate/src/test/resources/com/gemstone/gemfire/modules/Person.hbm.xml b/extensions/gemfire-modules-hibernate/src/test/resources/com/gemstone/gemfire/modules/Person.hbm.xml
index a4810d7..7c28734 100644
--- a/extensions/gemfire-modules-hibernate/src/test/resources/com/gemstone/gemfire/modules/Person.hbm.xml
+++ b/extensions/gemfire-modules-hibernate/src/test/resources/com/gemstone/gemfire/modules/Person.hbm.xml
@@ -1,4 +1,20 @@
 <?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 hibernate-mapping PUBLIC
         "-//Hibernate/Hibernate Mapping DTD 3.0//EN"
         "http://hibernate.sourceforge.net/hibernate-mapping-3.0.dtd">

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/ed3be77d/extensions/gemfire-modules-hibernate/src/test/resources/tomcat/conf/tomcat-users.xml
----------------------------------------------------------------------
diff --git a/extensions/gemfire-modules-hibernate/src/test/resources/tomcat/conf/tomcat-users.xml b/extensions/gemfire-modules-hibernate/src/test/resources/tomcat/conf/tomcat-users.xml
deleted file mode 100644
index 6c9f217..0000000
--- a/extensions/gemfire-modules-hibernate/src/test/resources/tomcat/conf/tomcat-users.xml
+++ /dev/null
@@ -1,3 +0,0 @@
-<?xml version='1.0' encoding='utf-8'?>
-<tomcat-users>
-</tomcat-users>

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/ed3be77d/gradle/rat.gradle
----------------------------------------------------------------------
diff --git a/gradle/rat.gradle b/gradle/rat.gradle
index 69b69d3..2720bea 100644
--- a/gradle/rat.gradle
+++ b/gradle/rat.gradle
@@ -80,6 +80,7 @@ rat {
     'extensions/gemfire-modules/src/test/resources/com/gemstone/gemfire/modules/Person.hbm.xml',
     'extensions/gemfire-modules/src/test/resources/log4j.properties',
     'extensions/gemfire-modules-tomcat7/src/test/resources/tomcat/conf/tomcat-users.xml',
+    'extensions/gemfire-modules-hibernate/src/test/resources/log4j.properties',
 
     // these are test files that don't expect the first element to be a comment
     'gemfire-core/src/test/resources/com/gemstone/gemfire/management/internal/configuration/domain/CacheElementJUnitTest.xml',