You are viewing a plain text version of this content. The canonical link for it is here.
Posted to derby-commits@db.apache.org by dj...@apache.org on 2005/01/11 00:35:07 UTC

svn commit: r124847 - in incubator/derby/code/trunk/java/engine/org/apache/derby: catalog/types iapi/sql/depend iapi/sql/dictionary impl/jdbc impl/sql/catalog impl/sql/compile impl/sql/depend impl/sql/execute

Author: djd
Date: Mon Jan 10 15:35:04 2005
New Revision: 124847

URL: http://svn.apache.org/viewcvs?view=rev&rev=124847
Log:
Remove the RowList class, replacing its use with simple ExecRow[] (arrays).

Clean up some code related to ProviderList, remove handling of
dependencies for defaults since defaults are constants.

This is a step towards removing ProviderList class, which can be simply
replaced with java.util.List. First I'm checking to see how it is used,
since some of its use is left over from the old Cloudsync product.

Removed:
   incubator/derby/code/trunk/java/engine/org/apache/derby/iapi/sql/dictionary/RowList.java
Modified:
   incubator/derby/code/trunk/java/engine/org/apache/derby/catalog/types/DefaultInfoImpl.java
   incubator/derby/code/trunk/java/engine/org/apache/derby/iapi/sql/depend/ProviderList.java
   incubator/derby/code/trunk/java/engine/org/apache/derby/iapi/sql/dictionary/TabInfo.java
   incubator/derby/code/trunk/java/engine/org/apache/derby/impl/jdbc/ConnectionChild.java
   incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/catalog/DataDictionaryImpl.java
   incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/catalog/TabInfoImpl.java
   incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/ColumnDefinitionNode.java
   incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/CompilerContextImpl.java
   incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/ConstraintDefinitionNode.java
   incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/CreateViewNode.java
   incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/DefaultNode.java
   incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/TableElementList.java
   incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/depend/BasicDependencyManager.java
   incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/AlterTableConstantAction.java
   incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/CreateTableConstantAction.java

Modified: incubator/derby/code/trunk/java/engine/org/apache/derby/catalog/types/DefaultInfoImpl.java
Url: http://svn.apache.org/viewcvs/incubator/derby/code/trunk/java/engine/org/apache/derby/catalog/types/DefaultInfoImpl.java?view=diff&rev=124847&p1=incubator/derby/code/trunk/java/engine/org/apache/derby/catalog/types/DefaultInfoImpl.java&r1=124846&p2=incubator/derby/code/trunk/java/engine/org/apache/derby/catalog/types/DefaultInfoImpl.java&r2=124847
==============================================================================
--- incubator/derby/code/trunk/java/engine/org/apache/derby/catalog/types/DefaultInfoImpl.java	(original)
+++ incubator/derby/code/trunk/java/engine/org/apache/derby/catalog/types/DefaultInfoImpl.java	Mon Jan 10 15:35:04 2005
@@ -2,7 +2,7 @@
 
    Derby - Class org.apache.derby.catalog.types.DefaultInfoImpl
 
-   Copyright 1999, 2004 The Apache Software Foundation or its licensors, as applicable.
+   Copyright 1999, 2005 The Apache Software Foundation or its licensors, as applicable.
 
    Licensed under the Apache License, Version 2.0 (the "License");
    you may not use this file except in compliance with the License.
@@ -53,7 +53,6 @@
 
 	private DataValueDescriptor	defaultValue;
 	private String				defaultText;
-	private ProviderInfo[]		providerInfo;
 
 	/**
 	 * Public niladic constructor. Needed for Formatable interface to work.
@@ -102,15 +101,7 @@
 	{
 		defaultText = (String) in.readObject();
 		defaultValue = (DataValueDescriptor) in.readObject();
-		int providerInfoLength = in.readInt();
-		if (providerInfoLength > 0)
-		{
-			providerInfo = new ProviderInfo[providerInfoLength];
-			for (int index = 0; index < providerInfoLength; index++)
-			{
-				providerInfo[index] = (ProviderInfo) in.readObject();
-			}
-		}
+		in.readInt(); // old provider info count - always 0.
 	}
 
 	/**
@@ -125,18 +116,7 @@
 	{
 		out.writeObject( defaultText );
 		out.writeObject( defaultValue );
-		if (providerInfo != null)
-		{
-			out.writeInt(providerInfo.length);
-			for (int index = 0; index < providerInfo.length; index++)
-			{
-				out.writeObject(providerInfo[index]);
-			}
-		}
-		else
-		{
-			out.writeInt(0);
-		}
+		out.writeInt(0); // old provider info count - always 0.
 	}
  
 	/**
@@ -168,27 +148,5 @@
 	public void setDefaultValue(DataValueDescriptor defaultValue)
 	{
 		this.defaultValue = defaultValue;
-	}
-
-	/**
-	 * Set the ProviderInfo. (Providers that default is dependent on.)
-	 *
-	 * @param providerInfo	Providers that default is dependent on.
-	 *
-	 * @return Nothing.
-	 */
-	public void setProviderInfo(ProviderInfo[] providerInfo)
-	{
-		this.providerInfo = providerInfo;
-	}
-
-	/**
-	 * Get the ProviderInfo. (Providers that default is dependent on.)
-	 *
-	 * @return Providers that default is dependent on.
-	 */
-	public ProviderInfo[] getProviderInfo()
-	{
-		return providerInfo;
 	}
 }

Modified: incubator/derby/code/trunk/java/engine/org/apache/derby/iapi/sql/depend/ProviderList.java
Url: http://svn.apache.org/viewcvs/incubator/derby/code/trunk/java/engine/org/apache/derby/iapi/sql/depend/ProviderList.java?view=diff&rev=124847&p1=incubator/derby/code/trunk/java/engine/org/apache/derby/iapi/sql/depend/ProviderList.java&r1=124846&p2=incubator/derby/code/trunk/java/engine/org/apache/derby/iapi/sql/depend/ProviderList.java&r2=124847
==============================================================================
--- incubator/derby/code/trunk/java/engine/org/apache/derby/iapi/sql/depend/ProviderList.java	(original)
+++ incubator/derby/code/trunk/java/engine/org/apache/derby/iapi/sql/depend/ProviderList.java	Mon Jan 10 15:35:04 2005
@@ -2,7 +2,7 @@
 
    Derby - Class org.apache.derby.iapi.sql.depend.ProviderList
 
-   Copyright 1999, 2004 The Apache Software Foundation or its licensors, as applicable.
+   Copyright 1999, 2005 The Apache Software Foundation or its licensors, as applicable.
 
    Licensed under the Apache License, Version 2.0 (the "License");
    you may not use this file except in compliance with the License.
@@ -20,9 +20,6 @@
 
 package org.apache.derby.iapi.sql.depend;
 
-import org.apache.derby.iapi.error.StandardException;
-
-import java.util.Enumeration;
 import java.util.Hashtable;
 
 /**

Deleted: /incubator/derby/code/trunk/java/engine/org/apache/derby/iapi/sql/dictionary/RowList.java
Url: http://svn.apache.org/viewcvs/incubator/derby/code/trunk/java/engine/org/apache/derby/iapi/sql/dictionary/RowList.java?view=auto&rev=124846
==============================================================================

Modified: incubator/derby/code/trunk/java/engine/org/apache/derby/iapi/sql/dictionary/TabInfo.java
Url: http://svn.apache.org/viewcvs/incubator/derby/code/trunk/java/engine/org/apache/derby/iapi/sql/dictionary/TabInfo.java?view=diff&rev=124847&p1=incubator/derby/code/trunk/java/engine/org/apache/derby/iapi/sql/dictionary/TabInfo.java&r1=124846&p2=incubator/derby/code/trunk/java/engine/org/apache/derby/iapi/sql/dictionary/TabInfo.java&r2=124847
==============================================================================
--- incubator/derby/code/trunk/java/engine/org/apache/derby/iapi/sql/dictionary/TabInfo.java	(original)
+++ incubator/derby/code/trunk/java/engine/org/apache/derby/iapi/sql/dictionary/TabInfo.java	Mon Jan 10 15:35:04 2005
@@ -2,7 +2,7 @@
 
    Derby - Class org.apache.derby.iapi.sql.dictionary.TabInfo
 
-   Copyright 1997, 2004 The Apache Software Foundation or its licensors, as applicable.
+   Copyright 1997, 2005 The Apache Software Foundation or its licensors, as applicable.
 
    Licensed under the Apache License, Version 2.0 (the "License");
    you may not use this file except in compliance with the License.
@@ -256,7 +256,7 @@
 	 *
 	 * @exception StandardException		Thrown on failure
 	 */
-	public int insertRowList( RowList rowList, TransactionController tc )
+	public int insertRowList(ExecRow[] rowList, TransactionController tc )
 		throws StandardException;
 
 	/**

Modified: incubator/derby/code/trunk/java/engine/org/apache/derby/impl/jdbc/ConnectionChild.java
Url: http://svn.apache.org/viewcvs/incubator/derby/code/trunk/java/engine/org/apache/derby/impl/jdbc/ConnectionChild.java?view=diff&rev=124847&p1=incubator/derby/code/trunk/java/engine/org/apache/derby/impl/jdbc/ConnectionChild.java&r1=124846&p2=incubator/derby/code/trunk/java/engine/org/apache/derby/impl/jdbc/ConnectionChild.java&r2=124847
==============================================================================
--- incubator/derby/code/trunk/java/engine/org/apache/derby/impl/jdbc/ConnectionChild.java	(original)
+++ incubator/derby/code/trunk/java/engine/org/apache/derby/impl/jdbc/ConnectionChild.java	Mon Jan 10 15:35:04 2005
@@ -2,7 +2,7 @@
 
    Derby - Class org.apache.derby.impl.jdbc.ConnectionChild
 
-   Copyright 1997, 2004 The Apache Software Foundation or its licensors, as applicable.
+   Copyright 1997, 2005 The Apache Software Foundation or its licensors, as applicable.
 
    Licensed under the Apache License, Version 2.0 (the "License");
    you may not use this file except in compliance with the License.
@@ -33,7 +33,7 @@
 	refer back to the EmbedConnection object extends this class.
 */
 
-public abstract class ConnectionChild {
+abstract class ConnectionChild {
 
 	// parameters to handleException
 	protected static final boolean CLOSE = true;

Modified: incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/catalog/DataDictionaryImpl.java
Url: http://svn.apache.org/viewcvs/incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/catalog/DataDictionaryImpl.java?view=diff&rev=124847&p1=incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/catalog/DataDictionaryImpl.java&r1=124846&p2=incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/catalog/DataDictionaryImpl.java&r2=124847
==============================================================================
--- incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/catalog/DataDictionaryImpl.java	(original)
+++ incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/catalog/DataDictionaryImpl.java	Mon Jan 10 15:35:04 2005
@@ -2,7 +2,7 @@
 
    Derby - Class org.apache.derby.impl.sql.catalog.DataDictionaryImpl
 
-   Copyright 1997, 2004 The Apache Software Foundation or its licensors, as applicable.
+   Copyright 1997, 2005 The Apache Software Foundation or its licensors, as applicable.
 
    Licensed under the Apache License, Version 2.0 (the "License");
    you may not use this file except in compliance with the License.
@@ -48,7 +48,6 @@
 import org.apache.derby.iapi.sql.dictionary.IndexRowGenerator;
 import org.apache.derby.iapi.sql.dictionary.KeyConstraintDescriptor;
 import org.apache.derby.iapi.sql.dictionary.ReferencedKeyConstraintDescriptor;
-import org.apache.derby.iapi.sql.dictionary.RowList;
 import org.apache.derby.iapi.sql.dictionary.SPSDescriptor;
 import org.apache.derby.iapi.sql.dictionary.SchemaDescriptor;
 import org.apache.derby.iapi.sql.dictionary.CheckConstraintDescriptor;
@@ -1529,12 +1528,13 @@
 		TabInfo ti =  (catalogNumber < NUM_CORE) ? coreInfo[catalogNumber] :
 			getNonCoreTI(catalogNumber);
 		CatalogRowFactory crf = ti.getCatalogRowFactory();
-		RowList rl = new RowList();
+
+		ExecRow[] rl = new ExecRow[td.length];
 
 		for (int index = 0; index < td.length; index++)
 		{
 			ExecRow row = crf.makeRow(td[index], parent);
-			rl.add(row);
+			rl[index] = row;
 		}
 
 		int insertRetCode = ti.insertRowList( rl, tc );

Modified: incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/catalog/TabInfoImpl.java
Url: http://svn.apache.org/viewcvs/incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/catalog/TabInfoImpl.java?view=diff&rev=124847&p1=incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/catalog/TabInfoImpl.java&r1=124846&p2=incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/catalog/TabInfoImpl.java&r2=124847
==============================================================================
--- incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/catalog/TabInfoImpl.java	(original)
+++ incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/catalog/TabInfoImpl.java	Mon Jan 10 15:35:04 2005
@@ -2,7 +2,7 @@
 
    Derby - Class org.apache.derby.impl.sql.catalog.TabInfoImpl
 
-   Copyright 1997, 2004 The Apache Software Foundation or its licensors, as applicable.
+   Copyright 1997, 2005 The Apache Software Foundation or its licensors, as applicable.
 
    Licensed under the Apache License, Version 2.0 (the "License");
    you may not use this file except in compliance with the License.
@@ -29,7 +29,6 @@
 import org.apache.derby.iapi.sql.dictionary.CatalogRowFactory;
 import org.apache.derby.iapi.sql.dictionary.ConglomerateDescriptor;
 import org.apache.derby.iapi.sql.dictionary.IndexRowGenerator;
-import org.apache.derby.iapi.sql.dictionary.RowList;
 import org.apache.derby.iapi.sql.dictionary.TabInfo;
 import org.apache.derby.iapi.sql.execute.ExecIndexRow;
 import org.apache.derby.iapi.sql.execute.ExecRow;
@@ -415,13 +414,10 @@
 	public int insertRow( ExecRow row, TransactionController tc, boolean wait)
 		throws StandardException
 	{
-		RowList					rowList = new RowList( this );
-
-		rowList.add(row);
 
 		RowLocation[] 			notUsed = new RowLocation[1]; 
 
-		return insertRowListImpl(rowList,tc,notUsed, wait);
+		return insertRowListImpl(new ExecRow[] {row},tc,notUsed, wait);
 	}
 
 
@@ -440,11 +436,7 @@
 	public int insertRow( ExecRow row, LanguageConnectionContext lcc )
 		throws StandardException
 	{
-		RowList					rowList = new RowList( this );
-
-		rowList.add(row);
-
-		return	insertRowList( rowList, lcc );
+		return	insertRowList(new ExecRow[] {row}, lcc.getTransactionExecute());
 	}
 
 	/**
@@ -454,10 +446,8 @@
 	public RowLocation insertRowAndFetchRowLocation(ExecRow row, TransactionController tc)
 		throws StandardException
 	{
-		RowList	rowList = new RowList( this );
-		rowList.add(row);
 		RowLocation[] rowLocationOut = new RowLocation[1]; 
-		insertRowListImpl(rowList,tc,rowLocationOut, true);
+		insertRowListImpl(new ExecRow[] {row},tc,rowLocationOut, true);
 		return rowLocationOut[0];
 	}
 
@@ -474,7 +464,7 @@
 	 *
 	 * @exception StandardException		Thrown on failure
 	 */
-	public int insertRowList( RowList rowList, TransactionController tc )
+	public int insertRowList(ExecRow[] rowList, TransactionController tc )
 		throws StandardException
 	{
 		RowLocation[] 			notUsed = new RowLocation[1]; 
@@ -483,27 +473,6 @@
 	}
 
 	/**
-	 * Inserts a list of base rows into a catalog and inserts all the corresponding
-	 * index rows.
-	 *
-	 *	@param	rowList		List of rows to insert
-	 *	@param	lcc			language state variable
-	 *
-	 *
-	 *	@return	row  number (>= 0) if duplicate row inserted into an index
-	 *			ROWNOTDUPLICATE otherwise
-	 *
-	 * @exception StandardException		Thrown on failure
-	 */
-	private int insertRowList( RowList rowList, LanguageConnectionContext lcc )
-		throws StandardException
-	{
-		TransactionController	tc = lcc.getTransactionExecute();
-
-		return insertRowList(rowList,tc);
-	}
-
-	/**
 	  Insert logic to insert a list of rows into a table. This logic has two
 	  odd features to support the TabInfo interface.
 
@@ -519,7 +488,7 @@
 	  @return row number (>= 0) if duplicate row inserted into an index
 	  			ROWNOTDUPLICATE otherwise
 	 */
-	private int insertRowListImpl( RowList rowList, TransactionController tc, RowLocation[] rowLocationOut,
+	private int insertRowListImpl(ExecRow[] rowList, TransactionController tc, RowLocation[] rowLocationOut,
 								   boolean wait)
 		throws StandardException
 	{
@@ -530,8 +499,6 @@
 		int							retCode = ROWNOTDUPLICATE;
 		int							indexCount = crf.getNumIndexes();
 		ConglomerateController[]	indexControllers = new ConglomerateController[ indexCount ];
-		Enumeration	       			iterator;
-		ExecRow						row;
 
 		// Open the conglomerates
 		heapController = 
@@ -571,10 +538,9 @@
 		rowLocationOut[0]=heapLocation;
 
 		// loop through rows on this list, inserting them into system table
-		int rowNumber = 0;
-		for (iterator =  rowList.elements(); iterator.hasMoreElements(); rowNumber++)
+		for (int rowNumber = 0; rowNumber < rowList.length; rowNumber++)
 		{
-			row = (ExecRow) iterator.nextElement();
+			ExecRow row = rowList[rowNumber];
 			// insert the base row and get its new location 
 			heapController.insertAndFetchLocation(row.getRowArray(), heapLocation);
 			

Modified: incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/ColumnDefinitionNode.java
Url: http://svn.apache.org/viewcvs/incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/ColumnDefinitionNode.java?view=diff&rev=124847&p1=incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/ColumnDefinitionNode.java&r1=124846&p2=incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/ColumnDefinitionNode.java&r2=124847
==============================================================================
--- incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/ColumnDefinitionNode.java	(original)
+++ incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/ColumnDefinitionNode.java	Mon Jan 10 15:35:04 2005
@@ -2,7 +2,7 @@
 
    Derby - Class org.apache.derby.impl.sql.compile.ColumnDefinitionNode
 
-   Copyright 1997, 2004 The Apache Software Foundation or its licensors, as applicable.
+   Copyright 1997, 2005 The Apache Software Foundation or its licensors, as applicable.
 
    Licensed under the Apache License, Version 2.0 (the "License");
    you may not use this file except in compliance with the License.
@@ -472,12 +472,10 @@
 	void validateDefault(DataDictionary dd, TableDescriptor td)
 		throws StandardException
 	{
-		CompilerContext cc;
-
 		if (defaultNode == null)
 			return;
 
-		cc = getCompilerContext();
+		CompilerContext cc = getCompilerContext();
 
 		ValueNode defaultTree = defaultNode.getDefaultTree();
 
@@ -488,19 +486,21 @@
 		final int previousReliability = cc.getReliability();
 		try
 		{
-			/* Each default can have its own set of dependencies.
-			 * These dependencies need to be shared with the prepared
-			 * statement as well.  We create a new auxiliary provider list
-			 * for the default, "push" it on the compiler context
-			 * by swapping it with the current auxiliary provider list
-			 * and the "pop" it when we're done by restoring the old 
-			 * auxiliary provider list.
+			/*
+				Defaults cannot have dependencies as they
+				should just be constants. Code used to exist
+				to handle dependencies in defaults, now this
+				is under sanity to ensure no dependencies exist.
 			 */
-			ProviderList apl = new ProviderList();
-
-			ProviderList prevAPL = cc.getCurrentAuxiliaryProviderList();
-			cc.setCurrentAuxiliaryProviderList(apl);
+			ProviderList apl = null;
+			ProviderList prevAPL = null;
 
+			if (SanityManager.DEBUG) {
+				apl = new ProviderList();
+				prevAPL = cc.getCurrentAuxiliaryProviderList();
+				cc.setCurrentAuxiliaryProviderList(apl);
+			}
+			
 			// Tell the compiler context to only allow deterministic nodes
 			cc.setReliability( CompilerContext.DEFAULT_RESTRICTION );
 			defaultTree = defaultTree.bindExpression(
@@ -537,24 +537,18 @@
 			// RESOLVEDEFAULT - Convert to constant if possible
 			defaultInfo = new DefaultInfoImpl(defaultNode.getDefaultText(), defaultValue);
 
-			/* Save the APL off in the constraint node */
-			if (apl.size() > 0)
+			if (SanityManager.DEBUG)
 			{
-				defaultNode.setAuxiliaryProviderList(apl);
-				// Add info on any providers to DefaultInfo
-				ProviderInfo[]	providerInfos = null;
+				/* Save the APL off in the constraint node */
+				if (apl.size() > 0)
+				{
 
-				/* Get all the dependencies for the current statement and transfer
-				 * them to this view.
-				 */
-				DependencyManager dm;
-				dm = dd.getDependencyManager();
-				providerInfos = dm.getPersistentProviderInfos(apl);
-				defaultInfo.setProviderInfo(providerInfos);
+					SanityManager.THROWASSERT("DEFAULT clause has unexpected dependencies");
+				}
+				// Restore the previous AuxiliaryProviderList
+				cc.setCurrentAuxiliaryProviderList(prevAPL);
 			}
 
-			// Restore the previous AuxiliaryProviderList
-			cc.setCurrentAuxiliaryProviderList(prevAPL);
 		}
 		finally
 		{

Modified: incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/CompilerContextImpl.java
Url: http://svn.apache.org/viewcvs/incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/CompilerContextImpl.java?view=diff&rev=124847&p1=incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/CompilerContextImpl.java&r1=124846&p2=incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/CompilerContextImpl.java&r2=124847
==============================================================================
--- incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/CompilerContextImpl.java	(original)
+++ incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/CompilerContextImpl.java	Mon Jan 10 15:35:04 2005
@@ -2,7 +2,7 @@
 
    Derby - Class org.apache.derby.impl.sql.compile.CompilerContextImpl
 
-   Copyright 1997, 2004 The Apache Software Foundation or its licensors, as applicable.
+   Copyright 1997, 2005 The Apache Software Foundation or its licensors, as applicable.
 
    Licensed under the Apache License, Version 2.0 (the "License");
    you may not use this file except in compliance with the License.
@@ -311,10 +311,8 @@
 	 *
 	 * @return Nothing.
 	 *
-	 * @exception StandardException thrown on failure.
 	 */
 	private void addProviderToAuxiliaryList(Provider p)
-		throws StandardException
 	{
 		if (currentAPL != null)
 		{

Modified: incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/ConstraintDefinitionNode.java
Url: http://svn.apache.org/viewcvs/incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/ConstraintDefinitionNode.java?view=diff&rev=124847&p1=incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/ConstraintDefinitionNode.java&r1=124846&p2=incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/ConstraintDefinitionNode.java&r2=124847
==============================================================================
--- incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/ConstraintDefinitionNode.java	(original)
+++ incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/ConstraintDefinitionNode.java	Mon Jan 10 15:35:04 2005
@@ -2,7 +2,7 @@
 
    Derby - Class org.apache.derby.impl.sql.compile.ConstraintDefinitionNode
 
-   Copyright 1997, 2004 The Apache Software Foundation or its licensors, as applicable.
+   Copyright 1997, 2005 The Apache Software Foundation or its licensors, as applicable.
 
    Licensed under the Apache License, Version 2.0 (the "License");
    you may not use this file except in compliance with the License.
@@ -246,16 +246,6 @@
 			backingIndexName = dd.getSystemSQLName();
 
 		return	backingIndexName;
-	}
-
-	/**
-	 * Get the constraint name
-	 *
-	 * @return constraintName	The constraint name.
-	 */
-	public TableName getXXRConstraintName()
-	{
-		return constraintName;
 	}
 
 	/**

Modified: incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/CreateViewNode.java
Url: http://svn.apache.org/viewcvs/incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/CreateViewNode.java?view=diff&rev=124847&p1=incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/CreateViewNode.java&r1=124846&p2=incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/CreateViewNode.java&r2=124847
==============================================================================
--- incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/CreateViewNode.java	(original)
+++ incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/CreateViewNode.java	Mon Jan 10 15:35:04 2005
@@ -2,7 +2,7 @@
 
    Derby - Class org.apache.derby.impl.sql.compile.CreateViewNode
 
-   Copyright 1997, 2004 The Apache Software Foundation or its licensors, as applicable.
+   Copyright 1997, 2005 The Apache Software Foundation or its licensors, as applicable.
 
    Licensed under the Apache License, Version 2.0 (the "License");
    you may not use this file except in compliance with the License.
@@ -379,17 +379,7 @@
 	  *
 	  *	@return	the parsed query expression.
 	  */
-	public	ResultSetNode	getParsedQueryExpression() { return queryExpression; }
-
-	/**
-	  *	Get the bound result column list.
-	  *
-	  *	@return	the bound result column list.
-	  */
-	public	ResultColumnList	getBoundResultColumnList()
-	{
-		return queryExpression.getResultColumns();
-	}
+	ResultSetNode	getParsedQueryExpression() { return queryExpression; }
 
 
 	/*

Modified: incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/DefaultNode.java
Url: http://svn.apache.org/viewcvs/incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/DefaultNode.java?view=diff&rev=124847&p1=incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/DefaultNode.java&r1=124846&p2=incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/DefaultNode.java&r2=124847
==============================================================================
--- incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/DefaultNode.java	(original)
+++ incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/DefaultNode.java	Mon Jan 10 15:35:04 2005
@@ -2,7 +2,7 @@
 
    Derby - Class org.apache.derby.impl.sql.compile.DefaultNode
 
-   Copyright 1999, 2004 The Apache Software Foundation or its licensors, as applicable.
+   Copyright 1999, 2005 The Apache Software Foundation or its licensors, as applicable.
 
    Licensed under the Apache License, Version 2.0 (the "License");
    you may not use this file except in compliance with the License.
@@ -39,8 +39,6 @@
 import org.apache.derby.iapi.sql.dictionary.DefaultDescriptor;
 import org.apache.derby.iapi.sql.dictionary.TableDescriptor;
 
-import org.apache.derby.iapi.sql.depend.ProviderList;
-
 import org.apache.derby.iapi.error.StandardException;
 
 import org.apache.derby.impl.sql.compile.ExpressionClassBuilder;
@@ -54,7 +52,6 @@
  */
 public  class DefaultNode extends ValueNode
 {
-	private ProviderList apl;
 	private String		columnName;
 	private String		defaultText;
 	private ValueNode	defaultTree;
@@ -98,16 +95,6 @@
 	ValueNode getDefaultTree()
 	{
 		return defaultTree;
-	}
-
-	void setAuxiliaryProviderList(ProviderList apl)
-	{
-		this.apl = apl;
-	}
-
-	public ProviderList getAuxiliaryProviderList()
-	{
-		return apl;
 	}
 
 	/**

Modified: incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/TableElementList.java
Url: http://svn.apache.org/viewcvs/incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/TableElementList.java?view=diff&rev=124847&p1=incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/TableElementList.java&r1=124846&p2=incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/TableElementList.java&r2=124847
==============================================================================
--- incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/TableElementList.java	(original)
+++ incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/compile/TableElementList.java	Mon Jan 10 15:35:04 2005
@@ -2,7 +2,7 @@
 
    Derby - Class org.apache.derby.impl.sql.compile.TableElementList
 
-   Copyright 1997, 2004 The Apache Software Foundation or its licensors, as applicable.
+   Copyright 1997, 2005 The Apache Software Foundation or its licensors, as applicable.
 
    Licensed under the Apache License, Version 2.0 (the "License");
    you may not use this file except in compliance with the License.
@@ -688,6 +688,7 @@
 				else
 				{
 					providerInfos = new ProviderInfo[0];
+					// System.out.println("TABLE ELEMENT LIST EMPTY");
 				}
 
 				conActions[conActionIndex++] = 

Modified: incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/depend/BasicDependencyManager.java
Url: http://svn.apache.org/viewcvs/incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/depend/BasicDependencyManager.java?view=diff&rev=124847&p1=incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/depend/BasicDependencyManager.java&r1=124846&p2=incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/depend/BasicDependencyManager.java&r2=124847
==============================================================================
--- incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/depend/BasicDependencyManager.java	(original)
+++ incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/depend/BasicDependencyManager.java	Mon Jan 10 15:35:04 2005
@@ -2,7 +2,7 @@
 
    Derby - Class org.apache.derby.impl.sql.depend.BasicDependencyManager
 
-   Copyright 1997, 2004 The Apache Software Foundation or its licensors, as applicable.
+   Copyright 1997, 2005 The Apache Software Foundation or its licensors, as applicable.
 
    Licensed under the Apache License, Version 2.0 (the "License");
    you may not use this file except in compliance with the License.
@@ -682,7 +682,7 @@
 					throws StandardException
 	{
 		Enumeration e = pl.elements();
-		while (e != null && e.hasMoreElements())
+		while (e.hasMoreElements())
 		{
 			Provider pro = (Provider) e.nextElement();
 			if (pro instanceof TableDescriptor)

Modified: incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/AlterTableConstantAction.java
Url: http://svn.apache.org/viewcvs/incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/AlterTableConstantAction.java?view=diff&rev=124847&p1=incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/AlterTableConstantAction.java&r1=124846&p2=incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/AlterTableConstantAction.java&r2=124847
==============================================================================
--- incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/AlterTableConstantAction.java	(original)
+++ incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/AlterTableConstantAction.java	Mon Jan 10 15:35:04 2005
@@ -2,7 +2,7 @@
 
    Derby - Class org.apache.derby.impl.sql.execute.AlterTableConstantAction
 
-   Copyright 1998, 2004 The Apache Software Foundation or its licensors, as applicable.
+   Copyright 1998, 2005 The Apache Software Foundation or its licensors, as applicable.
 
    Licensed under the Apache License, Version 2.0 (the "License");
    you may not use this file except in compliance with the License.
@@ -648,35 +648,6 @@
 								columnInfo[ix].name,
 								columnInfo[ix].defaultInfo.getDefaultText(),
 								lcc);
-				
-			DefaultDescriptor defaultDescriptor = new DefaultDescriptor(dd, defaultUUID, td.getUUID(), 
-										 colNumber + 1);
-
-			/* Create stored dependencies for each provider to default */
-			ProviderInfo[] providerInfo = ((DefaultInfoImpl) columnInfo[ix].defaultInfo).getProviderInfo();
-			int providerInfoLength = (providerInfo == null) ? 0 : providerInfo.length;
-			for (int provIndex = 0; provIndex < providerInfoLength; 
-				 provIndex++)
-			{
-				Provider provider = null;
-				
-				/* We should always be able to find the Provider */
-				try 
-				{
-					provider = (Provider) providerInfo[provIndex].
-						getDependableFinder().
-						getDependable(
-									  providerInfo[provIndex].getObjectId());
-				}	
-				catch (java.sql.SQLException te)
-				{	
-					if (SanityManager.DEBUG)
-					{
-						SanityManager.THROWASSERT("unexpected java.sql.SQLException - " + te);
-					}	
-				}	
-				dm.addDependency(defaultDescriptor, provider, lcc.getContextManager());
-			}	
 		}	
 	}
 
@@ -1085,41 +1056,6 @@
 										 columnInfo[ix].autoincStart);
 			dd.setAutoincrementValue(tc, td.getUUID(), columnInfo[ix].name,
 									 maxValue, true);
-		}
-
-		// Add default info for new default, if non-null
-		if (columnDescriptor.hasNonNullDefault())
-		{
-			DefaultDescriptor defaultDescriptor =
-				new DefaultDescriptor(dd, defaultUUID, 
-										 td.getUUID(), 
-										 columnPosition);
-		
-			/* Create stored dependencies for each provider to default */
-			ProviderInfo[] providerInfo = ((DefaultInfoImpl) columnInfo[ix].defaultInfo).getProviderInfo();
-			int providerInfoLength = (providerInfo == null) ? 0 : providerInfo.length;
-			for (int provIndex = 0; provIndex < providerInfoLength; provIndex++)
-			{
-				Provider provider = null;
-				
-				/* We should always be able to find the Provider */
-				try 
-				{
-					provider = (Provider) providerInfo[provIndex].
-						getDependableFinder().
-						getDependable(
-									  providerInfo[provIndex].getObjectId());
-				}	
-				catch(java.sql.SQLException te)
-				{
-					if (SanityManager.DEBUG)
-					{
-						SanityManager.THROWASSERT("unexpected java.sql.SQLException - " + te);
-					}
-				}
-				dm.addDependency(defaultDescriptor, provider, 
-								 lcc.getContextManager());
-			}
 		}
 	}
 

Modified: incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/CreateTableConstantAction.java
Url: http://svn.apache.org/viewcvs/incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/CreateTableConstantAction.java?view=diff&rev=124847&p1=incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/CreateTableConstantAction.java&r1=124846&p2=incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/CreateTableConstantAction.java&r2=124847
==============================================================================
--- incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/CreateTableConstantAction.java	(original)
+++ incubator/derby/code/trunk/java/engine/org/apache/derby/impl/sql/execute/CreateTableConstantAction.java	Mon Jan 10 15:35:04 2005
@@ -2,7 +2,7 @@
 
    Derby - Class org.apache.derby.impl.sql.execute.CreateTableConstantAction
 
-   Copyright 1997, 2004 The Apache Software Foundation or its licensors, as applicable.
+   Copyright 1997, 2005 The Apache Software Foundation or its licensors, as applicable.
 
    Licensed under the Apache License, Version 2.0 (the "License");
    you may not use this file except in compliance with the License.
@@ -270,36 +270,6 @@
 							   );
 
 			cdlArray[ix] = columnDescriptor;
-
-			if (columnInfo[ix].defaultInfo != null)
-			{
-				DefaultDescriptor defaultDescriptor = new DefaultDescriptor(dd, defaultUUID, td.getUUID(), ix + 1);
-
-				/* Create stored dependencies for each provider to default */
-				ProviderInfo[] providerInfo = ((DefaultInfoImpl) columnInfo[ix].defaultInfo).getProviderInfo();
-				int providerInfoLength = (providerInfo == null) ? 0 : providerInfo.length;
-				for (int provIndex = 0; provIndex < providerInfoLength; provIndex++)
-				{
-					Provider provider = null;
-
-					/* We should always be able to find the Provider */
-					try 
-					{
-						provider = (Provider) providerInfo[provIndex].
-												getDependableFinder().
-													getDependable(
-														providerInfo[provIndex].getObjectId());
-					}
-					catch(java.sql.SQLException te)
-					{
-						if (SanityManager.DEBUG)
-						{
-							SanityManager.THROWASSERT("unexpected java.sql.SQLException - " + te);
-						}
-					}
-					dm.addDependency(defaultDescriptor, provider, lcc.getContextManager());
-				}
-			}
 		}
 
 		if ( tableType != TableDescriptor.GLOBAL_TEMPORARY_TABLE_TYPE )