You are viewing a plain text version of this content. The canonical link for it is here.
Posted to scm@geronimo.apache.org by vi...@apache.org on 2011/02/17 09:24:04 UTC

svn commit: r1071543 [5/15] - in /geronimo/daytrader/trunk: ./ assemblies/javaee/ javaee6/ javaee6/assemblies/ javaee6/assemblies/daytrader-ear/ javaee6/assemblies/daytrader-ear/src/ javaee6/assemblies/daytrader-ear/src/main/ javaee6/assemblies/daytrad...

Added: geronimo/daytrader/trunk/javaee6/modules/core/src/main/java/org/apache/geronimo/daytrader/javaee6/core/direct/TradeJPADirect.java
URL: http://svn.apache.org/viewvc/geronimo/daytrader/trunk/javaee6/modules/core/src/main/java/org/apache/geronimo/daytrader/javaee6/core/direct/TradeJPADirect.java?rev=1071543&view=auto
==============================================================================
--- geronimo/daytrader/trunk/javaee6/modules/core/src/main/java/org/apache/geronimo/daytrader/javaee6/core/direct/TradeJPADirect.java (added)
+++ geronimo/daytrader/trunk/javaee6/modules/core/src/main/java/org/apache/geronimo/daytrader/javaee6/core/direct/TradeJPADirect.java Thu Feb 17 08:23:57 2011
@@ -0,0 +1,1041 @@
+/**
+ *  Licensed to the Apache Software Foundation (ASF) under one or more
+ *  contributor license agreements.  See the NOTICE file distributed with
+ *  this work for additional information regarding copyright ownership.
+ *  The ASF licenses this file to You under the Apache License, Version 2.0
+ *  (the "License"); you may not use this file except in compliance with
+ *  the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ *  Unless required by applicable law or agreed to in writing, software
+ *  distributed under the License is distributed on an "AS IS" BASIS,
+ *  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ *  See the License for the specific language governing permissions and
+ *  limitations under the License.
+ */
+package org.apache.geronimo.daytrader.javaee6.core.direct;
+
+import java.math.BigDecimal;
+import java.sql.Timestamp;
+import java.util.ArrayList;
+import java.util.Collection;
+import java.util.Iterator;
+
+import javax.persistence.EntityManager;
+import javax.persistence.EntityManagerFactory;
+import javax.persistence.Persistence;
+import javax.persistence.PersistenceUnit;
+import javax.persistence.Query;
+
+import org.apache.geronimo.daytrader.javaee6.entities.*;
+import org.apache.geronimo.daytrader.javaee6.core.api.*;
+import org.apache.geronimo.daytrader.javaee6.core.beans.*;
+
+import org.apache.geronimo.daytrader.javaee6.utils.*;
+
+/**
+ * TradeJPADirect uses JPA to implement the business methods of the Trade online
+ * broker application. These business methods represent the features and
+ * operations that can be performed by customers of the brokerage such as login,
+ * logout, get a stock quote, buy or sell a stock, etc. and are specified in the
+ * {@link org.apache.geronimo.samples.daytrader.TradeServices} interface
+ * 
+ * Note: In order for this class to be thread-safe, a new TradeJPA must be
+ * created for each call to a method from the TradeInterface interface.
+ * Otherwise, pooled connections may not be released.
+ * 
+ * @see org.apache.geronimo.samples.daytrader.TradeServices
+ * 
+ */
+
+public class TradeJPADirect implements TradeServices, TradeDBServices {
+
+    @PersistenceUnit(unitName="daytrader")
+    private static EntityManagerFactory emf;
+
+    private static BigDecimal ZERO = new BigDecimal(0.0);
+
+    private static boolean initialized = false;
+    
+    private Integer soldholdingID = null;
+    private Object soldholdingIDlock = new Object();
+
+    /**
+     * Zero arg constructor for TradeJPADirect
+     */
+    public TradeJPADirect() {
+
+
+        // FIXME - Why is this here???
+        TradeConfig.setPublishQuotePriceChange(false);
+        if (emf == null) {
+            Log.error("TradeJPADirect.ctor:  Calling createEntityManagerFactory()");
+            // creating entity manager factory. the persistence xml must be
+            // place under src/META-INF/
+            emf = Persistence.createEntityManagerFactory("daytrader");
+        }
+
+        if (initialized == false)
+            init();
+    }
+
+    public void setEmf (EntityManagerFactory em) { 
+        emf = em;
+    }
+
+    public static synchronized void init() {
+        if (initialized)
+            return;
+        if (Log.doTrace())
+            Log.trace("TradeJPADirect:init -- *** initializing");  
+
+        TradeConfig.setPublishQuotePriceChange(false);
+
+        if (Log.doTrace())
+            Log.trace("TradeJPADirect:init -- +++ initialized");
+
+        initialized = true;
+    }
+
+    public static void destroy() {
+        try {
+            if (!initialized)
+                return;
+            Log.trace("TradeJPADirect:destroy");
+        }
+        catch (Exception e) {
+            Log.error("TradeJPADirect:destroy", e);
+        }
+
+    }
+
+    public MarketSummaryDataBean getMarketSummary() {
+        MarketSummaryDataBean marketSummaryData;
+
+        /*
+         * Creating entiManager
+         */
+        EntityManager entityManager = emf.createEntityManager();
+
+        try {
+            if (Log.doTrace())
+                Log.trace("TradeJPADirect:getMarketSummary -- getting market summary");
+
+            // Find Trade Stock Index Quotes (Top 100 quotes)
+            // ordered by their change in value
+            Collection<QuoteDataBean> quotes;
+
+            Query query = entityManager
+                          .createNamedQuery("quoteejb.quotesByChange");
+            quotes = query.getResultList();
+
+            QuoteDataBean[] quoteArray = (QuoteDataBean[]) quotes.toArray(new QuoteDataBean[quotes.size()]);
+            ArrayList<QuoteDataBean> topGainers = new ArrayList<QuoteDataBean>(
+                                                                              5);
+            ArrayList<QuoteDataBean> topLosers = new ArrayList<QuoteDataBean>(5);
+            BigDecimal TSIA = FinancialUtils.ZERO;
+            BigDecimal openTSIA = FinancialUtils.ZERO;
+            double totalVolume = 0.0;
+
+            if (quoteArray.length > 5) {
+                for (int i = 0; i < 5; i++)
+                    topGainers.add(quoteArray[i]);
+                for (int i = quoteArray.length - 1; i >= quoteArray.length - 5; i--)
+                    topLosers.add(quoteArray[i]);
+
+                for (QuoteDataBean quote : quoteArray) {
+                    BigDecimal price = quote.getPrice();
+                    BigDecimal open = quote.getOpen();
+                    double volume = quote.getVolume();
+                    TSIA = TSIA.add(price);
+                    openTSIA = openTSIA.add(open);
+                    totalVolume += volume;
+                }
+                TSIA = TSIA.divide(new BigDecimal(quoteArray.length),
+                                   FinancialUtils.ROUND);
+                openTSIA = openTSIA.divide(new BigDecimal(quoteArray.length),
+                                           FinancialUtils.ROUND);
+            }
+
+            marketSummaryData = new MarketSummaryDataBean(TSIA, openTSIA,
+                                                          totalVolume, topGainers, topLosers);
+        }
+        catch (Exception e) {
+            Log.error("TradeJPADirect:getMarketSummary", e);
+            throw new RuntimeException("TradeJPADirect:getMarketSummary -- error ", e);
+        } finally {
+            entityManager.close();
+        }
+
+        return marketSummaryData;
+    }
+
+    public OrderDataBean buy(String userID, String symbol, double quantity, int orderProcessingMode) {
+        OrderDataBean order = null;
+        BigDecimal total;
+        /*
+         * creating entitymanager
+         */
+        EntityManager entityManager = emf.createEntityManager();
+
+        try {
+            if (Log.doTrace())
+                Log.trace("TradeJPADirect:buy", userID, symbol, quantity, orderProcessingMode);
+
+            entityManager.getTransaction().begin();
+
+            AccountProfileDataBean profile = entityManager.find(
+                                                               AccountProfileDataBean.class, userID);
+            AccountDataBean account = profile.getAccount();
+
+            QuoteDataBean quote = entityManager.find(QuoteDataBean.class,
+                                                     symbol);
+
+            HoldingDataBean holding = null; // The holding will be created by this buy order
+
+            order = createOrder(account, quote, holding, "buy", quantity, entityManager);
+
+            // order = createOrder(account, quote, holding, "buy", quantity);
+            // UPDATE - account should be credited during completeOrder
+
+            BigDecimal price = quote.getPrice();
+            BigDecimal orderFee = order.getOrderFee();
+            BigDecimal balance = account.getBalance();
+            total = (new BigDecimal(quantity).multiply(price)).add(orderFee);
+            account.setBalance(balance.subtract(total));
+
+            // commit the transaction before calling completeOrder
+            entityManager.getTransaction().commit();
+
+            if (orderProcessingMode == TradeConfig.SYNCH)
+                completeOrder(order.getOrderID(), false);
+            else if (orderProcessingMode == TradeConfig.ASYNCH_2PHASE)
+                queueOrder(order.getOrderID(), true);
+        }
+        catch (Exception e) {
+            Log.error("TradeJPADirect:buy(" + userID + "," + symbol + "," + quantity + ") --> failed", e);
+            /* On exception - cancel the order */
+            // TODO figure out how to do this with JPA
+            if (order != null)
+                order.cancel();
+
+            entityManager.getTransaction().rollback();
+
+            // throw new EJBException(e);
+            throw new RuntimeException(e);
+        } finally {
+            if (entityManager != null) {
+                entityManager.close();
+                entityManager = null;
+            }
+
+        }
+
+        // after the purchase or sell of a stock, update the stocks volume and
+        // price
+        updateQuotePriceVolume(symbol, TradeConfig.getRandomPriceChangeFactor(), quantity);
+
+        return order;
+    }
+
+    public OrderDataBean sell(String userID, Integer holdingID,
+                              int orderProcessingMode) {
+        EntityManager entityManager = emf.createEntityManager();
+
+        OrderDataBean order = null;
+        BigDecimal total;
+        try {
+            entityManager.getTransaction().begin();
+            if (Log.doTrace())
+                Log.trace("TradeJPADirect:sell", userID, holdingID, orderProcessingMode);
+
+            AccountProfileDataBean profile = entityManager.find(
+                                                               AccountProfileDataBean.class, userID);
+
+            AccountDataBean account = profile.getAccount();
+            HoldingDataBean holding = entityManager.find(HoldingDataBean.class,
+                                                         holdingID);
+
+            if (holding == null) {
+                Log.error("TradeJPADirect:sell User " + userID
+                          + " attempted to sell holding " + holdingID
+                          + " which has already been sold");
+
+                OrderDataBean orderData = new OrderDataBean();
+                orderData.setOrderStatus("cancelled");
+
+                entityManager.persist(orderData);
+                entityManager.getTransaction().commit();
+                return orderData;
+            }
+
+            QuoteDataBean quote = holding.getQuote();
+            double quantity = holding.getQuantity();
+
+            order = createOrder(account, quote, holding, "sell", quantity,
+                                entityManager);
+            // UPDATE the holding purchase data to signify this holding is
+            // "inflight" to be sold
+            // -- could add a new holdingStatus attribute to holdingEJB
+            holding.setPurchaseDate(new java.sql.Timestamp(0));
+
+            // UPDATE - account should be credited during completeOrder
+            BigDecimal price = quote.getPrice();
+            BigDecimal orderFee = order.getOrderFee();
+            BigDecimal balance = account.getBalance();
+            total = (new BigDecimal(quantity).multiply(price)).subtract(orderFee);
+
+            account.setBalance(balance.add(total));
+
+            // commit the transaction before calling completeOrder
+            entityManager.getTransaction().commit();
+
+            if (orderProcessingMode == TradeConfig.SYNCH) {                
+                synchronized(soldholdingIDlock) {
+                    this.soldholdingID = holding.getHoldingID();
+                    completeOrder(order.getOrderID(), false);
+                }                
+            } else if (orderProcessingMode == TradeConfig.ASYNCH_2PHASE)
+                queueOrder(order.getOrderID(), true);
+
+        }
+        catch (Exception e) {
+            Log.error("TradeJPADirect:sell(" + userID + "," + holdingID + ") --> failed", e);
+            // TODO figure out JPA cancel
+            if (order != null)
+                order.cancel();
+
+            entityManager.getTransaction().rollback();
+
+            throw new RuntimeException("TradeJPADirect:sell(" + userID + "," + holdingID + ")", e);
+        } finally {
+            if (entityManager != null) {
+                entityManager.close();
+                entityManager = null;
+            }
+        }
+
+        if (!(order.getOrderStatus().equalsIgnoreCase("cancelled")))
+            //after the purchase or sell of a stock, update the stocks volume and price
+            updateQuotePriceVolume(order.getSymbol(), TradeConfig.getRandomPriceChangeFactor(), order.getQuantity());
+
+        return order;
+    }
+
+    public void queueOrder(Integer orderID, boolean twoPhase) {
+        Log
+        .error("TradeJPADirect:queueOrder() not implemented for this runtime mode");
+        throw new UnsupportedOperationException(
+                                               "TradeJPADirect:queueOrder() not implemented for this runtime mode");
+    }
+
+    public OrderDataBean completeOrder(Integer orderID, boolean twoPhase)
+    throws Exception {
+        EntityManager entityManager = emf.createEntityManager();
+        OrderDataBean order = null;
+
+        if (Log.doTrace())
+            Log.trace("TradeJPADirect:completeOrder", orderID + " twoPhase=" + twoPhase);
+
+        order = entityManager.find(OrderDataBean.class, orderID);
+        order.getQuote();
+
+        if (order == null) {
+            Log.error("TradeJPADirect:completeOrder -- Unable to find Order " + orderID + " FBPK returned " + order);
+            return null;
+        }
+
+        if (order.isCompleted()) {
+            throw new RuntimeException("Error: attempt to complete Order that is already completed\n" + order);
+        }
+
+        AccountDataBean account = order.getAccount();
+        QuoteDataBean quote = order.getQuote();
+        HoldingDataBean holding = null;
+        if(order.isSell() && this.soldholdingID != null){
+            holding = entityManager.find(HoldingDataBean.class, this.soldholdingID);
+        }        
+        BigDecimal price = order.getPrice();
+        double quantity = order.getQuantity();
+
+        //String userID = account.getProfile().getUserID();
+
+        if (Log.doTrace())
+            Log.trace("TradeJPADirect:completeOrder--> Completing Order "
+                      + order.getOrderID() + "\n\t Order info: " + order
+                      + "\n\t Account info: " + account + "\n\t Quote info: "
+                      + quote + "\n\t Holding info: " + holding);
+
+        HoldingDataBean newHolding = null;        
+        
+        if (order.isBuy()) {
+            /*
+             * Complete a Buy operation - create a new Holding for the Account -
+             * deduct the Order cost from the Account balance
+             */
+            //newHolding = createHolding(account, quote, quantity, price, entityManager);
+            entityManager.getTransaction().begin();
+            newHolding = new HoldingDataBean(quantity, price, new Timestamp(System.currentTimeMillis()), account, quote);
+            entityManager.persist(newHolding);            
+            
+            if (newHolding != null) {
+                order.setHolding(newHolding);
+            }
+            entityManager.getTransaction().commit();
+        }
+
+        try {
+            if (order.isSell()) {
+                /*
+                 * Complete a Sell operation - remove the Holding from the Account -
+                 * deposit the Order proceeds to the Account balance
+                 */
+                if (holding == null) {
+                    Log.error("TradeJPADirect:completeOrder -- Unable to sell order " + order.getOrderID() + " holding already sold");
+                    order.cancel();                    
+                    return order;
+                }
+                else {
+                    entityManager.getTransaction().begin();
+                    entityManager.remove(holding);                    
+                    order.setHolding(null);
+                    this.soldholdingID = null;
+                    entityManager.getTransaction().commit();
+                }
+            }
+
+            order.setOrderStatus("closed");
+
+            order.setCompletionDate(new java.sql.Timestamp(System.currentTimeMillis()));
+
+            if (Log.doTrace())
+                Log.trace("TradeJPADirect:completeOrder--> Completed Order "
+                          + order.getOrderID() + "\n\t Order info: " + order
+                          + "\n\t Account info: " + account + "\n\t Quote info: "
+                          + quote + "\n\t Holding info: " + holding);
+
+        }
+        catch (Exception e) {
+            e.printStackTrace();
+            entityManager.getTransaction().rollback();
+        } finally {
+            if (entityManager != null) {
+                entityManager.close();
+                entityManager = null;
+            }
+        }
+
+        return order;
+    }
+
+    public void cancelOrder(Integer orderID, boolean twoPhase) {
+        EntityManager entityManager = emf.createEntityManager();
+
+        if (Log.doTrace())
+            Log.trace("TradeJPADirect:cancelOrder", orderID + " twoPhase=" + twoPhase);
+
+        OrderDataBean order = entityManager.find(OrderDataBean.class, orderID);
+        /*
+         * managed transaction
+         */
+        try {
+            entityManager.getTransaction().begin();
+            order.cancel();
+            entityManager.getTransaction().commit();
+        }
+        catch (Exception e) {
+            entityManager.getTransaction().rollback();
+        } finally {
+            entityManager.close();
+        }
+    }
+
+    public void orderCompleted(String userID, Integer orderID) {
+        if (Log.doActionTrace())
+            Log.trace("TradeAction:orderCompleted", userID, orderID);
+        if (Log.doTrace())
+            Log.trace("OrderCompleted", userID, orderID);
+    }
+
+    public Collection<OrderDataBean> getOrders(String userID) {
+        if (Log.doTrace())
+            Log.trace("TradeJPADirect:getOrders", userID);
+        EntityManager entityManager = emf.createEntityManager();
+        AccountProfileDataBean profile = entityManager.find(
+                                                           AccountProfileDataBean.class, userID);
+        AccountDataBean account = profile.getAccount();
+        entityManager.close();
+        return account.getOrders();
+    }
+
+    public Collection<OrderDataBean> getClosedOrders(String userID) {
+
+        if (Log.doTrace())
+            Log.trace("TradeJPADirect:getClosedOrders", userID);
+        EntityManager entityManager = emf.createEntityManager();
+
+        try {
+
+            // Get the primary keys for all the closed Orders for this
+            // account.
+            /*
+             * managed transaction
+             */
+            //entityManager.getTransaction().begin();
+            Query query = entityManager
+                          .createNamedQuery("orderejb.closedOrders");
+            query.setParameter("userID", userID);
+
+            //entityManager.getTransaction().commit();
+            Collection results = query.getResultList();
+            Iterator itr = results.iterator();
+            // entityManager.joinTransaction();
+            // Spin through the orders to populate the lazy quote fields
+            while (itr.hasNext()) {
+                OrderDataBean thisOrder = (OrderDataBean) itr.next();
+                thisOrder.getQuote();
+            }
+
+            if (TradeConfig.jpaLayer == TradeConfig.OPENJPA) {
+                Query updateStatus = entityManager
+                                     .createNamedQuery("orderejb.completeClosedOrders");
+                /*
+                 * managed transaction
+                 */
+                try {
+                    entityManager.getTransaction().begin();
+                    updateStatus.setParameter("userID", userID);
+
+                    updateStatus.executeUpdate();
+                    entityManager.getTransaction().commit();
+                }
+                catch (Exception e) {
+                    entityManager.getTransaction().rollback();
+                    entityManager.close();
+                    entityManager = null;
+                }
+            }
+            else if (TradeConfig.jpaLayer == TradeConfig.HIBERNATE) {
+                try {
+                /*
+                 * Add logic to do update orders operation, because JBoss5'
+                 * Hibernate 3.3.1GA DB2Dialect and MySQL5Dialect do not work
+                 * with annotated query "orderejb.completeClosedOrders" defined
+                 * in OrderDatabean
+                 */
+                Query findaccountid = entityManager
+                                      .createNativeQuery(
+                                                        "select "
+                                                        + "a.ACCOUNTID, "
+                                                        + "a.LOGINCOUNT, "
+                                                        + "a.LOGOUTCOUNT, "
+                                                        + "a.LASTLOGIN, "
+                                                        + "a.CREATIONDATE, "
+                                                        + "a.BALANCE, "
+                                                        + "a.OPENBALANCE, "
+                                                        + "a.PROFILE_USERID "
+                                                        + "from accountejb a where a.profile_userid = ?",
+                                                        AccountDataBean.class);
+                findaccountid.setParameter(1, userID);
+                AccountDataBean account = (AccountDataBean) findaccountid.getSingleResult();
+                Integer accountid = account.getAccountID();
+                Query updateStatus = entityManager.createNativeQuery("UPDATE orderejb o SET o.orderStatus = 'completed' WHERE "
+                                                                     + "o.orderStatus = 'closed' AND o.ACCOUNT_ACCOUNTID  = ?");
+                updateStatus.setParameter(1, accountid.intValue());
+                entityManager.getTransaction().begin();
+                updateStatus.executeUpdate();
+                entityManager.getTransaction().commit();
+                } catch (Exception e){
+                    entityManager.getTransaction().rollback();
+                    entityManager.close();
+                    entityManager = null;
+                }
+            }
+            
+            if (entityManager != null) {
+                entityManager.close();
+                entityManager = null;
+            }
+            return results;
+        }
+        catch (Exception e) {
+            Log.error("TradeJPADirect.getClosedOrders", e);
+            entityManager.close();
+            entityManager = null;
+            throw new RuntimeException(
+                                      "TradeJPADirect.getClosedOrders - error", e);
+
+        } finally {
+            if (entityManager != null) {
+                entityManager.close();
+                entityManager = null;
+            }
+        }
+
+    }
+
+    public QuoteDataBean createQuote(String symbol, String companyName,
+                                     BigDecimal price) {
+        EntityManager entityManager = emf.createEntityManager();
+        try {
+            QuoteDataBean quote = new QuoteDataBean(symbol, companyName, 0, price, price, price, price, 0);
+            /*
+             * managed transaction
+             */
+            try {
+                entityManager.getTransaction().begin();
+                entityManager.persist(quote);
+                entityManager.getTransaction().commit();
+            }
+            catch (Exception e) {
+                entityManager.getTransaction().rollback();
+            }
+
+            if (Log.doTrace())
+                Log.trace("TradeJPADirect:createQuote-->" + quote);
+
+            if (entityManager != null) {
+                entityManager.close();
+                entityManager = null;
+            }
+            return quote;
+        }
+        catch (Exception e) {
+            Log.error("TradeJPADirect:createQuote -- exception creating Quote", e);
+            entityManager.close();
+            entityManager = null;
+            throw new RuntimeException(e);
+        } finally {
+            if (entityManager != null) {
+                entityManager.close();
+                entityManager = null;
+            }
+        }
+
+    }
+
+    public QuoteDataBean getQuote(String symbol) {
+        if (Log.doTrace())
+            Log.trace("TradeJPADirect:getQuote", symbol);
+        EntityManager entityManager = emf.createEntityManager();
+
+        QuoteDataBean qdb = entityManager.find(QuoteDataBean.class, symbol);
+
+        if (entityManager != null) {
+            entityManager.close();
+            entityManager = null;
+        }
+        return qdb;
+    }
+
+    public Collection<QuoteDataBean> getAllQuotes() {
+        if (Log.doTrace())
+            Log.trace("TradeJPADirect:getAllQuotes");
+        EntityManager entityManager = emf.createEntityManager();
+
+        Query query = entityManager.createNamedQuery("quoteejb.allQuotes");
+
+        if (entityManager != null) {
+            entityManager.close();
+            entityManager = null;
+
+        }
+        return query.getResultList();
+    }
+
+    public QuoteDataBean updateQuotePriceVolume(String symbol,
+                                                BigDecimal changeFactor, double sharesTraded) {
+        if (!TradeConfig.getUpdateQuotePrices())
+            return new QuoteDataBean();
+
+        if (Log.doTrace())
+            Log.trace("TradeJPADirect:updateQuote", symbol, changeFactor);
+
+        /*
+         * Add logic to determine JPA layer, because JBoss5' Hibernate 3.3.1GA
+         * DB2Dialect and MySQL5Dialect do not work with annotated query
+         * "quoteejb.quoteForUpdate" defined in QuoteDatabean
+         */
+        EntityManager entityManager = emf.createEntityManager();
+        QuoteDataBean quote = null;
+        if (TradeConfig.jpaLayer == TradeConfig.HIBERNATE) {
+            quote = entityManager.find(QuoteDataBean.class, symbol);
+        } else if (TradeConfig.jpaLayer == TradeConfig.OPENJPA) {
+  
+            Query q = entityManager.createNamedQuery("quoteejb.quoteForUpdate");
+            q.setParameter(1, symbol);
+  
+            quote = (QuoteDataBean) q.getSingleResult();
+        }
+
+        BigDecimal oldPrice = quote.getPrice();
+
+        if (quote.getPrice().equals(TradeConfig.PENNY_STOCK_PRICE)) {
+            changeFactor = TradeConfig.PENNY_STOCK_RECOVERY_MIRACLE_MULTIPLIER;
+        }
+
+        BigDecimal newPrice = changeFactor.multiply(oldPrice).setScale(2, BigDecimal.ROUND_HALF_UP);
+
+        /*
+         * managed transaction
+         */
+
+        try {
+
+            quote.setPrice(newPrice);
+            quote.setVolume(quote.getVolume() + sharesTraded);
+            quote.setChange((newPrice.subtract(quote.getOpen()).doubleValue()));
+
+            entityManager.getTransaction().begin();
+            entityManager.merge(quote);
+            entityManager.getTransaction().commit();
+        }
+        catch (Exception e) {
+            entityManager.getTransaction().rollback();
+        } finally {
+            if (entityManager != null) {
+                entityManager.close();
+                entityManager = null;
+            }
+        }
+
+        this.publishQuotePriceChange(quote, oldPrice, changeFactor, sharesTraded);
+
+        return quote;
+    }
+
+    public Collection<HoldingDataBean> getHoldings(String userID) {
+        if (Log.doTrace())
+            Log.trace("TradeJPADirect:getHoldings", userID);
+        EntityManager entityManager = emf.createEntityManager();
+        /*
+         * managed transaction
+         */
+        entityManager.getTransaction().begin();
+
+        Query query = entityManager.createNamedQuery("holdingejb.holdingsByUserID");
+        query.setParameter("userID", userID);
+
+        entityManager.getTransaction().commit();
+        Collection<HoldingDataBean> holdings = query.getResultList();
+        /*
+         * Inflate the lazy data memebers
+         */
+        Iterator itr = holdings.iterator();
+        while (itr.hasNext()) {
+            ((HoldingDataBean) itr.next()).getQuote();
+        }
+
+        entityManager.close();
+        entityManager = null;
+        return holdings;
+    }
+
+    public HoldingDataBean getHolding(Integer holdingID) {
+        if (Log.doTrace())
+            Log.trace("TradeJPADirect:getHolding", holdingID);
+        HoldingDataBean holding;
+        EntityManager entityManager = emf.createEntityManager();
+        holding = entityManager.find(HoldingDataBean.class, holdingID);
+        entityManager.close();
+        return holding;
+    }
+
+    public AccountDataBean getAccountData(String userID) {
+        if (Log.doTrace())
+            Log.trace("TradeJPADirect:getAccountData", userID);
+
+        EntityManager entityManager = emf.createEntityManager();
+
+        AccountProfileDataBean profile = entityManager.find(AccountProfileDataBean.class, userID);
+        /*
+         * Inflate the lazy data memebers
+         */
+        AccountDataBean account = profile.getAccount();
+        account.getProfile();
+
+        // Added to populate transient field for account
+        account.setProfileID(profile.getUserID());
+        entityManager.close();
+        entityManager = null;
+
+        return account;
+    }
+
+    public AccountProfileDataBean getAccountProfileData(String userID) {
+        if (Log.doTrace())
+            Log.trace("TradeJPADirect:getProfileData", userID);
+        EntityManager entityManager = emf.createEntityManager();
+
+        AccountProfileDataBean apb = entityManager.find(AccountProfileDataBean.class, userID);
+        entityManager.close();
+        entityManager = null;
+        return apb;
+    }
+
+    public AccountProfileDataBean updateAccountProfile(AccountProfileDataBean profileData) {
+
+        EntityManager entityManager = emf.createEntityManager();
+
+        if (Log.doTrace())
+            Log.trace("TradeJPADirect:updateAccountProfileData", profileData);
+        /*
+         * // Retrieve the previous account profile in order to get account
+         * data... hook it into new object AccountProfileDataBean temp =
+         * entityManager.find(AccountProfileDataBean.class,
+         * profileData.getUserID()); // In order for the object to merge
+         * correctly, the account has to be hooked into the temp object... // -
+         * may need to reverse this and obtain the full object first
+         * 
+         * profileData.setAccount(temp.getAccount());
+         * 
+         * //TODO this might not be correct temp =
+         * entityManager.merge(profileData); //System.out.println(temp);
+         */
+
+        AccountProfileDataBean temp = entityManager.find(AccountProfileDataBean.class, profileData.getUserID());
+        temp.setAddress(profileData.getAddress());
+        temp.setPassword(profileData.getPassword());
+        temp.setFullName(profileData.getFullName());
+        temp.setCreditCard(profileData.getCreditCard());
+        temp.setEmail(profileData.getEmail());
+        /*
+         * Managed Transaction
+         */
+        try {
+
+            entityManager.getTransaction().begin();
+            entityManager.merge(temp);
+            entityManager.getTransaction().commit();
+        }
+        catch (Exception e) {
+            entityManager.getTransaction().rollback();
+        } finally {
+            entityManager.close();
+        }
+
+        return temp;
+    }
+
+    public AccountDataBean login(String userID, String password)
+    throws Exception {
+
+        EntityManager entityManager = emf.createEntityManager();
+
+        AccountProfileDataBean profile = entityManager.find(AccountProfileDataBean.class, userID);
+
+        if (profile == null) {
+            throw new RuntimeException("No such user: " + userID);
+        }
+        /*
+         * Managed Transaction
+         */
+        entityManager.getTransaction().begin();
+        entityManager.merge(profile);
+
+        AccountDataBean account = profile.getAccount();
+
+        if (Log.doTrace())
+            Log.trace("TradeJPADirect:login", userID, password);
+
+        account.login(password);
+        entityManager.getTransaction().commit();
+        if (Log.doTrace())
+            Log.trace("TradeJPADirect:login(" + userID + "," + password + ") success" + account);
+        entityManager.close();
+        return account;
+    }
+
+    public void logout(String userID) {
+        if (Log.doTrace())
+            Log.trace("TradeJPADirect:logout", userID);
+        EntityManager entityManager = emf.createEntityManager();
+
+        AccountProfileDataBean profile = entityManager.find(AccountProfileDataBean.class, userID);
+        AccountDataBean account = profile.getAccount();
+
+        /*
+         * Managed Transaction
+         */
+        try {
+            entityManager.getTransaction().begin();
+            account.logout();
+            entityManager.getTransaction().commit();
+        }
+        catch (Exception e) {
+            entityManager.getTransaction().rollback();
+        } finally {
+            entityManager.close();
+        }
+
+        if (Log.doTrace())
+            Log.trace("TradeJPADirect:logout(" + userID + ") success");
+    }
+
+    public AccountDataBean register(String userID, String password, String fullname, 
+                                    String address, String email, String creditcard,
+                                    BigDecimal openBalance) {
+        AccountDataBean account = null;
+        AccountProfileDataBean profile = null;
+        EntityManager entityManager = emf.createEntityManager();
+
+        if (Log.doTrace())
+            Log.trace("TradeJPADirect:register", userID, password, fullname, address, email, creditcard, openBalance);
+
+        // Check to see if a profile with the desired userID already exists
+
+        profile = entityManager.find(AccountProfileDataBean.class, userID);
+
+        if (profile != null) {
+            Log.error("Failed to register new Account - AccountProfile with userID(" + userID + ") already exists");
+            return null;
+        }
+        else {
+            profile = new AccountProfileDataBean(userID, password, fullname,
+                                                 address, email, creditcard);
+            account = new AccountDataBean(0, 0, null, new Timestamp(System.currentTimeMillis()), openBalance, openBalance, userID);
+            profile.setAccount(account);
+            account.setProfile(profile);
+            /*
+             * managed Transaction
+             */
+            try {
+                entityManager.getTransaction().begin();
+                entityManager.persist(profile);
+                entityManager.persist(account);
+                entityManager.getTransaction().commit();
+            }
+            catch (Exception e) {
+                entityManager.getTransaction().rollback();
+            } finally {
+                entityManager.close();
+            }
+
+        }
+
+        return account;
+    }
+
+    // @TransactionAttribute(TransactionAttributeType.NOT_SUPPORTED)
+    public RunStatsDataBean resetTrade(boolean deleteAll) throws Exception {
+        if (Log.doTrace())
+            Log.trace("TradeJPADirect:resetTrade", deleteAll);
+
+        return(new TradeJDBCDirect(false)).resetTrade(deleteAll);
+    }
+
+    /*
+     * NO LONGER USE
+     */
+
+    private void publishQuotePriceChange(QuoteDataBean quote,
+                                         BigDecimal oldPrice, BigDecimal changeFactor, double sharesTraded) {
+        if (!TradeConfig.getPublishQuotePriceChange())
+            return;
+        Log.error("TradeJPADirect:publishQuotePriceChange - is not implemented for this runtime mode");
+        throw new UnsupportedOperationException("TradeJPADirect:publishQuotePriceChange - is not implemented for this runtime mode");
+    }
+
+    /*
+     * new Method() that takes EntityManager as a parameter
+     */
+    private OrderDataBean createOrder(AccountDataBean account,
+                                      QuoteDataBean quote, HoldingDataBean holding, String orderType,
+                                      double quantity, EntityManager entityManager) {
+        OrderDataBean order;
+        if (Log.doTrace())
+            Log.trace("TradeJPADirect:createOrder(orderID=" + " account="
+                      + ((account == null) ? null : account.getAccountID())
+                      + " quote=" + ((quote == null) ? null : quote.getSymbol())
+                      + " orderType=" + orderType + " quantity=" + quantity);
+        try {
+            order = new OrderDataBean(orderType, 
+                                      "open", 
+                                      new Timestamp(System.currentTimeMillis()), 
+                                      null, 
+                                      quantity, 
+                                      quote.getPrice().setScale(FinancialUtils.SCALE, FinancialUtils.ROUND),
+                                      TradeConfig.getOrderFee(orderType), 
+                                      account, 
+                                      quote, 
+                                      holding);
+                entityManager.persist(order);
+        }
+        catch (Exception e) {
+            entityManager.getTransaction().rollback();
+            Log.error("TradeJPADirect:createOrder -- failed to create Order", e);
+            throw new RuntimeException("TradeJPADirect:createOrder -- failed to create Order", e);
+        }
+        return order;
+    }
+
+    /*private HoldingDataBean createHolding(AccountDataBean account,
+                                          QuoteDataBean quote, double quantity, BigDecimal purchasePrice,
+                                          EntityManager entityManager) throws Exception {
+        HoldingDataBean newHolding = new HoldingDataBean(quantity,
+                                                         purchasePrice, new Timestamp(System.currentTimeMillis()),
+                                                         account, quote);
+        try {            
+            entityManager.persist(newHolding);            
+        }
+        catch (Exception e) {
+            entityManager.getTransaction().rollback();
+        } 
+        
+        return newHolding;
+    }*/
+
+    public double investmentReturn(double investment, double NetValue)
+    throws Exception {
+        if (Log.doTrace())
+            Log.trace("TradeJPADirect:investmentReturn");
+
+        double diff = NetValue - investment;
+        double ir = diff / investment;
+        return ir;
+    }
+
+    public QuoteDataBean pingTwoPhase(String symbol) throws Exception {
+        Log
+        .error("TradeJPADirect:pingTwoPhase - is not implemented for this runtime mode");
+        throw new UnsupportedOperationException("TradeJPADirect:pingTwoPhase - is not implemented for this runtime mode");
+    }
+
+    class quotePriceComparator implements java.util.Comparator {
+        public int compare(Object quote1, Object quote2) {
+            double change1 = ((QuoteDataBean) quote1).getChange();
+            double change2 = ((QuoteDataBean) quote2).getChange();
+            return new Double(change2).compareTo(change1);
+        }
+    }
+
+    /**
+     * TradeBuildDB needs this abstracted method
+     */
+    public String checkDBProductName() throws Exception {
+        if (Log.doTrace())
+            Log.trace("TradeJPADirect:checkDBProductName");
+        return(new TradeJDBCDirect(false)).checkDBProductName();
+    }
+
+    /**
+     * TradeBuildDB needs this abstracted method
+     */
+    public boolean recreateDBTables(Object[] sqlBuffer, java.io.PrintWriter out)
+    throws Exception {
+        if (Log.doTrace())
+            Log.trace("TradeJPADirect:checkDBProductName");
+        return(new TradeJDBCDirect(false)).recreateDBTables(sqlBuffer, out);
+    }
+
+    /**
+     * Get mode - returns the persistence mode (TradeConfig.JPA)
+     * 
+     * @return int mode
+     */
+    public int getMode() {
+        return TradeConfig.JPA;
+    }
+
+}

Added: geronimo/daytrader/trunk/javaee6/modules/entities/pom.xml
URL: http://svn.apache.org/viewvc/geronimo/daytrader/trunk/javaee6/modules/entities/pom.xml?rev=1071543&view=auto
==============================================================================
--- geronimo/daytrader/trunk/javaee6/modules/entities/pom.xml (added)
+++ geronimo/daytrader/trunk/javaee6/modules/entities/pom.xml Thu Feb 17 08:23:57 2011
@@ -0,0 +1,108 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<project xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd" xmlns="http://maven.apache.org/POM/4.0.0"
+    xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance">
+  <modelVersion>4.0.0</modelVersion>
+  
+  <parent>
+    <artifactId>modules</artifactId>
+    <groupId>org.apache.geronimo.daytrader.javaee6</groupId>
+    <version>3.0-SNAPSHOT</version>
+  </parent>
+  
+  <artifactId>entities</artifactId>
+  
+ <name>DayTrader :: Java EE 6 :: Modules - Entities</name>
+  <description>Daytrader Java EE 6 Entities Module</description>
+  
+  <dependencies>
+        <dependency>
+            <groupId>org.apache.geronimo.daytrader.javaee6</groupId>
+            <artifactId>utils</artifactId>
+            <version>${project.version}</version>
+        </dependency>
+        <dependency>
+            <groupId>org.apache.geronimo.specs</groupId>
+            <artifactId>geronimo-jms_1.1_spec</artifactId>
+            <scope>provided</scope>
+        </dependency>
+        <dependency>
+            <groupId>org.apache.geronimo.specs</groupId>
+            <artifactId>geronimo-jta_1.1_spec</artifactId>
+            <scope>provided</scope>
+        </dependency>    
+        <dependency>
+            <groupId>org.apache.geronimo.specs</groupId>
+            <artifactId>geronimo-jpa_2.0_spec</artifactId>
+            <scope>provided</scope>
+        </dependency>
+        <dependency>
+            <groupId>org.apache.geronimo.specs</groupId>
+            <artifactId>geronimo-annotation_1.1_spec</artifactId>
+            <scope>provided</scope>
+                </dependency>
+        <dependency>
+            <groupId>org.apache.geronimo.specs</groupId>
+            <artifactId>geronimo-ejb_3.1_spec</artifactId>
+            <scope>provided</scope>
+        </dependency>
+        <dependency>
+            <groupId>org.apache.geronimo.specs</groupId>
+            <artifactId>geronimo-validation_1.0_spec</artifactId>
+            <scope>provided</scope>
+        </dependency>
+        <dependency>
+            <groupId>commons-logging</groupId>
+            <artifactId>commons-logging</artifactId>
+            <scope>provided</scope>
+        </dependency>        
+        <dependency>
+            <groupId>org.apache.openjpa</groupId>
+            <artifactId>openjpa</artifactId>
+            <scope>provided</scope>
+        </dependency>
+        <!-- OpenJPA PCEnhancer depends -->
+        <dependency>
+            <groupId>net.sourceforge.serp</groupId>
+            <artifactId>serp</artifactId>
+            <version>1.13.1</version>
+            <scope>provided</scope>
+        </dependency> 
+        <dependency>
+            <groupId>commons-lang</groupId>
+            <artifactId>commons-lang</artifactId>
+            <version>2.4</version>
+            <scope>provided</scope>
+        </dependency>
+        <dependency>
+            <groupId>commons-collections</groupId>
+            <artifactId>commons-collections</artifactId>
+            <version>3.2.1</version>
+            <scope>provided</scope>
+        </dependency>
+        <!-- end OpenJPA PCEnhancer depends -->
+    </dependencies>
+ 
+  <build>
+        <resources>
+            <resource>
+                <directory>${basedir}/src/main/resources</directory>
+                <filtering>true</filtering>
+            </resource>
+        </resources>
+
+        <!--  <plugins>
+            <plugin>
+                <groupId>org.apache.maven.plugins</groupId>
+                <artifactId>maven-ejb-plugin</artifactId>
+                <configuration>
+                    <generateClient>true</generateClient>
+                    <archive>
+                        <manifestEntries>
+                            <Class-Path>wsappclient.jar</Class-Path>
+                        </manifestEntries>
+                    </archive>
+                </configuration>
+            </plugin>
+        </plugins>-->
+    </build>
+</project>

Added: geronimo/daytrader/trunk/javaee6/modules/entities/src/main/java/org/apache/geronimo/daytrader/javaee6/entities/AccountDataBean.java
URL: http://svn.apache.org/viewvc/geronimo/daytrader/trunk/javaee6/modules/entities/src/main/java/org/apache/geronimo/daytrader/javaee6/entities/AccountDataBean.java?rev=1071543&view=auto
==============================================================================
--- geronimo/daytrader/trunk/javaee6/modules/entities/src/main/java/org/apache/geronimo/daytrader/javaee6/entities/AccountDataBean.java (added)
+++ geronimo/daytrader/trunk/javaee6/modules/entities/src/main/java/org/apache/geronimo/daytrader/javaee6/entities/AccountDataBean.java Thu Feb 17 08:23:57 2011
@@ -0,0 +1,325 @@
+package org.apache.geronimo.daytrader.javaee6.entities;
+
+/**
+ *  Licensed to the Apache Software Foundation (ASF) under one or more
+ *  contributor license agreements.  See the NOTICE file distributed with
+ *  this work for additional information regarding copyright ownership.
+ *  The ASF licenses this file to You under the Apache License, Version 2.0
+ *  (the "License"); you may not use this file except in compliance with
+ *  the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ *  Unless required by applicable law or agreed to in writing, software
+ *  distributed under the License is distributed on an "AS IS" BASIS,
+ *  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ *  See the License for the specific language governing permissions and
+ *  limitations under the License.
+ */
+
+import java.io.Serializable;
+import java.math.BigDecimal;
+import java.sql.Timestamp;
+import java.util.Collection;
+import java.util.Date;
+
+import javax.persistence.Column;
+import javax.persistence.Entity;
+import javax.persistence.FetchType;
+import javax.persistence.GeneratedValue;
+import javax.persistence.GenerationType;
+import javax.persistence.Id;
+import javax.persistence.JoinColumn;
+import javax.persistence.NamedQueries;
+import javax.persistence.NamedQuery;
+import javax.persistence.OneToMany;
+import javax.persistence.OneToOne;
+import javax.persistence.Table;
+import javax.persistence.TableGenerator;
+import javax.persistence.Temporal;
+import javax.persistence.TemporalType;
+import javax.persistence.Transient;
+import javax.validation.constraints.NotNull;
+
+import org.apache.geronimo.daytrader.javaee6.utils.Log;
+import org.apache.geronimo.daytrader.javaee6.utils.TradeConfig;
+
+@Entity(name = "accountejb")
+@Table(name = "accountejb")
+@NamedQueries( {
+        @NamedQuery(name = "accountejb.findByCreationdate", query = "SELECT a FROM accountejb a WHERE a.creationDate = :creationdate"),
+        @NamedQuery(name = "accountejb.findByOpenbalance", query = "SELECT a FROM accountejb a WHERE a.openBalance = :openbalance"),
+        @NamedQuery(name = "accountejb.findByLogoutcount", query = "SELECT a FROM accountejb a WHERE a.logoutCount = :logoutcount"),
+        @NamedQuery(name = "accountejb.findByBalance", query = "SELECT a FROM accountejb a WHERE a.balance = :balance"),
+        @NamedQuery(name = "accountejb.findByAccountid", query = "SELECT a FROM accountejb a WHERE a.accountID = :accountid"),
+        @NamedQuery(name = "accountejb.findByAccountid_eager", query = "SELECT a FROM accountejb a LEFT JOIN FETCH a.profile WHERE a.accountID = :accountid"),
+        @NamedQuery(name = "accountejb.findByAccountid_eagerholdings", query = "SELECT a FROM accountejb a LEFT JOIN FETCH a.holdings WHERE a.accountID = :accountid"),
+        @NamedQuery(name = "accountejb.findByLastlogin", query = "SELECT a FROM accountejb a WHERE a.lastLogin = :lastlogin"),
+        @NamedQuery(name = "accountejb.findByLogincount", query = "SELECT a FROM accountejb a WHERE a.loginCount = :logincount")
+    })
+public class AccountDataBean implements Serializable {
+
+    /* Accessor methods for persistent fields */
+    @TableGenerator(
+            name="accountIdGen",
+            table="keygenejb",
+            pkColumnName="KEYNAME",
+            valueColumnName="KEYVAL",
+            pkColumnValue="account",
+            allocationSize=1000)
+    
+    @Id
+    @GeneratedValue(strategy=GenerationType.TABLE, generator="accountIdGen")
+    @Column(name = "ACCOUNTID", nullable = false)
+    @NotNull
+    private Integer accountID;              /* accountID */
+    
+    @NotNull
+    @Column(name = "LOGINCOUNT", nullable = false)
+    private int loginCount;                 /* loginCount */
+    
+    @NotNull
+    @Column(name = "LOGOUTCOUNT", nullable = false)
+    private int logoutCount;                /* logoutCount */
+    
+    @Column(name = "LASTLOGIN")
+    @Temporal(TemporalType.TIMESTAMP)
+    private Date lastLogin;                 /* lastLogin Date */
+    
+    @Column(name = "CREATIONDATE")
+    @Temporal(TemporalType.TIMESTAMP)
+    private Date creationDate;              /* creationDate */
+    
+    @Column(name = "BALANCE")
+    private BigDecimal balance;             /* balance */
+    
+    @Column(name = "OPENBALANCE")
+    private BigDecimal openBalance;         /* open balance */
+    
+    // change to eager so that pingservlet2session2cmrone2many works
+    @OneToMany(mappedBy = "account", fetch=FetchType.EAGER)
+    //@OneToMany(mappedBy = "account", fetch=FetchType.LAZY)
+    private Collection<OrderDataBean> orders;
+    
+    @OneToMany(mappedBy = "account", fetch=FetchType.LAZY)
+    private Collection<HoldingDataBean> holdings;
+    
+    @OneToOne(fetch=FetchType.LAZY)
+    @JoinColumn(name="PROFILE_USERID")
+    private AccountProfileDataBean profile;
+
+//    @Version
+//    private Integer optLock;
+
+    /* Accessor methods for relationship fields are only included for the AccountProfile profileID */
+    @Transient
+    private String profileID;
+
+    public AccountDataBean() {
+    }
+
+    public AccountDataBean(Integer accountID,
+            int loginCount,
+            int logoutCount,
+            Date lastLogin,
+            Date creationDate,
+            BigDecimal balance,
+            BigDecimal openBalance,
+            String profileID) {
+        setAccountID(accountID);
+        setLoginCount(loginCount);
+        setLogoutCount(logoutCount);
+        setLastLogin(lastLogin);
+        setCreationDate(creationDate);
+        setBalance(balance);
+        setOpenBalance(openBalance);
+        setProfileID(profileID);
+    }
+
+    public AccountDataBean(int loginCount,
+            int logoutCount,
+            Date lastLogin,
+            Date creationDate,
+            BigDecimal balance,
+            BigDecimal openBalance,
+            String profileID) {
+        setLoginCount(loginCount);
+        setLogoutCount(logoutCount);
+        setLastLogin(lastLogin);
+        setCreationDate(creationDate);
+        setBalance(balance);
+        setOpenBalance(openBalance);
+        setProfileID(profileID);
+    }
+
+    public static AccountDataBean getRandomInstance() {
+        return new AccountDataBean(new Integer(TradeConfig.rndInt(100000)), //accountID
+                TradeConfig.rndInt(10000), //loginCount
+                TradeConfig.rndInt(10000), //logoutCount
+                new java.util.Date(), //lastLogin
+                new java.util.Date(TradeConfig.rndInt(Integer.MAX_VALUE)), //creationDate
+                TradeConfig.rndBigDecimal(1000000.0f), //balance
+                TradeConfig.rndBigDecimal(1000000.0f), //openBalance
+                TradeConfig.rndUserID() //profileID
+        );
+    }
+
+    public String toString() {
+        return "\n\tAccount Data for account: " + getAccountID()
+                + "\n\t\t   loginCount:" + getLoginCount()
+                + "\n\t\t  logoutCount:" + getLogoutCount()
+                + "\n\t\t    lastLogin:" + getLastLogin()
+                + "\n\t\t creationDate:" + getCreationDate()
+                + "\n\t\t      balance:" + getBalance()
+                + "\n\t\t  openBalance:" + getOpenBalance()
+                + "\n\t\t    profileID:" + getProfileID()
+                ;
+    }
+
+    public String toHTML() {
+        return "<BR>Account Data for account: <B>" + getAccountID() + "</B>"
+                + "<LI>   loginCount:" + getLoginCount() + "</LI>"
+                + "<LI>  logoutCount:" + getLogoutCount() + "</LI>"
+                + "<LI>    lastLogin:" + getLastLogin() + "</LI>"
+                + "<LI> creationDate:" + getCreationDate() + "</LI>"
+                + "<LI>      balance:" + getBalance() + "</LI>"
+                + "<LI>  openBalance:" + getOpenBalance() + "</LI>"
+                + "<LI>    profileID:" + getProfileID() + "</LI>"
+                ;
+    }
+
+    public void print() {
+        Log.log(this.toString());
+    }
+
+    public Integer getAccountID() {
+        return accountID;
+    }
+
+    public void setAccountID(Integer accountID) {
+        this.accountID = accountID;
+    }
+
+    public int getLoginCount() {
+        return loginCount;
+    }
+
+    public void setLoginCount(int loginCount) {
+        this.loginCount = loginCount;
+    }
+
+    public int getLogoutCount() {
+        return logoutCount;
+    }
+
+    public void setLogoutCount(int logoutCount) {
+        this.logoutCount = logoutCount;
+    }
+
+    public Date getLastLogin() {
+        return lastLogin;
+    }
+
+    public void setLastLogin(Date lastLogin) {
+        this.lastLogin = lastLogin;
+    }
+
+    public Date getCreationDate() {
+        return creationDate;
+    }
+
+    public void setCreationDate(Date creationDate) {
+        this.creationDate = creationDate;
+    }
+
+    public BigDecimal getBalance() {
+        return balance;
+    }
+
+    public void setBalance(BigDecimal balance) {
+        this.balance = balance;
+    }
+
+    public BigDecimal getOpenBalance() {
+        return openBalance;
+    }
+
+    public void setOpenBalance(BigDecimal openBalance) {
+        this.openBalance = openBalance;
+    }
+
+    public String getProfileID() {
+        return profileID;
+    }
+
+    public void setProfileID(String profileID) {
+        this.profileID = profileID;
+    }
+
+    /* Disabled for D185273
+     public String getUserID() {
+         return getProfileID();
+     }
+     */
+
+    public Collection<OrderDataBean> getOrders() {
+        return orders;
+    }
+
+    public void setOrders(Collection<OrderDataBean> orders) {
+        this.orders = orders;
+    }
+    
+    public Collection<HoldingDataBean> getHoldings() {
+        return holdings;
+    }
+
+    public void setHoldings(Collection<HoldingDataBean> holdings) {
+        this.holdings = holdings;
+    }
+
+    public AccountProfileDataBean getProfile() {
+        return profile;
+    }
+
+    public void setProfile(AccountProfileDataBean profile) {
+        this.profile = profile;
+    }
+
+    public void login(String password) {
+        AccountProfileDataBean profile = getProfile();
+        if ((profile == null) || (profile.getPassword().equals(password) == false)) {
+            String error = "AccountBean:Login failure for account: " + getAccountID() +
+                    ((profile == null) ? "null AccountProfile" :
+                            "\n\tIncorrect password-->" + profile.getUserID() + ":" + profile.getPassword());
+            throw new RuntimeException(error);
+            
+        }
+
+        setLastLogin(new Timestamp(System.currentTimeMillis()));
+        setLoginCount(getLoginCount() + 1);
+    }
+
+    public void logout() {
+        setLogoutCount(getLogoutCount() + 1);
+    }
+
+    @Override
+    public int hashCode() {
+        int hash = 0;
+        hash += (this.accountID != null ? this.accountID.hashCode() : 0);
+        return hash;
+    }
+
+    @Override
+    public boolean equals(Object object) {
+        // TODO: Warning - this method won't work in the case the id fields are not set
+        if (!(object instanceof AccountDataBean)) {
+            return false;
+        }
+        AccountDataBean other = (AccountDataBean)object;
+        if (this.accountID != other.accountID && (this.accountID == null || !this.accountID.equals(other.accountID))) return false;
+        return true;
+    }
+}
+

Added: geronimo/daytrader/trunk/javaee6/modules/entities/src/main/java/org/apache/geronimo/daytrader/javaee6/entities/AccountProfileDataBean.java
URL: http://svn.apache.org/viewvc/geronimo/daytrader/trunk/javaee6/modules/entities/src/main/java/org/apache/geronimo/daytrader/javaee6/entities/AccountProfileDataBean.java?rev=1071543&view=auto
==============================================================================
--- geronimo/daytrader/trunk/javaee6/modules/entities/src/main/java/org/apache/geronimo/daytrader/javaee6/entities/AccountProfileDataBean.java (added)
+++ geronimo/daytrader/trunk/javaee6/modules/entities/src/main/java/org/apache/geronimo/daytrader/javaee6/entities/AccountProfileDataBean.java Thu Feb 17 08:23:57 2011
@@ -0,0 +1,197 @@
+/**
+ *  Licensed to the Apache Software Foundation (ASF) under one or more
+ *  contributor license agreements.  See the NOTICE file distributed with
+ *  this work for additional information regarding copyright ownership.
+ *  The ASF licenses this file to You under the Apache License, Version 2.0
+ *  (the "License"); you may not use this file except in compliance with
+ *  the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ *  Unless required by applicable law or agreed to in writing, software
+ *  distributed under the License is distributed on an "AS IS" BASIS,
+ *  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ *  See the License for the specific language governing permissions and
+ *  limitations under the License.
+ */
+package org.apache.geronimo.daytrader.javaee6.entities;
+
+import javax.persistence.Column;
+import javax.persistence.Entity;
+import javax.persistence.FetchType;
+import javax.persistence.Id;
+import javax.persistence.NamedQueries;
+import javax.persistence.NamedQuery;
+import javax.persistence.OneToOne;
+import javax.persistence.Table;
+import javax.validation.constraints.NotNull;
+
+import org.apache.geronimo.daytrader.javaee6.utils.Log;
+import org.apache.geronimo.daytrader.javaee6.utils.TradeConfig;
+
+@Entity(name = "accountprofileejb")
+@Table(name = "accountprofileejb")
+@NamedQueries( {
+        @NamedQuery(name = "accountprofileejb.findByAddress", query = "SELECT a FROM accountprofileejb a WHERE a.address = :address"),
+        @NamedQuery(name = "accountprofileejb.findByPasswd", query = "SELECT a FROM accountprofileejb a WHERE a.passwd = :passwd"),
+        @NamedQuery(name = "accountprofileejb.findByUserid", query = "SELECT a FROM accountprofileejb a WHERE a.userID = :userid"),
+        @NamedQuery(name = "accountprofileejb.findByEmail", query = "SELECT a FROM accountprofileejb a WHERE a.email = :email"),
+        @NamedQuery(name = "accountprofileejb.findByCreditcard", query = "SELECT a FROM accountprofileejb a WHERE a.creditCard = :creditcard"),
+        @NamedQuery(name = "accountprofileejb.findByFullname", query = "SELECT a FROM accountprofileejb a WHERE a.fullName = :fullname")
+    })
+public class AccountProfileDataBean implements java.io.Serializable {
+
+    /* Accessor methods for persistent fields */
+
+    @Id
+    @Column(name = "USERID", nullable = false)
+    @NotNull
+    private String userID;              /* userID */
+    
+    @Column(name = "PASSWD")
+    private String passwd;              /* password */
+    
+    @Column(name = "FULLNAME")
+    private String fullName;            /* fullName */
+    
+    @Column(name = "ADDRESS")
+    private String address;             /* address */
+    
+    @Column(name = "EMAIL")
+    private String email;               /* email */
+    
+    @Column(name = "CREDITCARD")
+    private String creditCard;          /* creditCard */
+    
+    @OneToOne(mappedBy="profile", fetch=FetchType.LAZY)
+    private AccountDataBean account;
+
+//    @Version
+//    private Integer optLock;
+
+    public AccountProfileDataBean() {
+    }
+
+    public AccountProfileDataBean(String userID,
+            String password,
+            String fullName,
+            String address,
+            String email,
+            String creditCard) {
+        setUserID(userID);
+        setPassword(password);
+        setFullName(fullName);
+        setAddress(address);
+        setEmail(email);
+        setCreditCard(creditCard);
+    }
+
+    public static AccountProfileDataBean getRandomInstance() {
+        return new AccountProfileDataBean(
+                TradeConfig.rndUserID(),                        // userID
+                TradeConfig.rndUserID(),                        // passwd
+                TradeConfig.rndFullName(),                      // fullname
+                TradeConfig.rndAddress(),                       // address
+                TradeConfig.rndEmail(TradeConfig.rndUserID()),  //email
+                TradeConfig.rndCreditCard()                     // creditCard
+        );
+    }
+
+    public String toString() {
+        return "\n\tAccount Profile Data for userID:" + getUserID()
+                + "\n\t\t   passwd:" + getPassword()
+                + "\n\t\t   fullName:" + getFullName()
+                + "\n\t\t    address:" + getAddress()
+                + "\n\t\t      email:" + getEmail()
+                + "\n\t\t creditCard:" + getCreditCard()
+                ;
+    }
+
+    public String toHTML() {
+        return "<BR>Account Profile Data for userID: <B>" + getUserID() + "</B>"
+                + "<LI>   passwd:" + getPassword() + "</LI>"
+                + "<LI>   fullName:" + getFullName() + "</LI>"
+                + "<LI>    address:" + getAddress() + "</LI>"
+                + "<LI>      email:" + getEmail() + "</LI>"
+                + "<LI> creditCard:" + getCreditCard() + "</LI>"
+                ;
+    }
+
+    public void print() {
+        Log.log(this.toString());
+    }
+
+    public String getUserID() {
+        return userID;
+    }
+
+    public void setUserID(String userID) {
+        this.userID = userID;
+    }
+
+    public String getPassword() {
+        return passwd;
+    }
+
+    public void setPassword(String password) {
+        this.passwd = password;
+    }
+
+    public String getFullName() {
+        return fullName;
+    }
+
+    public void setFullName(String fullName) {
+        this.fullName = fullName;
+    }
+
+    public String getAddress() {
+        return address;
+    }
+
+    public void setAddress(String address) {
+        this.address = address;
+    }
+
+    public String getEmail() {
+        return email;
+    }
+
+    public void setEmail(String email) {
+        this.email = email;
+    }
+
+    public String getCreditCard() {
+        return creditCard;
+    }
+
+    public void setCreditCard(String creditCard) {
+        this.creditCard = creditCard;
+    }
+
+    public AccountDataBean getAccount() {
+        return account;
+    }
+
+    public void setAccount(AccountDataBean account) {
+        this.account = account;
+    }
+    
+    @Override
+    public int hashCode() {
+        int hash = 0;
+        hash += (this.userID != null ? this.userID.hashCode() : 0);
+        return hash;
+    }
+
+    @Override
+    public boolean equals(Object object) {
+        // TODO: Warning - this method won't work in the case the id fields are not set
+        if (!(object instanceof AccountProfileDataBean)) {
+            return false;
+        }
+        AccountProfileDataBean other = (AccountProfileDataBean)object;
+        if (this.userID != other.userID && (this.userID == null || !this.userID.equals(other.userID))) return false;
+        return true;
+    }
+}

Added: geronimo/daytrader/trunk/javaee6/modules/entities/src/main/java/org/apache/geronimo/daytrader/javaee6/entities/HoldingDataBean.java
URL: http://svn.apache.org/viewvc/geronimo/daytrader/trunk/javaee6/modules/entities/src/main/java/org/apache/geronimo/daytrader/javaee6/entities/HoldingDataBean.java?rev=1071543&view=auto
==============================================================================
--- geronimo/daytrader/trunk/javaee6/modules/entities/src/main/java/org/apache/geronimo/daytrader/javaee6/entities/HoldingDataBean.java (added)
+++ geronimo/daytrader/trunk/javaee6/modules/entities/src/main/java/org/apache/geronimo/daytrader/javaee6/entities/HoldingDataBean.java Thu Feb 17 08:23:57 2011
@@ -0,0 +1,238 @@
+/**
+ *  Licensed to the Apache Software Foundation (ASF) under one or more
+ *  contributor license agreements.  See the NOTICE file distributed with
+ *  this work for additional information regarding copyright ownership.
+ *  The ASF licenses this file to You under the Apache License, Version 2.0
+ *  (the "License"); you may not use this file except in compliance with
+ *  the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ *  Unless required by applicable law or agreed to in writing, software
+ *  distributed under the License is distributed on an "AS IS" BASIS,
+ *  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ *  See the License for the specific language governing permissions and
+ *  limitations under the License.
+ */
+package org.apache.geronimo.daytrader.javaee6.entities;
+
+import java.io.Serializable;
+import java.math.BigDecimal;
+import java.util.Date;
+
+import javax.persistence.Column;
+import javax.persistence.Entity;
+import javax.persistence.FetchType;
+import javax.persistence.GeneratedValue;
+import javax.persistence.GenerationType;
+import javax.persistence.Id;
+import javax.persistence.JoinColumn;
+import javax.persistence.ManyToOne;
+import javax.persistence.NamedQueries;
+import javax.persistence.NamedQuery;
+import javax.persistence.Table;
+import javax.persistence.TableGenerator;
+import javax.persistence.Temporal;
+import javax.persistence.TemporalType;
+import javax.persistence.Transient;
+
+import javax.validation.constraints.NotNull;
+
+
+
+import org.apache.geronimo.daytrader.javaee6.utils.Log;
+import org.apache.geronimo.daytrader.javaee6.utils.TradeConfig;
+
+@Entity(name = "holdingejb")
+@Table(name = "holdingejb")
+@NamedQueries( {
+        @NamedQuery(name = "holdingejb.findByPurchaseprice", query = "SELECT h FROM holdingejb h WHERE h.purchasePrice = :purchaseprice"),
+        @NamedQuery(name = "holdingejb.findByHoldingid", query = "SELECT h FROM holdingejb h WHERE h.holdingID = :holdingid"),
+        @NamedQuery(name = "holdingejb.findByQuantity", query = "SELECT h FROM holdingejb h WHERE h.quantity = :quantity"),
+        @NamedQuery(name = "holdingejb.findByPurchasedate", query = "SELECT h FROM holdingejb h WHERE h.purchaseDate = :purchasedate"),
+        @NamedQuery(name = "holdingejb.holdingsByUserID", query = "SELECT h FROM holdingejb h where h.account.profile.userID = :userID")
+    })
+public class HoldingDataBean implements Serializable {
+
+    /* persistent/relationship fields */
+
+    @TableGenerator(
+            name="holdingIdGen",
+            table="keygenejb",
+            pkColumnName="KEYNAME",
+            valueColumnName="KEYVAL",
+            pkColumnValue="holding",
+            allocationSize=1000)
+    @Id
+    @GeneratedValue(strategy=GenerationType.TABLE, generator="holdingIdGen")
+    @Column(name = "HOLDINGID", nullable = false)
+    @NotNull
+    private Integer holdingID;              /* holdingID */
+    
+    @NotNull
+    @Column(name = "QUANTITY", nullable = false)
+    private double quantity;                /* quantity */
+    
+    @Column(name = "PURCHASEPRICE")
+    private BigDecimal purchasePrice;       /* purchasePrice */
+    
+    @Column(name = "PURCHASEDATE")
+    @Temporal(TemporalType.TIMESTAMP)
+    private Date purchaseDate;              /* purchaseDate */
+    
+    @Transient
+    private String quoteID;                 /* Holding(*)  ---> Quote(1) */
+    
+    @ManyToOne(fetch=FetchType.LAZY)
+    @JoinColumn(name="ACCOUNT_ACCOUNTID")
+    private AccountDataBean account;
+    
+    @ManyToOne(fetch=FetchType.EAGER)
+    @JoinColumn(name = "QUOTE_SYMBOL")
+    private QuoteDataBean quote;
+
+//    @Version
+//    private Integer optLock;
+
+    public HoldingDataBean() {
+    }
+
+    public HoldingDataBean(Integer holdingID,
+            double quantity,
+            BigDecimal purchasePrice,
+            Date purchaseDate,
+            String quoteID) {
+        setHoldingID(holdingID);
+        setQuantity(quantity);
+        setPurchasePrice(purchasePrice);
+        setPurchaseDate(purchaseDate);
+        setQuoteID(quoteID);
+    }
+
+    public HoldingDataBean(double quantity,
+            BigDecimal purchasePrice,
+            Date purchaseDate,
+            AccountDataBean account,
+            QuoteDataBean quote) {
+        setQuantity(quantity);
+        setPurchasePrice(purchasePrice);
+        setPurchaseDate(purchaseDate);
+        setAccount(account);
+        setQuote(quote);
+    }
+
+    public static HoldingDataBean getRandomInstance() {
+        return new HoldingDataBean(
+                new Integer(TradeConfig.rndInt(100000)),     //holdingID
+                TradeConfig.rndQuantity(),                     //quantity
+                TradeConfig.rndBigDecimal(1000.0f),             //purchasePrice
+                new java.util.Date(TradeConfig.rndInt(Integer.MAX_VALUE)), //purchaseDate
+                TradeConfig.rndSymbol()                        // symbol
+        );
+    }
+
+    public String toString() {
+        return "\n\tHolding Data for holding: " + getHoldingID()
+                + "\n\t\t      quantity:" + getQuantity()
+                + "\n\t\t purchasePrice:" + getPurchasePrice()
+                + "\n\t\t  purchaseDate:" + getPurchaseDate()
+                + "\n\t\t       quoteID:" + getQuoteID()
+                ;
+    }
+
+    public String toHTML() {
+        return "<BR>Holding Data for holding: " + getHoldingID() + "</B>"
+                + "<LI>      quantity:" + getQuantity() + "</LI>"
+                + "<LI> purchasePrice:" + getPurchasePrice() + "</LI>"
+                + "<LI>  purchaseDate:" + getPurchaseDate() + "</LI>"
+                + "<LI>       quoteID:" + getQuoteID() + "</LI>"
+                ;
+    }
+
+    public void print() {
+        Log.log(this.toString());
+    }
+
+    public Integer getHoldingID() {
+        return holdingID;
+    }
+
+    public void setHoldingID(Integer holdingID) {
+        this.holdingID = holdingID;
+    }
+
+    public double getQuantity() {
+        return quantity;
+    }
+
+    public void setQuantity(double quantity) {
+        this.quantity = quantity;
+    }
+
+    public BigDecimal getPurchasePrice() {
+        return purchasePrice;
+    }
+
+    public void setPurchasePrice(BigDecimal purchasePrice) {
+        this.purchasePrice = purchasePrice;
+    }
+
+    public Date getPurchaseDate() {
+        return purchaseDate;
+    }
+
+    public void setPurchaseDate(Date purchaseDate) {
+        this.purchaseDate = purchaseDate;
+    }
+
+    public String getQuoteID() {
+        if (quote != null) {
+            return quote.getSymbol();
+        }
+        return quoteID;
+    }
+
+    public void setQuoteID(String quoteID) {
+        this.quoteID = quoteID;
+    }
+
+    public AccountDataBean getAccount() {
+        return account;
+    }
+
+    public void setAccount(AccountDataBean account) {
+        this.account = account;
+    }
+
+    /* Disabled for D185273
+     public String getSymbol() {
+         return getQuoteID();
+     }
+     */
+    
+    public QuoteDataBean getQuote() {
+        return quote;
+    }
+
+    public void setQuote(QuoteDataBean quote) {
+        this.quote = quote;
+    }
+    
+    @Override
+    public int hashCode() {
+        int hash = 0;
+        hash += (this.holdingID != null ? this.holdingID.hashCode() : 0);
+        return hash;
+    }
+
+    @Override
+    public boolean equals(Object object) {
+        // TODO: Warning - this method won't work in the case the id fields are not set
+        if (!(object instanceof HoldingDataBean)) {
+            return false;
+        }
+        HoldingDataBean other = (HoldingDataBean) object;
+        if (this.holdingID != other.holdingID && (this.holdingID == null || !this.holdingID.equals(other.holdingID))) return false;
+        return true;
+    }
+}