You are viewing a plain text version of this content. The canonical link for it is here.
Posted to scm@geronimo.apache.org by dj...@apache.org on 2011/02/28 00:56:23 UTC

svn commit: r1075183 [2/3] - in /geronimo/sandbox/djencks/txmanager: ./ connector-itests/ geronimo-connector-builder-1_6/ geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/ geronimo-connector-builder-1_6/src/main/jav...

Added: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/InfoBuilder.java
URL: http://svn.apache.org/viewvc/geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/InfoBuilder.java?rev=1075183&view=auto
==============================================================================
--- geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/InfoBuilder.java (added)
+++ geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/InfoBuilder.java Sun Feb 27 23:56:21 2011
@@ -0,0 +1,583 @@
+/*
+ * 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.connector.deployment;
+
+import java.beans.Introspector;
+import java.beans.PropertyEditor;
+import java.lang.reflect.Method;
+import java.util.ArrayList;
+import java.util.Collections;
+import java.util.Date;
+import java.util.HashMap;
+import java.util.HashSet;
+import java.util.List;
+import java.util.Map;
+import java.util.Set;
+
+import org.apache.geronimo.common.DeploymentException;
+import org.apache.geronimo.common.propertyeditor.PropertyEditors;
+import org.apache.geronimo.connector.deployment.plan.AdminobjectInstanceType;
+import org.apache.geronimo.connector.deployment.plan.AdminobjectType;
+import org.apache.geronimo.connector.deployment.plan.ConfigPropertySettingType;
+import org.apache.geronimo.connector.deployment.plan.ConnectionDefinitionType;
+import org.apache.geronimo.connector.deployment.plan.ConnectiondefinitionInstanceType;
+import org.apache.geronimo.connector.deployment.plan.ConnectionmanagerType;
+import org.apache.geronimo.connector.deployment.plan.ConnectorType;
+import org.apache.geronimo.connector.deployment.plan.OutboundResourceadapterType;
+import org.apache.geronimo.connector.deployment.plan.PartitionedpoolType;
+import org.apache.geronimo.connector.deployment.plan.ResourceadapterType;
+import org.apache.geronimo.connector.deployment.plan.SinglepoolType;
+import org.apache.geronimo.connector.model.AdminObjectInfo;
+import org.apache.geronimo.connector.model.ManagedConnectionFactoryInfo;
+import org.apache.geronimo.connector.model.ResourceAdapterInfo;
+import org.apache.geronimo.connector.model.ResourceAdapterModuleInfo;
+import org.apache.openejb.jee.AdminObject;
+import org.apache.openejb.jee.ConfigProperty;
+import org.apache.openejb.jee.ConnectionDefinition;
+import org.apache.openejb.jee.Connector;
+import org.apache.openejb.jee.OutboundResourceAdapter;
+import org.osgi.framework.Bundle;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+/**
+ * @version $Rev:$ $Date:$
+ */
+public class InfoBuilder {
+
+    private static final Logger log = LoggerFactory.getLogger(InfoBuilder.class);
+    private static final Map<String, Class> TYPE_LOOKUP = new HashMap<String, Class>();
+
+    static {
+        TYPE_LOOKUP.put("byte", Byte.class);
+        TYPE_LOOKUP.put(Byte.class.getName(), Byte.class);
+        TYPE_LOOKUP.put("int", Integer.class);
+        TYPE_LOOKUP.put(Integer.class.getName(), Integer.class);
+        TYPE_LOOKUP.put("short", Short.class);
+        TYPE_LOOKUP.put(Short.class.getName(), Short.class);
+        TYPE_LOOKUP.put("long", Long.class);
+        TYPE_LOOKUP.put(Long.class.getName(), Long.class);
+        TYPE_LOOKUP.put("float", Float.class);
+        TYPE_LOOKUP.put(Float.class.getName(), Float.class);
+        TYPE_LOOKUP.put("double", Double.class);
+        TYPE_LOOKUP.put(Double.class.getName(), Double.class);
+        TYPE_LOOKUP.put("boolean", Boolean.class);
+        TYPE_LOOKUP.put(Boolean.class.getName(), Boolean.class);
+        TYPE_LOOKUP.put("char", Character.class);
+        TYPE_LOOKUP.put(Character.class.getName(), Character.class);
+        TYPE_LOOKUP.put(String.class.getName(), String.class);
+    }
+
+    private String defaultWorkManagerTarget = "(service.ranking>=0)";
+    private boolean defaultXATransactionCaching = true;
+    private boolean defaultXAThreadCaching = false;
+    private int defaultMaxSize = 10;
+    private int defaultMinSize = 0;
+    private int defaultBlockingTimeoutMilliseconds = 5000;
+    private int defaultIdleTimeoutMinutes = 5;
+
+    public ResourceAdapterModuleInfo configureConnector(Connector connector, ConnectorType geronimoConnector, Bundle bundle) throws DeploymentException {
+
+        //TODO set filters for workmanager and tx manager
+        String connectionTrackerFilter = null;
+        String transactionManagerFilter = null;
+        ResourceAdapterModuleInfo raModuleInfo = new ResourceAdapterModuleInfo();
+        org.apache.openejb.jee.ResourceAdapter resourceAdapterType = connector.getResourceAdapter();
+
+        List<ResourceadapterType> geronimoResourceAdapters = geronimoConnector.getResourceadapter();
+        for (ResourceadapterType resourceAdapterInstance : geronimoResourceAdapters) {
+            ResourceAdapterInfo raInfo = null;
+            // Resource Adapter
+            if (resourceAdapterType.getResourceAdapterClass() != null) {
+                raInfo = new ResourceAdapterInfo();
+                raInfo.resourceAdapterClass = resourceAdapterType.getResourceAdapterClass();
+                if (resourceAdapterInstance.getResourceadapterInstance() != null) {
+                    setConfigProperties(raInfo.configProperties, raInfo.resourceAdapterClass, resourceAdapterType.getConfigProperty(), resourceAdapterInstance.getResourceadapterInstance().getConfigPropertySetting(), bundle);
+                    raInfo.workManagerTarget = resourceAdapterInstance.getResourceadapterInstance().getWorkmanager();
+                    raInfo.name = resourceAdapterInstance.getResourceadapterInstance().getResourceadapterName();
+                } else {
+                    setConfigProperties(raInfo.configProperties, raInfo.resourceAdapterClass, resourceAdapterType.getConfigProperty(), Collections.<ConfigPropertySettingType>emptyList(), bundle);
+                    raInfo.workManagerTarget = defaultWorkManagerTarget;
+                    raInfo.name = "ResourceAdapterInstance-" + System.currentTimeMillis();
+                    log.warn("Resource adapter instance information was not specified in Geronimo plan. Using defaults.");
+                }
+
+                raModuleInfo.resourceAdapterInfos.add(raInfo);
+                //add admin objects associated with a resource adapter
+                configureAdminObjects(raInfo.adminObjectInfos, resourceAdapterType.getAdminObject(), resourceAdapterInstance.getAdminobject(), bundle);
+            } else {
+                //add admin objects associated with a resource adapter
+                configureAdminObjects(raModuleInfo.adminObjectInfos, resourceAdapterType.getAdminObject(), resourceAdapterInstance.getAdminobject(), bundle);
+
+            }
+
+            // Outbound Managed Connection Factories (think JDBC data source or JMS connection factory)
+
+            // ManagedConnectionFactory setup
+            if (resourceAdapterInstance.getOutboundResourceadapter() != null) {
+                OutboundResourceAdapter outboundType = resourceAdapterType.getOutboundResourceAdapter();
+                if (outboundType == null) {
+                    throw new DeploymentException("Geronimo plan configures an outbound resource adapter but ra.xml does not describe any");
+                }
+                String transactionSupport = outboundType.getTransactionSupport().value();
+                OutboundResourceadapterType outboundInstance = resourceAdapterInstance.getOutboundResourceadapter();
+
+                Map<String, ConnectionDefinition> types = new HashMap<String, ConnectionDefinition>(outboundType.getConnectionDefinition().size());
+                for (ConnectionDefinition connectionDefinition : outboundType.getConnectionDefinition()) {
+                    types.put(connectionDefinition.getConnectionFactoryInterface(), connectionDefinition);
+                }
+                for (ConnectionDefinitionType geronimoConnectionDefinition : outboundInstance.getConnectionDefinition()) {
+                    assert geronimoConnectionDefinition != null : "Null GeronimoConnectionDefinition";
+
+                    String connectionFactoryInterfaceName = geronimoConnectionDefinition.getConnectionfactoryInterface().trim();
+                    ConnectionDefinition connectionDefinition = types.get(connectionFactoryInterfaceName);
+
+                    if (connectionDefinition == null) {
+                        throw new DeploymentException("No connection definition for ConnectionFactory interface: " + connectionFactoryInterfaceName);
+                    }
+
+                    for (ConnectiondefinitionInstanceType connectionfactoryInstance : geronimoConnectionDefinition.getConnectiondefinitionInstance()) {
+
+                        configureOutbound(raInfo == null ? raModuleInfo.managedConnectionFactoryInfos : raInfo.managedConnectionFactoryInfos,
+                                connectionDefinition, connectionfactoryInstance, transactionSupport, bundle, connectionTrackerFilter, transactionManagerFilter);
+                    }
+                }
+            }
+        }
+        // add admin objects not associated with a resource adapter
+        configureAdminObjects(raModuleInfo.adminObjectInfos, resourceAdapterType.getAdminObject(), geronimoConnector.getAdminobject(), bundle);
+        return raModuleInfo;
+    }
+
+    private void configureAdminObjects(List<AdminObjectInfo> adminObjectInfos, List<AdminObject> adminObjectTypes, List<AdminobjectType> adminObjects, Bundle bundle) throws DeploymentException {
+        Map<String, AdminObject> types = new HashMap<String, AdminObject>(adminObjects.size());
+        for (AdminObject adminObject : adminObjectTypes) {
+            types.put(adminObject.getAdminObjectInterface(), adminObject);
+        }
+        for (AdminobjectType typeInstance : adminObjects) {
+            String adminObjectInterface = typeInstance.getAdminobjectInterface();
+            AdminObject adminObjectType = types.get(adminObjectInterface);
+            if (adminObjectType == null) {
+                throw new DeploymentException("No admin object declared for interface: " + adminObjectInterface);
+            }
+
+            for (AdminobjectInstanceType instance : typeInstance.getAdminobjectInstance()) {
+                AdminObjectInfo info = new AdminObjectInfo();
+                info.name = instance.getMessageDestinationName();
+                info.adminObjectInterface = adminObjectType.getAdminObjectInterface();
+                info.adminObjectClass = adminObjectType.getAdminObjectClass();
+                setConfigProperties(info.configProperties, info.adminObjectClass, adminObjectType.getConfigProperty(), instance.getConfigPropertySetting(), bundle);
+//                Set<String> implementedInterfaces = new HashSet<String>();
+//                implementedInterfaces.add(checkClass(bundle, (String) adminObjectInstanceGBeanData.getAttribute("adminObjectInterface")));
+//                implementedInterfaces.add(checkClass(bundle, (String) adminObjectInstanceGBeanData.getAttribute("adminObjectClass")));
+//                adminObjectInstanceGBeanData.setServiceInterfaces(implementedInterfaces.toArray(new String[implementedInterfaces.size()]));
+//                String jndiName = naming.toOsgiJndiName(adminObjectAbstractName);
+//                TODO allow specifying osig jndi name directly, like for connection factories
+//                adminObjectInstanceGBeanData.getServiceProperties().put(OSGI_JNDI_SERVICE_NAME, jndiName);
+                adminObjectInfos.add(info);
+            }
+        }
+    }
+
+//    private Map<String, GBeanData> getActivationSpecInfoMap(AbstractName validatorName, List<MessageListener> messageListeners, Bundle bundle) throws DeploymentException {
+//        Map<String, GBeanData> activationSpecInfos = new HashMap<String, GBeanData>();
+//        for (MessageListener messageListener : messageListeners) {
+//            String messageListenerInterface = messageListener.getMessageListenerType();
+//            ActivationSpec activationSpec = messageListener.getActivationSpec();
+//            String activationSpecClassName = activationSpec.getActivationSpecClass();
+//            GBeanInfoBuilder infoBuilder = new GBeanInfoBuilder(ActivationSpecWrapperGBean.class, new AnnotationGBeanInfoBuilder(ActivationSpecWrapperGBean.class).buildGBeanInfo());
+//            Set<String> ignore = Collections.singleton("resourceAdapter");
+//            setUpDynamicGBean(activationSpecClassName, infoBuilder, ignore, bundle, true);
+//
+//
+//            GBeanInfo gbeanInfo = infoBuilder.getBeanInfo();
+//
+//            GBeanData activationSpecInfo = new GBeanData(gbeanInfo);
+//            activationSpecInfo.setAttribute("activationSpecClass", activationSpecClassName);
+//            activationSpecInfo.setReferencePattern("ValidatorFactory", validatorName);
+//            activationSpecInfos.put(messageListenerInterface, activationSpecInfo);
+//        }
+//        return activationSpecInfos;
+//    }
+
+    private Map<String, String> findConfigProperties(String className, Set<String> ignore, Bundle bundle, boolean decapitalize) throws DeploymentException {
+        //add all javabean properties that have both getter and setter.  Ignore the "required" flag from the dd.
+        Map<String, String> getters = new HashMap<String, String>();
+        Set<String> setters = new HashSet<String>();
+        Method[] methods;
+        try {
+            Class clazz = bundle.loadClass(className);
+            methods = clazz.getMethods();
+        } catch (ClassNotFoundException e) {
+            throw new DeploymentException("Can not load adapter class in classloader " + bundle, e);
+        } catch (NoClassDefFoundError e) {
+            throw new DeploymentException("Can not load adapter class in classloader " + bundle, e);
+        }
+        for (Method method : methods) {
+            String methodName = method.getName();
+            if ((methodName.startsWith("get") || methodName.startsWith("is")) && method.getParameterTypes().length == 0) {
+                String attributeName = (methodName.startsWith("get")) ? methodName.substring(3) : methodName.substring(2);
+                getters.put(setCase(attributeName, decapitalize), method.getReturnType().getName());
+            } else if (methodName.startsWith("set") && method.getParameterTypes().length == 1) {
+                setters.add(setCase(methodName.substring(3), decapitalize));
+            }
+        }
+        getters.keySet().retainAll(setters);
+        getters.keySet().removeAll(ignore);
+        return getters;
+    }
+
+    private String setCase(String attributeName, boolean decapitalize) {
+        if (decapitalize) {
+            return Introspector.decapitalize(attributeName);
+        } else {
+            return attributeName;
+        }
+    }
+
+    private static String switchCase(String name) {
+        if (name == null || name.length() == 0) {
+            return name;
+        }
+        if (Character.isUpperCase(name.charAt(0))) {
+            char chars[] = name.toCharArray();
+            chars[0] = Character.toLowerCase(chars[0]);
+            return new String(chars);
+        } else if (Character.isLowerCase(name.charAt(0))) {
+            char chars[] = name.toCharArray();
+            chars[0] = Character.toUpperCase(chars[0]);
+            return new String(chars);
+        } else {
+            return name;
+        }
+    }
+
+    private void setConfigProperties(Map<String, Object> configMap, String beanClass, List<ConfigProperty> configProperties, List<ConfigPropertySettingType> configPropertySettings, Bundle bundle) throws DeploymentException {
+        Map<String, String> configPropertyTypes = findConfigProperties(beanClass, Collections.<String>emptySet(), bundle, false);
+        setConfigProperties(configMap, configProperties, configPropertyTypes, bundle);
+        setConfigPropertySettings(configMap, configPropertySettings, configPropertyTypes, bundle);
+    }
+
+    private void setConfigProperties(Map<String, Object> configMap, List<ConfigProperty> configProperties, Map<String, String> configPropertyTypes, Bundle bundle) throws DeploymentException {
+        for (ConfigProperty configProperty : configProperties) {
+            String name = configProperty.getConfigPropertyName();
+
+            String type = configProperty.getConfigPropertyType();
+            if (configPropertyTypes.get(name) == null || !configPropertyTypes.get(name).equals(type)) {
+                throw new DeploymentException("Wrong type, expected " + configPropertyTypes.get(name) + " actual " + type);
+            }
+            configMap.put(name, getValue(type, configProperty.getConfigPropertyValue(), bundle));
+        }
+    }
+
+    private void setConfigPropertySettings(Map<String, Object> configMap, List<ConfigPropertySettingType> configProperties, Map<String, String> configPropertyTypes, Bundle bundle) throws DeploymentException {
+        List<String> unknownNames = new ArrayList<String>();
+        for (ConfigPropertySettingType configProperty : configProperties) {
+            String name = configProperty.getName();
+            String type = configPropertyTypes.get(name);
+            if (type == null) {
+                String originalName = name;
+                name = switchCase(name);
+                type = configPropertyTypes.get(name);
+                if (type == null) {
+                    unknownNames.add(originalName);
+                    continue;
+                }
+            }
+
+            configMap.put(name, getValue(type, configProperty.getValue().trim(), bundle));
+        }
+        if (unknownNames.size() > 0) {
+            StringBuffer buf = new StringBuffer("The plan is trying to set attributes: ").append(unknownNames).append("\n");
+            buf.append("Known attributes: \n");
+            for (Map.Entry<String, String> entry : configPropertyTypes.entrySet()) {
+                buf.append("name: ").append(entry.getKey()).append(", type: ").append(entry.getValue()).append("\n");
+            }
+            throw new DeploymentException(buf.toString());
+        }
+    }
+
+    private Object getValue(String type, String value, Bundle bundle) throws DeploymentException {
+        if (value == null) {
+            return null;
+        }
+
+        Class clazz = TYPE_LOOKUP.get(type);
+        if (clazz == null) {
+            try {
+                clazz = bundle.loadClass(type);
+            } catch (ClassNotFoundException e) {
+                throw new DeploymentException("Could not load attribute class:  type: " + type, e);
+            }
+        }
+
+        // Handle numeric fields with no value set
+        if (value.equals("")) {
+            if (Number.class.isAssignableFrom(clazz) || Date.class.isAssignableFrom(clazz)) {
+                return null;
+            }
+        }
+
+        PropertyEditor editor = PropertyEditors.getEditor(clazz);
+        editor.setAsText(value);
+        return editor.getValue();
+    }
+
+
+    private void configureConnectionManager(ManagedConnectionFactoryInfo mcfInfo, String ddTransactionSupport, ConnectiondefinitionInstanceType connectionfactoryInstance, String connectionTrackerName, String transactionManagerName) throws DeploymentException {
+
+        //we configure our connection manager
+        ConnectionmanagerType connectionManager = connectionfactoryInstance.getConnectionmanager();
+        ManagedConnectionFactoryInfo.TransactionSupport transactionSupport;
+        if (connectionManager.getNoTransaction() != null) {
+            transactionSupport = ManagedConnectionFactoryInfo.TransactionSupport.none;
+        } else if (connectionManager.getLocalTransaction() != null) {
+            if ("NoTransaction".equals(ddTransactionSupport)) {
+                throw new DeploymentException("You are requesting local transaction support for a connector that does not support transactions: named: " + connectionfactoryInstance.getName().trim());
+            }
+            transactionSupport = ManagedConnectionFactoryInfo.TransactionSupport.local;
+        } else if (connectionManager.getTransactionLog() != null) {
+            if ("NoTransaction".equals(ddTransactionSupport)) {
+                throw new DeploymentException("You are requesting local transaction support for a connector that does not support transactions: named: " + connectionfactoryInstance.getName().trim());
+            }
+            transactionSupport = ManagedConnectionFactoryInfo.TransactionSupport.xaTxLog;
+        } else if (connectionManager.getXaTransaction() != null) {
+            if ("NoTransaction".equals(ddTransactionSupport)) {
+                throw new DeploymentException("You are requesting xa transaction support for a connector that does not support transactions: named: " + connectionfactoryInstance.getName().trim());
+            }
+            if ("LocalTransaction".equals(ddTransactionSupport)) {
+                throw new DeploymentException("You are requesting xa transaction support for a connector that supports only local transactions: named: " + connectionfactoryInstance.getName().trim());
+            }
+            transactionSupport = getXATxSupport(connectionManager.getXaTransaction().getTransactionCaching() != null,
+                    connectionManager.getXaTransaction().getThreadCaching() != null);
+        } else if ("NoTransaction".equals(ddTransactionSupport)) {
+            transactionSupport = ManagedConnectionFactoryInfo.TransactionSupport.none;
+        } else if ("LocalTransaction".equals(ddTransactionSupport)) {
+            transactionSupport = ManagedConnectionFactoryInfo.TransactionSupport.local;
+        } else if ("XATransaction".equals(ddTransactionSupport)) {
+            transactionSupport = getXATxSupport(defaultXATransactionCaching, defaultXAThreadCaching);
+        } else {
+            //this should not happen
+            throw new DeploymentException("Unexpected transaction support element in connector named: " + connectionfactoryInstance.getName().trim());
+        }
+        if (connectionManager.getSinglePool() != null) {
+            SinglepoolType pool = connectionManager.getSinglePool();
+
+            mcfInfo.poolCardinality = ManagedConnectionFactoryInfo.PoolCardinality.single;
+            mcfInfo.maxPoolSize = pool.getMaxSize() != null ? pool.getMaxSize() : defaultMaxSize;
+            mcfInfo.minPoolSize = pool.getMinSize() != null ? pool.getMinSize() : defaultMinSize;
+            mcfInfo.blockingTimeoutMilliseconds = pool.getBlockingTimeoutMilliseconds() != null ? pool.getBlockingTimeoutMilliseconds() : defaultBlockingTimeoutMilliseconds;
+            mcfInfo.idleTimeoutMinutes = pool.getIdleTimeoutMinutes() != null ? pool.getIdleTimeoutMinutes() : defaultIdleTimeoutMinutes;
+            mcfInfo.matchingPolicy = getMatchingPolicy(pool.getMatchOne() != null,
+                    pool.getMatchAll() != null,
+                    pool.getSelectOneAssumeMatch() != null);
+        } else if (connectionManager.getPartitionedPool() != null) {
+            PartitionedpoolType pool = connectionManager.getPartitionedPool();
+            mcfInfo.maxPoolSize = pool.getMaxSize() != null ? pool.getMaxSize() : defaultMaxSize;
+            mcfInfo.minPoolSize = pool.getMinSize() != null ? pool.getMinSize() : defaultMinSize;
+            mcfInfo.blockingTimeoutMilliseconds = pool.getBlockingTimeoutMilliseconds() != null ? pool.getBlockingTimeoutMilliseconds() : defaultBlockingTimeoutMilliseconds;
+            mcfInfo.idleTimeoutMinutes = pool.getIdleTimeoutMinutes() != null ? pool.getIdleTimeoutMinutes() : defaultIdleTimeoutMinutes;
+            mcfInfo.matchingPolicy = getMatchingPolicy(pool.getMatchOne() != null,
+                    pool.getMatchAll() != null,
+                    pool.getSelectOneAssumeMatch() != null);
+            mcfInfo.poolCardinality = getPoolPartitioning(
+                    pool.getPartitionByConnectionrequestinfo() != null,
+                    pool.getPartitionBySubject() != null);
+        } else if (connectionManager.getNoPool() != null) {
+            mcfInfo.poolCardinality = ManagedConnectionFactoryInfo.PoolCardinality.none;
+        } else {
+            throw new DeploymentException("Unexpected pooling support element in connector named " + connectionfactoryInstance.getName().trim());
+        }
+        try {
+//            String jndiName = naming.toOsgiJndiName(connectionManagerAbstractName);
+//            connectionManagerGBean.getServiceProperties().put(OSGI_JNDI_SERVICE_NAME, jndiName);
+            mcfInfo.transactionSupport = transactionSupport;
+            mcfInfo.transactionManagerTarget = transactionManagerName;
+            mcfInfo.connectionTrackerTarget = connectionTrackerName;
+            if (connectionManager.getContainerManagedSecurity() != null) {
+                //TODO configure subject source??
+            }
+        } catch (Exception e) {
+            throw new DeploymentException("Problem setting up ConnectionManager named " + connectionfactoryInstance.getName().trim(), e);
+        }
+    }
+
+    private ManagedConnectionFactoryInfo.PoolCardinality getPoolPartitioning(boolean partitionByCRI, boolean partitionBySubjct) throws DeploymentException {
+        if (partitionByCRI) {
+            if (partitionBySubjct) {
+                return ManagedConnectionFactoryInfo.PoolCardinality.partitionedBySubjectAndConnectionRequestInfo;
+            }
+            return ManagedConnectionFactoryInfo.PoolCardinality.partitionedByConnectionRequestInfo;
+        }
+        if (partitionBySubjct) {
+            return ManagedConnectionFactoryInfo.PoolCardinality.partitionedBySubject;
+        }
+        throw new DeploymentException("specify at least one of partition by connectionRequestInfo and partition by subject");
+    }
+
+    private ManagedConnectionFactoryInfo.MatchingPolicy getMatchingPolicy(boolean matchOne, boolean matchAll, boolean selectOneAssumeMatch) throws DeploymentException {
+        if (matchOne) {
+            return ManagedConnectionFactoryInfo.MatchingPolicy.selectOne;
+        }
+        if (matchAll) {
+            return ManagedConnectionFactoryInfo.MatchingPolicy.selectAll;
+        }
+        if (selectOneAssumeMatch) {
+            return ManagedConnectionFactoryInfo.MatchingPolicy.selectOneAssumeMatch;
+        }
+        throw new DeploymentException("no matching policy specified");
+    }
+
+    private ManagedConnectionFactoryInfo.TransactionSupport getXATxSupport(boolean txCaching, boolean threadCaching) throws DeploymentException {
+        if (txCaching && !threadCaching) return ManagedConnectionFactoryInfo.TransactionSupport.xaTxCached;
+        if (!txCaching && threadCaching) return ManagedConnectionFactoryInfo.TransactionSupport.xaThreadCached;
+        if (!txCaching && !threadCaching) return ManagedConnectionFactoryInfo.TransactionSupport.xaNoCache;
+        throw new DeploymentException("Both txCaching and threadCaching specified");
+    }
+
+    private void configureOutbound(List<ManagedConnectionFactoryInfo> mcfInfos, ConnectionDefinition connectionDefinition, ConnectiondefinitionInstanceType connectiondefinitionInstance, String transactionSupport, Bundle bundle, String connectionTrackerName, String transactionManagerName) throws DeploymentException {
+        ManagedConnectionFactoryInfo mcfInfo = new ManagedConnectionFactoryInfo();
+        mcfInfos.add(mcfInfo);
+
+        // ManagedConnectionFactory
+        setConfigProperties(mcfInfo.configProperties, connectionDefinition.getManagedConnectionFactoryClass(), connectionDefinition.getConfigProperty(), connectiondefinitionInstance.getConfigPropertySetting(), bundle);
+
+        //Check if Driver class is available here. This should be available in cl. If not log a warning as
+        //the plan gets deployed and while starting GBean an error is thrown
+
+        Object driver = mcfInfo.configProperties.get("Driver");
+        if (driver != null && driver instanceof String) {
+            checkClass(bundle, (String) driver);
+        }
+
+        mcfInfo.managedConnectionFactoryClass = connectionDefinition.getManagedConnectionFactoryClass();
+        //TODO consider supporting list of implemented interfaces
+//        Set<String> implementedInterfaces = new HashSet<String>();
+//        implementedInterfaces.add(checkClass(bundle, (String) managedConnectionFactoryInstanceGBeanData.getAttribute("connectionFactoryInterface")));
+//        implementedInterfaces.add(checkClass(bundle, (String) managedConnectionFactoryInstanceGBeanData.getAttribute("connectionFactoryImplClass")));
+//        try {
+//            //additional interfaces implemented by connection factory
+//            List<String> additionalInterfaces = connectiondefinitionInstance.getImplementedInterface();
+//            if (additionalInterfaces != null) {
+//                for (String additionalInterface : additionalInterfaces) {
+//                    implementedInterfaces.add(checkClass(bundle, additionalInterface.trim()));
+//                }
+//            }
+//            //in case some class was not loadable
+//            implementedInterfaces.remove(null);
+//            managedConnectionFactoryInstanceGBeanData.setAttribute("implementedInterfaces", implementedInterfaces.toArray(new String[implementedInterfaces.size()]));
+//
+//        } catch (Exception e) {
+//            throw new DeploymentException(e);
+//        }
+
+        mcfInfo.name = connectiondefinitionInstance.getName();
+        // ConnectionManager
+        configureConnectionManager(mcfInfo, transactionSupport, connectiondefinitionInstance, connectionTrackerName, transactionManagerName);
+
+        // ConnectionFactory
+//        GBeanData connectionFactoryGBeanData = new GBeanData(connectionFactoryAbstractName, JCAConnectionFactoryImpl.class);
+//        connectionFactoryGBeanData.setReferencePattern("ConnectionManager", connectionManagerName);
+//        connectionFactoryGBeanData.setServiceInterfaces(implementedInterfaces.toArray(new String[implementedInterfaces.size()]));
+//        String jndiName = connectiondefinitionInstance.getJndiName();
+//        if (jndiName == null) {
+//            jndiName = naming.toOsgiJndiName(connectionFactoryAbstractName);
+//        } else {
+//            jndiName = jndiName.trim();
+//        }
+//        connectionFactoryGBeanData.getServiceProperties().put(OSGI_JNDI_SERVICE_NAME, jndiName);
+//
+//        raBeans.add(connectionFactoryGBeanData);
+    }
+
+    /**
+     * check class is loadable: return null and log warning if not.
+     *
+     * @param bundle to use to load the class
+     * @param clazz  name of class to try to load
+     * @return clazz if loadable, null otherwise.
+     */
+    private String checkClass(Bundle bundle, String clazz) {
+        try {
+            bundle.loadClass(clazz);
+            return clazz;
+        } catch (ClassNotFoundException e1) {
+            log.warn("Problem loading class: " + clazz, e1);
+        }
+        return null;
+    }
+
+//    public GBeanData locateActivationSpecInfo(AbstractNameQuery resourceAdapterInstanceQuery, String messageListenerInterface, Configuration configuration) throws DeploymentException {
+//        //First, locate the module gbean from the JCAResourceAdapter instance
+//        AbstractName instanceName;
+//        try {
+//            instanceName = configuration.findGBean(resourceAdapterInstanceQuery);
+//        } catch (GBeanNotFoundException e) {
+//            throw new DeploymentException("No resource adapter instance gbean found matching " + resourceAdapterInstanceQuery + " from configuration " + configuration.getId(), e);
+//        }
+//        String moduleName = (String) instanceName.getName().get(NameFactory.RESOURCE_ADAPTER_MODULE);
+//        Map<String, String> moduleNameMap = new HashMap<String, String>(instanceName.getName());
+//        moduleNameMap.remove(NameFactory.JCA_RESOURCE);
+//        moduleNameMap.remove(NameFactory.RESOURCE_ADAPTER);
+//        moduleNameMap.remove(NameFactory.RESOURCE_ADAPTER_MODULE);
+//        moduleNameMap.put(NameFactory.J2EE_TYPE, NameFactory.RESOURCE_ADAPTER_MODULE);
+//        moduleNameMap.put(NameFactory.J2EE_NAME, moduleName);
+//        AbstractNameQuery nameQuery = new AbstractNameQuery(instanceName.getArtifact(), moduleNameMap, ResourceAdapterModule.class.getName());
+//        //now find the gbeandata and extract the activation spec info.
+//        GBeanData resourceModuleData;
+//        try {
+//            resourceModuleData = configuration.findGBeanData(nameQuery);
+//        } catch (GBeanNotFoundException e) {
+//            throw new DeploymentException("No resource module gbean found matching " + nameQuery + " from configuration " + configuration.getId(), e);
+//        }
+//        Map activationSpecInfos = (Map) resourceModuleData.getAttribute("activationSpecInfoMap");
+//        if (activationSpecInfos == null) {
+//            throw new DeploymentException("No activation spec info map found in resource adapter module: " + resourceModuleData.getAbstractName());
+//        }
+//        return (GBeanData) activationSpecInfos.get(messageListenerInterface);
+//    }
+
+//    private GBeanData locateResourceAdapterGBeanData(GBeanData resourceAdapterModuleData) throws DeploymentException {
+//        GBeanData data = (GBeanData) resourceAdapterModuleData.getAttribute("resourceAdapterGBeanData");
+//        if (data == null) {
+//            throw new DeploymentException("No resource adapter info found for resource adapter module: " + resourceAdapterModuleData.getAbstractName());
+//        }
+//        return data;
+//    }
+
+//    private GBeanData locateAdminObjectInfo(GBeanData resourceAdapterModuleData, String adminObjectInterfaceName) throws DeploymentException {
+//        Map adminObjectInfos = (Map) resourceAdapterModuleData.getAttribute("adminObjectInfoMap");
+//        if (adminObjectInfos == null) {
+//            throw new DeploymentException("No admin object infos found for resource adapter module: " + resourceAdapterModuleData.getAbstractName());
+//        }
+//        return (GBeanData) adminObjectInfos.get(adminObjectInterfaceName);
+//    }
+
+//    private GBeanData locateConnectionFactoryInfo(GBeanData resourceAdapterModuleData, String connectionFactoryInterfaceName) throws DeploymentException {
+//        Map managedConnectionFactoryInfos = (Map) resourceAdapterModuleData.getAttribute("managedConnectionFactoryInfoMap");
+//        if (managedConnectionFactoryInfos == null) {
+//            throw new DeploymentException("No managed connection factory infos found for resource adapter module: " + resourceAdapterModuleData.getAbstractName());
+//        }
+//        return (GBeanData) managedConnectionFactoryInfos.get(connectionFactoryInterfaceName);
+//    }
+
+
+}

Added: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/AdminobjectInstanceType.java
URL: http://svn.apache.org/viewvc/geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/AdminobjectInstanceType.java?rev=1075183&view=auto
==============================================================================
--- geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/AdminobjectInstanceType.java (added)
+++ geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/AdminobjectInstanceType.java Sun Feb 27 23:56:21 2011
@@ -0,0 +1,104 @@
+//
+// This file was generated by the JavaTM Architecture for XML Binding(JAXB) Reference Implementation, vhudson-jaxb-ri-2.1-833 
+// See <a href="http://java.sun.com/xml/jaxb">http://java.sun.com/xml/jaxb</a> 
+// Any modifications to this file will be lost upon recompilation of the source schema. 
+// Generated on: 2011.02.25 at 01:20:32 AM PST 
+//
+
+
+package org.apache.geronimo.connector.deployment.plan;
+
+import java.util.ArrayList;
+import java.util.List;
+import javax.xml.bind.annotation.XmlAccessType;
+import javax.xml.bind.annotation.XmlAccessorType;
+import javax.xml.bind.annotation.XmlElement;
+import javax.xml.bind.annotation.XmlType;
+
+
+/**
+ * <p>Java class for adminobject-instanceType complex type.
+ * 
+ * <p>The following schema fragment specifies the expected content contained within this class.
+ * 
+ * <pre>
+ * &lt;complexType name="adminobject-instanceType">
+ *   &lt;complexContent>
+ *     &lt;restriction base="{http://www.w3.org/2001/XMLSchema}anyType">
+ *       &lt;sequence>
+ *         &lt;element name="message-destination-name" type="{http://www.w3.org/2001/XMLSchema}string"/>
+ *         &lt;element name="config-property-setting" type="{http://geronimo.apache.org/xml/ns/j2ee/connector-1.2}config-property-settingType" maxOccurs="unbounded" minOccurs="0"/>
+ *       &lt;/sequence>
+ *     &lt;/restriction>
+ *   &lt;/complexContent>
+ * &lt;/complexType>
+ * </pre>
+ * 
+ * 
+ */
+@XmlAccessorType(XmlAccessType.FIELD)
+@XmlType(name = "adminobject-instanceType", propOrder = {
+    "messageDestinationName",
+    "configPropertySetting"
+})
+public class AdminobjectInstanceType {
+
+    @XmlElement(name = "message-destination-name", required = true)
+    protected String messageDestinationName;
+    @XmlElement(name = "config-property-setting")
+    protected List<ConfigPropertySettingType> configPropertySetting;
+
+    /**
+     * Gets the value of the messageDestinationName property.
+     * 
+     * @return
+     *     possible object is
+     *     {@link String }
+     *     
+     */
+    public String getMessageDestinationName() {
+        return messageDestinationName;
+    }
+
+    /**
+     * Sets the value of the messageDestinationName property.
+     * 
+     * @param value
+     *     allowed object is
+     *     {@link String }
+     *     
+     */
+    public void setMessageDestinationName(String value) {
+        this.messageDestinationName = value;
+    }
+
+    /**
+     * Gets the value of the configPropertySetting property.
+     * 
+     * <p>
+     * This accessor method returns a reference to the live list,
+     * not a snapshot. Therefore any modification you make to the
+     * returned list will be present inside the JAXB object.
+     * This is why there is not a <CODE>set</CODE> method for the configPropertySetting property.
+     * 
+     * <p>
+     * For example, to add a new item, do as follows:
+     * <pre>
+     *    getConfigPropertySetting().add(newItem);
+     * </pre>
+     * 
+     * 
+     * <p>
+     * Objects of the following type(s) are allowed in the list
+     * {@link ConfigPropertySettingType }
+     * 
+     * 
+     */
+    public List<ConfigPropertySettingType> getConfigPropertySetting() {
+        if (configPropertySetting == null) {
+            configPropertySetting = new ArrayList<ConfigPropertySettingType>();
+        }
+        return this.configPropertySetting;
+    }
+
+}

Propchange: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/AdminobjectInstanceType.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/AdminobjectInstanceType.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision

Propchange: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/AdminobjectInstanceType.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Added: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/AdminobjectType.java
URL: http://svn.apache.org/viewvc/geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/AdminobjectType.java?rev=1075183&view=auto
==============================================================================
--- geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/AdminobjectType.java (added)
+++ geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/AdminobjectType.java Sun Feb 27 23:56:21 2011
@@ -0,0 +1,137 @@
+//
+// This file was generated by the JavaTM Architecture for XML Binding(JAXB) Reference Implementation, vhudson-jaxb-ri-2.1-833 
+// See <a href="http://java.sun.com/xml/jaxb">http://java.sun.com/xml/jaxb</a> 
+// Any modifications to this file will be lost upon recompilation of the source schema. 
+// Generated on: 2011.02.25 at 01:20:32 AM PST 
+//
+
+
+package org.apache.geronimo.connector.deployment.plan;
+
+import java.util.ArrayList;
+import java.util.List;
+import javax.xml.bind.annotation.XmlAccessType;
+import javax.xml.bind.annotation.XmlAccessorType;
+import javax.xml.bind.annotation.XmlElement;
+import javax.xml.bind.annotation.XmlType;
+
+
+/**
+ * 
+ *                 This complex type maps back to adminobjectType complex type in
+ *                 connectors xsd.
+ *             
+ * 
+ * <p>Java class for adminobjectType complex type.
+ * 
+ * <p>The following schema fragment specifies the expected content contained within this class.
+ * 
+ * <pre>
+ * &lt;complexType name="adminobjectType">
+ *   &lt;complexContent>
+ *     &lt;restriction base="{http://www.w3.org/2001/XMLSchema}anyType">
+ *       &lt;sequence>
+ *         &lt;element name="adminobject-interface" type="{http://geronimo.apache.org/xml/ns/j2ee/connector-1.2}fully-qualified-classType"/>
+ *         &lt;element name="adminobject-class" type="{http://geronimo.apache.org/xml/ns/j2ee/connector-1.2}fully-qualified-classType"/>
+ *         &lt;element name="adminobject-instance" type="{http://geronimo.apache.org/xml/ns/j2ee/connector-1.2}adminobject-instanceType" maxOccurs="unbounded" minOccurs="0"/>
+ *       &lt;/sequence>
+ *     &lt;/restriction>
+ *   &lt;/complexContent>
+ * &lt;/complexType>
+ * </pre>
+ * 
+ * 
+ */
+@XmlAccessorType(XmlAccessType.FIELD)
+@XmlType(name = "adminobjectType", propOrder = {
+    "adminobjectInterface",
+    "adminobjectClass",
+    "adminobjectInstance"
+})
+public class AdminobjectType {
+
+    @XmlElement(name = "adminobject-interface", required = true)
+    protected String adminobjectInterface;
+    @XmlElement(name = "adminobject-class", required = true)
+    protected String adminobjectClass;
+    @XmlElement(name = "adminobject-instance")
+    protected List<AdminobjectInstanceType> adminobjectInstance;
+
+    /**
+     * Gets the value of the adminobjectInterface property.
+     * 
+     * @return
+     *     possible object is
+     *     {@link String }
+     *     
+     */
+    public String getAdminobjectInterface() {
+        return adminobjectInterface;
+    }
+
+    /**
+     * Sets the value of the adminobjectInterface property.
+     * 
+     * @param value
+     *     allowed object is
+     *     {@link String }
+     *     
+     */
+    public void setAdminobjectInterface(String value) {
+        this.adminobjectInterface = value;
+    }
+
+    /**
+     * Gets the value of the adminobjectClass property.
+     * 
+     * @return
+     *     possible object is
+     *     {@link String }
+     *     
+     */
+    public String getAdminobjectClass() {
+        return adminobjectClass;
+    }
+
+    /**
+     * Sets the value of the adminobjectClass property.
+     * 
+     * @param value
+     *     allowed object is
+     *     {@link String }
+     *     
+     */
+    public void setAdminobjectClass(String value) {
+        this.adminobjectClass = value;
+    }
+
+    /**
+     * Gets the value of the adminobjectInstance property.
+     * 
+     * <p>
+     * This accessor method returns a reference to the live list,
+     * not a snapshot. Therefore any modification you make to the
+     * returned list will be present inside the JAXB object.
+     * This is why there is not a <CODE>set</CODE> method for the adminobjectInstance property.
+     * 
+     * <p>
+     * For example, to add a new item, do as follows:
+     * <pre>
+     *    getAdminobjectInstance().add(newItem);
+     * </pre>
+     * 
+     * 
+     * <p>
+     * Objects of the following type(s) are allowed in the list
+     * {@link AdminobjectInstanceType }
+     * 
+     * 
+     */
+    public List<AdminobjectInstanceType> getAdminobjectInstance() {
+        if (adminobjectInstance == null) {
+            adminobjectInstance = new ArrayList<AdminobjectInstanceType>();
+        }
+        return this.adminobjectInstance;
+    }
+
+}

Propchange: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/AdminobjectType.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/AdminobjectType.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision

Propchange: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/AdminobjectType.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Added: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConfigPropertySettingType.java
URL: http://svn.apache.org/viewvc/geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConfigPropertySettingType.java?rev=1075183&view=auto
==============================================================================
--- geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConfigPropertySettingType.java (added)
+++ geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConfigPropertySettingType.java Sun Feb 27 23:56:21 2011
@@ -0,0 +1,99 @@
+//
+// This file was generated by the JavaTM Architecture for XML Binding(JAXB) Reference Implementation, vhudson-jaxb-ri-2.1-833 
+// See <a href="http://java.sun.com/xml/jaxb">http://java.sun.com/xml/jaxb</a> 
+// Any modifications to this file will be lost upon recompilation of the source schema. 
+// Generated on: 2011.02.25 at 01:20:32 AM PST 
+//
+
+
+package org.apache.geronimo.connector.deployment.plan;
+
+import javax.xml.bind.annotation.XmlAccessType;
+import javax.xml.bind.annotation.XmlAccessorType;
+import javax.xml.bind.annotation.XmlAttribute;
+import javax.xml.bind.annotation.XmlType;
+import javax.xml.bind.annotation.XmlValue;
+
+
+/**
+ * 
+ *                 The config-property-settingType contains a name-value pair for a
+ *                 config-property or required-config-property
+ *             
+ * 
+ * <p>Java class for config-property-settingType complex type.
+ * 
+ * <p>The following schema fragment specifies the expected content contained within this class.
+ * 
+ * <pre>
+ * &lt;complexType name="config-property-settingType">
+ *   &lt;simpleContent>
+ *     &lt;extension base="&lt;http://www.w3.org/2001/XMLSchema>string">
+ *       &lt;attribute name="name" use="required" type="{http://www.w3.org/2001/XMLSchema}string" />
+ *     &lt;/extension>
+ *   &lt;/simpleContent>
+ * &lt;/complexType>
+ * </pre>
+ * 
+ * 
+ */
+@XmlAccessorType(XmlAccessType.FIELD)
+@XmlType(name = "config-property-settingType", propOrder = {
+    "value"
+})
+public class ConfigPropertySettingType {
+
+    @XmlValue
+    protected String value;
+    @XmlAttribute(required = true)
+    protected String name;
+
+    /**
+     * Gets the value of the value property.
+     * 
+     * @return
+     *     possible object is
+     *     {@link String }
+     *     
+     */
+    public String getValue() {
+        return value;
+    }
+
+    /**
+     * Sets the value of the value property.
+     * 
+     * @param value
+     *     allowed object is
+     *     {@link String }
+     *     
+     */
+    public void setValue(String value) {
+        this.value = value;
+    }
+
+    /**
+     * Gets the value of the name property.
+     * 
+     * @return
+     *     possible object is
+     *     {@link String }
+     *     
+     */
+    public String getName() {
+        return name;
+    }
+
+    /**
+     * Sets the value of the name property.
+     * 
+     * @param value
+     *     allowed object is
+     *     {@link String }
+     *     
+     */
+    public void setName(String value) {
+        this.name = value;
+    }
+
+}

Propchange: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConfigPropertySettingType.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConfigPropertySettingType.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision

Propchange: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConfigPropertySettingType.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Added: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConnectionDefinitionType.java
URL: http://svn.apache.org/viewvc/geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConnectionDefinitionType.java?rev=1075183&view=auto
==============================================================================
--- geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConnectionDefinitionType.java (added)
+++ geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConnectionDefinitionType.java Sun Feb 27 23:56:21 2011
@@ -0,0 +1,114 @@
+//
+// This file was generated by the JavaTM Architecture for XML Binding(JAXB) Reference Implementation, vhudson-jaxb-ri-2.1-833 
+// See <a href="http://java.sun.com/xml/jaxb">http://java.sun.com/xml/jaxb</a> 
+// Any modifications to this file will be lost upon recompilation of the source schema. 
+// Generated on: 2011.02.25 at 01:20:32 AM PST 
+//
+
+
+package org.apache.geronimo.connector.deployment.plan;
+
+import java.util.ArrayList;
+import java.util.List;
+import javax.xml.bind.annotation.XmlAccessType;
+import javax.xml.bind.annotation.XmlAccessorType;
+import javax.xml.bind.annotation.XmlElement;
+import javax.xml.bind.annotation.XmlType;
+
+
+/**
+ * 
+ *                 The connection-definitionType defines a set of connection
+ *                 interfaces and classes pertaining to a particular connection
+ *                 type. This also includes configurable properties for
+ *                 ManagedConnectionFactory instances that may be produced out of
+ *                 this set.
+ * 
+ *                 The name element uniquely identifies this instance
+ *             
+ * 
+ * <p>Java class for connection-definitionType complex type.
+ * 
+ * <p>The following schema fragment specifies the expected content contained within this class.
+ * 
+ * <pre>
+ * &lt;complexType name="connection-definitionType">
+ *   &lt;complexContent>
+ *     &lt;restriction base="{http://www.w3.org/2001/XMLSchema}anyType">
+ *       &lt;sequence>
+ *         &lt;element name="connectionfactory-interface" type="{http://geronimo.apache.org/xml/ns/j2ee/connector-1.2}fully-qualified-classType"/>
+ *         &lt;element name="connectiondefinition-instance" type="{http://geronimo.apache.org/xml/ns/j2ee/connector-1.2}connectiondefinition-instanceType" maxOccurs="unbounded" minOccurs="0"/>
+ *       &lt;/sequence>
+ *     &lt;/restriction>
+ *   &lt;/complexContent>
+ * &lt;/complexType>
+ * </pre>
+ * 
+ * 
+ */
+@XmlAccessorType(XmlAccessType.FIELD)
+@XmlType(name = "connection-definitionType", propOrder = {
+    "connectionfactoryInterface",
+    "connectiondefinitionInstance"
+})
+public class ConnectionDefinitionType {
+
+    @XmlElement(name = "connectionfactory-interface", required = true)
+    protected String connectionfactoryInterface;
+    @XmlElement(name = "connectiondefinition-instance")
+    protected List<ConnectiondefinitionInstanceType> connectiondefinitionInstance;
+
+    /**
+     * Gets the value of the connectionfactoryInterface property.
+     * 
+     * @return
+     *     possible object is
+     *     {@link String }
+     *     
+     */
+    public String getConnectionfactoryInterface() {
+        return connectionfactoryInterface;
+    }
+
+    /**
+     * Sets the value of the connectionfactoryInterface property.
+     * 
+     * @param value
+     *     allowed object is
+     *     {@link String }
+     *     
+     */
+    public void setConnectionfactoryInterface(String value) {
+        this.connectionfactoryInterface = value;
+    }
+
+    /**
+     * Gets the value of the connectiondefinitionInstance property.
+     * 
+     * <p>
+     * This accessor method returns a reference to the live list,
+     * not a snapshot. Therefore any modification you make to the
+     * returned list will be present inside the JAXB object.
+     * This is why there is not a <CODE>set</CODE> method for the connectiondefinitionInstance property.
+     * 
+     * <p>
+     * For example, to add a new item, do as follows:
+     * <pre>
+     *    getConnectiondefinitionInstance().add(newItem);
+     * </pre>
+     * 
+     * 
+     * <p>
+     * Objects of the following type(s) are allowed in the list
+     * {@link ConnectiondefinitionInstanceType }
+     * 
+     * 
+     */
+    public List<ConnectiondefinitionInstanceType> getConnectiondefinitionInstance() {
+        if (connectiondefinitionInstance == null) {
+            connectiondefinitionInstance = new ArrayList<ConnectiondefinitionInstanceType>();
+        }
+        return this.connectiondefinitionInstance;
+    }
+
+}

Propchange: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConnectionDefinitionType.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConnectionDefinitionType.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision

Propchange: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConnectionDefinitionType.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Added: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConnectiondefinitionInstanceType.java
URL: http://svn.apache.org/viewvc/geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConnectiondefinitionInstanceType.java?rev=1075183&view=auto
==============================================================================
--- geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConnectiondefinitionInstanceType.java (added)
+++ geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConnectiondefinitionInstanceType.java Sun Feb 27 23:56:21 2011
@@ -0,0 +1,193 @@
+//
+// This file was generated by the JavaTM Architecture for XML Binding(JAXB) Reference Implementation, vhudson-jaxb-ri-2.1-833 
+// See <a href="http://java.sun.com/xml/jaxb">http://java.sun.com/xml/jaxb</a> 
+// Any modifications to this file will be lost upon recompilation of the source schema. 
+// Generated on: 2011.02.25 at 01:20:32 AM PST 
+//
+
+
+package org.apache.geronimo.connector.deployment.plan;
+
+import java.util.ArrayList;
+import java.util.List;
+import javax.xml.bind.annotation.XmlAccessType;
+import javax.xml.bind.annotation.XmlAccessorType;
+import javax.xml.bind.annotation.XmlElement;
+import javax.xml.bind.annotation.XmlType;
+
+
+/**
+ * <p>Java class for connectiondefinition-instanceType complex type.
+ * 
+ * <p>The following schema fragment specifies the expected content contained within this class.
+ * 
+ * <pre>
+ * &lt;complexType name="connectiondefinition-instanceType">
+ *   &lt;complexContent>
+ *     &lt;restriction base="{http://www.w3.org/2001/XMLSchema}anyType">
+ *       &lt;sequence>
+ *         &lt;element name="name" type="{http://www.w3.org/2001/XMLSchema}string"/>
+ *         &lt;element name="jndi-name" type="{http://www.w3.org/2001/XMLSchema}string" minOccurs="0"/>
+ *         &lt;element name="implemented-interface" type="{http://geronimo.apache.org/xml/ns/j2ee/connector-1.2}fully-qualified-classType" maxOccurs="unbounded" minOccurs="0"/>
+ *         &lt;element name="config-property-setting" type="{http://geronimo.apache.org/xml/ns/j2ee/connector-1.2}config-property-settingType" maxOccurs="unbounded" minOccurs="0"/>
+ *         &lt;element name="connectionmanager" type="{http://geronimo.apache.org/xml/ns/j2ee/connector-1.2}connectionmanagerType"/>
+ *       &lt;/sequence>
+ *     &lt;/restriction>
+ *   &lt;/complexContent>
+ * &lt;/complexType>
+ * </pre>
+ * 
+ * 
+ */
+@XmlAccessorType(XmlAccessType.FIELD)
+@XmlType(name = "connectiondefinition-instanceType", propOrder = {
+    "name",
+    "jndiName",
+    "implementedInterface",
+    "configPropertySetting",
+    "connectionmanager"
+})
+public class ConnectiondefinitionInstanceType {
+
+    @XmlElement(required = true)
+    protected String name;
+    @XmlElement(name = "jndi-name")
+    protected String jndiName;
+    @XmlElement(name = "implemented-interface")
+    protected List<String> implementedInterface;
+    @XmlElement(name = "config-property-setting")
+    protected List<ConfigPropertySettingType> configPropertySetting;
+    @XmlElement(required = true)
+    protected ConnectionmanagerType connectionmanager;
+
+    /**
+     * Gets the value of the name property.
+     * 
+     * @return
+     *     possible object is
+     *     {@link String }
+     *     
+     */
+    public String getName() {
+        return name;
+    }
+
+    /**
+     * Sets the value of the name property.
+     * 
+     * @param value
+     *     allowed object is
+     *     {@link String }
+     *     
+     */
+    public void setName(String value) {
+        this.name = value;
+    }
+
+    /**
+     * Gets the value of the jndiName property.
+     * 
+     * @return
+     *     possible object is
+     *     {@link String }
+     *     
+     */
+    public String getJndiName() {
+        return jndiName;
+    }
+
+    /**
+     * Sets the value of the jndiName property.
+     * 
+     * @param value
+     *     allowed object is
+     *     {@link String }
+     *     
+     */
+    public void setJndiName(String value) {
+        this.jndiName = value;
+    }
+
+    /**
+     * Gets the value of the implementedInterface property.
+     * 
+     * <p>
+     * This accessor method returns a reference to the live list,
+     * not a snapshot. Therefore any modification you make to the
+     * returned list will be present inside the JAXB object.
+     * This is why there is not a <CODE>set</CODE> method for the implementedInterface property.
+     * 
+     * <p>
+     * For example, to add a new item, do as follows:
+     * <pre>
+     *    getImplementedInterface().add(newItem);
+     * </pre>
+     * 
+     * 
+     * <p>
+     * Objects of the following type(s) are allowed in the list
+     * {@link String }
+     * 
+     * 
+     */
+    public List<String> getImplementedInterface() {
+        if (implementedInterface == null) {
+            implementedInterface = new ArrayList<String>();
+        }
+        return this.implementedInterface;
+    }
+
+    /**
+     * Gets the value of the configPropertySetting property.
+     * 
+     * <p>
+     * This accessor method returns a reference to the live list,
+     * not a snapshot. Therefore any modification you make to the
+     * returned list will be present inside the JAXB object.
+     * This is why there is not a <CODE>set</CODE> method for the configPropertySetting property.
+     * 
+     * <p>
+     * For example, to add a new item, do as follows:
+     * <pre>
+     *    getConfigPropertySetting().add(newItem);
+     * </pre>
+     * 
+     * 
+     * <p>
+     * Objects of the following type(s) are allowed in the list
+     * {@link ConfigPropertySettingType }
+     * 
+     * 
+     */
+    public List<ConfigPropertySettingType> getConfigPropertySetting() {
+        if (configPropertySetting == null) {
+            configPropertySetting = new ArrayList<ConfigPropertySettingType>();
+        }
+        return this.configPropertySetting;
+    }
+
+    /**
+     * Gets the value of the connectionmanager property.
+     * 
+     * @return
+     *     possible object is
+     *     {@link ConnectionmanagerType }
+     *     
+     */
+    public ConnectionmanagerType getConnectionmanager() {
+        return connectionmanager;
+    }
+
+    /**
+     * Sets the value of the connectionmanager property.
+     * 
+     * @param value
+     *     allowed object is
+     *     {@link ConnectionmanagerType }
+     *     
+     */
+    public void setConnectionmanager(ConnectionmanagerType value) {
+        this.connectionmanager = value;
+    }
+
+}

Propchange: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConnectiondefinitionInstanceType.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConnectiondefinitionInstanceType.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision

Propchange: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConnectiondefinitionInstanceType.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Added: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConnectionmanagerType.java
URL: http://svn.apache.org/viewvc/geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConnectionmanagerType.java?rev=1075183&view=auto
==============================================================================
--- geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConnectionmanagerType.java (added)
+++ geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConnectionmanagerType.java Sun Feb 27 23:56:21 2011
@@ -0,0 +1,274 @@
+//
+// This file was generated by the JavaTM Architecture for XML Binding(JAXB) Reference Implementation, vhudson-jaxb-ri-2.1-833 
+// See <a href="http://java.sun.com/xml/jaxb">http://java.sun.com/xml/jaxb</a> 
+// Any modifications to this file will be lost upon recompilation of the source schema. 
+// Generated on: 2011.02.25 at 01:20:32 AM PST 
+//
+
+
+package org.apache.geronimo.connector.deployment.plan;
+
+import javax.xml.bind.annotation.XmlAccessType;
+import javax.xml.bind.annotation.XmlAccessorType;
+import javax.xml.bind.annotation.XmlElement;
+import javax.xml.bind.annotation.XmlType;
+
+
+/**
+ * 
+ *                 The connectionmanager element specifies the connection specific
+ *                 settings like transaction, security, and connection pool.
+ *             
+ * 
+ * <p>Java class for connectionmanagerType complex type.
+ * 
+ * <p>The following schema fragment specifies the expected content contained within this class.
+ * 
+ * <pre>
+ * &lt;complexType name="connectionmanagerType">
+ *   &lt;complexContent>
+ *     &lt;restriction base="{http://www.w3.org/2001/XMLSchema}anyType">
+ *       &lt;sequence>
+ *         &lt;element name="container-managed-security" type="{http://geronimo.apache.org/xml/ns/j2ee/connector-1.2}emptyType" minOccurs="0"/>
+ *         &lt;choice minOccurs="0">
+ *           &lt;element name="no-transaction" type="{http://geronimo.apache.org/xml/ns/j2ee/connector-1.2}emptyType"/>
+ *           &lt;element name="local-transaction" type="{http://geronimo.apache.org/xml/ns/j2ee/connector-1.2}emptyType"/>
+ *           &lt;element name="xa-transaction" type="{http://geronimo.apache.org/xml/ns/j2ee/connector-1.2}xatransactionType"/>
+ *           &lt;element name="transaction-log" type="{http://geronimo.apache.org/xml/ns/j2ee/connector-1.2}emptyType"/>
+ *         &lt;/choice>
+ *         &lt;choice>
+ *           &lt;element name="no-pool" type="{http://geronimo.apache.org/xml/ns/j2ee/connector-1.2}emptyType"/>
+ *           &lt;element name="single-pool" type="{http://geronimo.apache.org/xml/ns/j2ee/connector-1.2}singlepoolType"/>
+ *           &lt;element name="partitioned-pool" type="{http://geronimo.apache.org/xml/ns/j2ee/connector-1.2}partitionedpoolType"/>
+ *         &lt;/choice>
+ *       &lt;/sequence>
+ *     &lt;/restriction>
+ *   &lt;/complexContent>
+ * &lt;/complexType>
+ * </pre>
+ * 
+ * 
+ */
+@XmlAccessorType(XmlAccessType.FIELD)
+@XmlType(name = "connectionmanagerType", propOrder = {
+    "containerManagedSecurity",
+    "noTransaction",
+    "localTransaction",
+    "xaTransaction",
+    "transactionLog",
+    "noPool",
+    "singlePool",
+    "partitionedPool"
+})
+public class ConnectionmanagerType {
+
+    @XmlElement(name = "container-managed-security")
+    protected EmptyType containerManagedSecurity;
+    @XmlElement(name = "no-transaction")
+    protected EmptyType noTransaction;
+    @XmlElement(name = "local-transaction")
+    protected EmptyType localTransaction;
+    @XmlElement(name = "xa-transaction")
+    protected XatransactionType xaTransaction;
+    @XmlElement(name = "transaction-log")
+    protected EmptyType transactionLog;
+    @XmlElement(name = "no-pool")
+    protected EmptyType noPool;
+    @XmlElement(name = "single-pool")
+    protected SinglepoolType singlePool;
+    @XmlElement(name = "partitioned-pool")
+    protected PartitionedpoolType partitionedPool;
+
+    /**
+     * Gets the value of the containerManagedSecurity property.
+     * 
+     * @return
+     *     possible object is
+     *     {@link EmptyType }
+     *     
+     */
+    public EmptyType getContainerManagedSecurity() {
+        return containerManagedSecurity;
+    }
+
+    /**
+     * Sets the value of the containerManagedSecurity property.
+     * 
+     * @param value
+     *     allowed object is
+     *     {@link EmptyType }
+     *     
+     */
+    public void setContainerManagedSecurity(EmptyType value) {
+        this.containerManagedSecurity = value;
+    }
+
+    /**
+     * Gets the value of the noTransaction property.
+     * 
+     * @return
+     *     possible object is
+     *     {@link EmptyType }
+     *     
+     */
+    public EmptyType getNoTransaction() {
+        return noTransaction;
+    }
+
+    /**
+     * Sets the value of the noTransaction property.
+     * 
+     * @param value
+     *     allowed object is
+     *     {@link EmptyType }
+     *     
+     */
+    public void setNoTransaction(EmptyType value) {
+        this.noTransaction = value;
+    }
+
+    /**
+     * Gets the value of the localTransaction property.
+     * 
+     * @return
+     *     possible object is
+     *     {@link EmptyType }
+     *     
+     */
+    public EmptyType getLocalTransaction() {
+        return localTransaction;
+    }
+
+    /**
+     * Sets the value of the localTransaction property.
+     * 
+     * @param value
+     *     allowed object is
+     *     {@link EmptyType }
+     *     
+     */
+    public void setLocalTransaction(EmptyType value) {
+        this.localTransaction = value;
+    }
+
+    /**
+     * Gets the value of the xaTransaction property.
+     * 
+     * @return
+     *     possible object is
+     *     {@link XatransactionType }
+     *     
+     */
+    public XatransactionType getXaTransaction() {
+        return xaTransaction;
+    }
+
+    /**
+     * Sets the value of the xaTransaction property.
+     * 
+     * @param value
+     *     allowed object is
+     *     {@link XatransactionType }
+     *     
+     */
+    public void setXaTransaction(XatransactionType value) {
+        this.xaTransaction = value;
+    }
+
+    /**
+     * Gets the value of the transactionLog property.
+     * 
+     * @return
+     *     possible object is
+     *     {@link EmptyType }
+     *     
+     */
+    public EmptyType getTransactionLog() {
+        return transactionLog;
+    }
+
+    /**
+     * Sets the value of the transactionLog property.
+     * 
+     * @param value
+     *     allowed object is
+     *     {@link EmptyType }
+     *     
+     */
+    public void setTransactionLog(EmptyType value) {
+        this.transactionLog = value;
+    }
+
+    /**
+     * Gets the value of the noPool property.
+     * 
+     * @return
+     *     possible object is
+     *     {@link EmptyType }
+     *     
+     */
+    public EmptyType getNoPool() {
+        return noPool;
+    }
+
+    /**
+     * Sets the value of the noPool property.
+     * 
+     * @param value
+     *     allowed object is
+     *     {@link EmptyType }
+     *     
+     */
+    public void setNoPool(EmptyType value) {
+        this.noPool = value;
+    }
+
+    /**
+     * Gets the value of the singlePool property.
+     * 
+     * @return
+     *     possible object is
+     *     {@link SinglepoolType }
+     *     
+     */
+    public SinglepoolType getSinglePool() {
+        return singlePool;
+    }
+
+    /**
+     * Sets the value of the singlePool property.
+     * 
+     * @param value
+     *     allowed object is
+     *     {@link SinglepoolType }
+     *     
+     */
+    public void setSinglePool(SinglepoolType value) {
+        this.singlePool = value;
+    }
+
+    /**
+     * Gets the value of the partitionedPool property.
+     * 
+     * @return
+     *     possible object is
+     *     {@link PartitionedpoolType }
+     *     
+     */
+    public PartitionedpoolType getPartitionedPool() {
+        return partitionedPool;
+    }
+
+    /**
+     * Sets the value of the partitionedPool property.
+     * 
+     * @param value
+     *     allowed object is
+     *     {@link PartitionedpoolType }
+     *     
+     */
+    public void setPartitionedPool(PartitionedpoolType value) {
+        this.partitionedPool = value;
+    }
+
+}

Propchange: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConnectionmanagerType.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConnectionmanagerType.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision

Propchange: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConnectionmanagerType.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Added: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConnectorType.java
URL: http://svn.apache.org/viewvc/geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConnectorType.java?rev=1075183&view=auto
==============================================================================
--- geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConnectorType.java (added)
+++ geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConnectorType.java Sun Feb 27 23:56:21 2011
@@ -0,0 +1,116 @@
+//
+// This file was generated by the JavaTM Architecture for XML Binding(JAXB) Reference Implementation, vhudson-jaxb-ri-2.1-833 
+// See <a href="http://java.sun.com/xml/jaxb">http://java.sun.com/xml/jaxb</a> 
+// Any modifications to this file will be lost upon recompilation of the source schema. 
+// Generated on: 2011.02.25 at 01:20:32 AM PST 
+//
+
+
+package org.apache.geronimo.connector.deployment.plan;
+
+import java.util.ArrayList;
+import java.util.List;
+import javax.xml.bind.annotation.XmlAccessType;
+import javax.xml.bind.annotation.XmlAccessorType;
+import javax.xml.bind.annotation.XmlElement;
+import javax.xml.bind.annotation.XmlType;
+
+
+/**
+ * 
+ *                 The connector element is the root element of the deployment
+ *                 descriptor for the resource adapter. Note that the sub-elements
+ *                 of this element should be as in the given order in a sequence.
+ *                 It includes geronimo specific information for the resource
+ *                 adapter library.
+ *             
+ * 
+ * <p>Java class for connectorType complex type.
+ * 
+ * <p>The following schema fragment specifies the expected content contained within this class.
+ * 
+ * <pre>
+ * &lt;complexType name="connectorType">
+ *   &lt;complexContent>
+ *     &lt;restriction base="{http://www.w3.org/2001/XMLSchema}anyType">
+ *       &lt;sequence>
+ *         &lt;element name="resourceadapter" type="{http://geronimo.apache.org/xml/ns/j2ee/connector-1.2}resourceadapterType" maxOccurs="unbounded"/>
+ *         &lt;element name="adminobject" type="{http://geronimo.apache.org/xml/ns/j2ee/connector-1.2}adminobjectType" maxOccurs="unbounded" minOccurs="0"/>
+ *       &lt;/sequence>
+ *     &lt;/restriction>
+ *   &lt;/complexContent>
+ * &lt;/complexType>
+ * </pre>
+ * 
+ * 
+ */
+@XmlAccessorType(XmlAccessType.FIELD)
+@XmlType(name = "connectorType", propOrder = {
+    "resourceadapter",
+    "adminobject"
+})
+public class ConnectorType {
+
+    @XmlElement(required = true)
+    protected List<ResourceadapterType> resourceadapter;
+    protected List<AdminobjectType> adminobject;
+
+    /**
+     * Gets the value of the resourceadapter property.
+     * 
+     * <p>
+     * This accessor method returns a reference to the live list,
+     * not a snapshot. Therefore any modification you make to the
+     * returned list will be present inside the JAXB object.
+     * This is why there is not a <CODE>set</CODE> method for the resourceadapter property.
+     * 
+     * <p>
+     * For example, to add a new item, do as follows:
+     * <pre>
+     *    getResourceadapter().add(newItem);
+     * </pre>
+     * 
+     * 
+     * <p>
+     * Objects of the following type(s) are allowed in the list
+     * {@link ResourceadapterType }
+     * 
+     * 
+     */
+    public List<ResourceadapterType> getResourceadapter() {
+        if (resourceadapter == null) {
+            resourceadapter = new ArrayList<ResourceadapterType>();
+        }
+        return this.resourceadapter;
+    }
+
+    /**
+     * Gets the value of the adminobject property.
+     * 
+     * <p>
+     * This accessor method returns a reference to the live list,
+     * not a snapshot. Therefore any modification you make to the
+     * returned list will be present inside the JAXB object.
+     * This is why there is not a <CODE>set</CODE> method for the adminobject property.
+     * 
+     * <p>
+     * For example, to add a new item, do as follows:
+     * <pre>
+     *    getAdminobject().add(newItem);
+     * </pre>
+     * 
+     * 
+     * <p>
+     * Objects of the following type(s) are allowed in the list
+     * {@link AdminobjectType }
+     * 
+     * 
+     */
+    public List<AdminobjectType> getAdminobject() {
+        if (adminobject == null) {
+            adminobject = new ArrayList<AdminobjectType>();
+        }
+        return this.adminobject;
+    }
+
+}

Propchange: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConnectorType.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConnectorType.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision

Propchange: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/ConnectorType.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Added: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/DescriptionType.java
URL: http://svn.apache.org/viewvc/geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/DescriptionType.java?rev=1075183&view=auto
==============================================================================
--- geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/DescriptionType.java (added)
+++ geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/DescriptionType.java Sun Feb 27 23:56:21 2011
@@ -0,0 +1,94 @@
+//
+// This file was generated by the JavaTM Architecture for XML Binding(JAXB) Reference Implementation, vhudson-jaxb-ri-2.1-833 
+// See <a href="http://java.sun.com/xml/jaxb">http://java.sun.com/xml/jaxb</a> 
+// Any modifications to this file will be lost upon recompilation of the source schema. 
+// Generated on: 2011.02.25 at 01:20:32 AM PST 
+//
+
+
+package org.apache.geronimo.connector.deployment.plan;
+
+import javax.xml.bind.annotation.XmlAccessType;
+import javax.xml.bind.annotation.XmlAccessorType;
+import javax.xml.bind.annotation.XmlAttribute;
+import javax.xml.bind.annotation.XmlType;
+import javax.xml.bind.annotation.XmlValue;
+
+
+/**
+ * <p>Java class for descriptionType complex type.
+ * 
+ * <p>The following schema fragment specifies the expected content contained within this class.
+ * 
+ * <pre>
+ * &lt;complexType name="descriptionType">
+ *   &lt;simpleContent>
+ *     &lt;extension base="&lt;http://www.w3.org/2001/XMLSchema>string">
+ *       &lt;attribute ref="{http://www.w3.org/XML/1998/namespace}lang"/>
+ *     &lt;/extension>
+ *   &lt;/simpleContent>
+ * &lt;/complexType>
+ * </pre>
+ * 
+ * 
+ */
+@XmlAccessorType(XmlAccessType.FIELD)
+@XmlType(name = "descriptionType", propOrder = {
+    "value"
+})
+public class DescriptionType {
+
+    @XmlValue
+    protected String value;
+    @XmlAttribute(namespace = "http://www.w3.org/XML/1998/namespace")
+    protected String lang;
+
+    /**
+     * Gets the value of the value property.
+     * 
+     * @return
+     *     possible object is
+     *     {@link String }
+     *     
+     */
+    public String getValue() {
+        return value;
+    }
+
+    /**
+     * Sets the value of the value property.
+     * 
+     * @param value
+     *     allowed object is
+     *     {@link String }
+     *     
+     */
+    public void setValue(String value) {
+        this.value = value;
+    }
+
+    /**
+     * Gets the value of the lang property.
+     * 
+     * @return
+     *     possible object is
+     *     {@link String }
+     *     
+     */
+    public String getLang() {
+        return lang;
+    }
+
+    /**
+     * Sets the value of the lang property.
+     * 
+     * @param value
+     *     allowed object is
+     *     {@link String }
+     *     
+     */
+    public void setLang(String value) {
+        this.lang = value;
+    }
+
+}

Propchange: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/DescriptionType.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/DescriptionType.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision

Propchange: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/DescriptionType.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Added: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/EmptyType.java
URL: http://svn.apache.org/viewvc/geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/EmptyType.java?rev=1075183&view=auto
==============================================================================
--- geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/EmptyType.java (added)
+++ geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/EmptyType.java Sun Feb 27 23:56:21 2011
@@ -0,0 +1,37 @@
+//
+// This file was generated by the JavaTM Architecture for XML Binding(JAXB) Reference Implementation, vhudson-jaxb-ri-2.1-833 
+// See <a href="http://java.sun.com/xml/jaxb">http://java.sun.com/xml/jaxb</a> 
+// Any modifications to this file will be lost upon recompilation of the source schema. 
+// Generated on: 2011.02.25 at 01:20:32 AM PST 
+//
+
+
+package org.apache.geronimo.connector.deployment.plan;
+
+import javax.xml.bind.annotation.XmlAccessType;
+import javax.xml.bind.annotation.XmlAccessorType;
+import javax.xml.bind.annotation.XmlType;
+
+
+/**
+ * <p>Java class for emptyType complex type.
+ * 
+ * <p>The following schema fragment specifies the expected content contained within this class.
+ * 
+ * <pre>
+ * &lt;complexType name="emptyType">
+ *   &lt;complexContent>
+ *     &lt;restriction base="{http://www.w3.org/2001/XMLSchema}anyType">
+ *     &lt;/restriction>
+ *   &lt;/complexContent>
+ * &lt;/complexType>
+ * </pre>
+ * 
+ * 
+ */
+@XmlAccessorType(XmlAccessType.FIELD)
+@XmlType(name = "emptyType")
+public class EmptyType {
+
+
+}

Propchange: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/EmptyType.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/EmptyType.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision

Propchange: geronimo/sandbox/djencks/txmanager/geronimo-connector-builder-1_6/src/main/java/org/apache/geronimo/connector/deployment/plan/EmptyType.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain