You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@trafodion.apache.org by db...@apache.org on 2016/05/24 16:34:49 UTC

[5/9] incubator-trafodion git commit: Rename required prefix with Traf

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/38e49cf7/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/HPT4PooledConnectionManager.java
----------------------------------------------------------------------
diff --git a/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/HPT4PooledConnectionManager.java b/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/HPT4PooledConnectionManager.java
deleted file mode 100644
index 0657b92..0000000
--- a/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/HPT4PooledConnectionManager.java
+++ /dev/null
@@ -1,385 +0,0 @@
-// @@@ START COPYRIGHT @@@
-//
-// 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.
-//
-// @@@ END COPYRIGHT @@@
-
-package org.trafodion.jdbc.t4;
-
-import java.io.PrintWriter;
-import java.sql.Connection;
-import java.sql.SQLException;
-import java.util.Collections;
-import java.util.Hashtable;
-import java.util.Iterator;
-import java.util.LinkedList;
-import java.util.List;
-import java.util.Timer;
-import java.util.TimerTask;
-import java.util.Vector;
-import java.util.logging.Level;
-import java.util.logging.LogRecord;
-
-import javax.sql.ConnectionEvent;
-import javax.sql.ConnectionPoolDataSource;
-import javax.sql.PooledConnection;
-
-public class HPT4PooledConnectionManager implements javax.sql.ConnectionEventListener {
-
-	public void connectionClosed(ConnectionEvent event) {
-		if (T4Properties.t4GlobalLogger.isLoggable(Level.FINE) == true) {
-			Object p[] = T4LoggingUtilities.makeParams(null, event);
-			T4Properties.t4GlobalLogger.logp(Level.FINE, "HPT4PooledConnectionManager", "connectionClosed", "", p);
-		}
-		if (out_ != null) {
-			LogRecord lr = new LogRecord(Level.FINE, "");
-			Object p[] = T4LoggingUtilities.makeParams(null, event);
-			lr.setParameters(p);
-			lr.setSourceClassName("HPT4PooledConnectionManager");
-			lr.setSourceMethodName("connectionClosed");
-			T4LogFormatter lf = new T4LogFormatter();
-			String temp = lf.format(lr);
-			out_.println(temp);
-		}
-		if (out_ != null) {
-			if (traceLevel_ != Level.OFF) {
-				out_.println(traceId_ + "connectionClosed(" + event + ")");
-			}
-		}
-		PooledConnection pc;
-
-		pc = (PooledConnection) event.getSource();
-
-		boolean addToFreePool = true;
-		if (minPoolSize_ > 0 && free_.size() >= minPoolSize_) {
-			addToFreePool = false;
-		}
-		// If an initial pool is being created, then ensure that the connection
-		// is
-		// added to the free pool irrespective of minPoolSize being reached
-		if (initialPoolCreationFlag_) {
-			addToFreePool = true;
-		}
-		boolean wasPresent = removeInUseConnection(pc, addToFreePool);
-
-		if (wasPresent && (!addToFreePool)) {
-			try {
-				pc.close();
-			} catch (SQLException e) {
-				// ignore any close error
-			}
-		}
-	}
-
-	public void connectionErrorOccurred(ConnectionEvent event) {
-		if (out_ != null) {
-			if (traceLevel_ != Level.OFF) {
-				out_.println(traceId_ + "connectionErrorOccurred(" + event + ")");
-			}
-		}
-
-		PooledConnection pc;
-
-		pc = (PooledConnection) event.getSource();
-		try {
-			pc.close();
-		} catch (SQLException e) {
-			// ignore any close error
-		}
-		removeInUseConnection(pc, false);
-	}
-
-	public Connection getConnection() throws SQLException {
-		if (out_ != null) {
-			if (traceLevel_ != Level.OFF) {
-				out_.println(traceId_ + "getConnection()");
-			}
-		}
-
-		PooledConnection pc;
-		boolean validConnection = false;
-
-		do {
-			if (free_.size() == 0) {
-				if (maxPoolSize_ == 0 || count_ < maxPoolSize_) {
-					pc = pds_.getPooledConnection();
-					count_++;
-					pc.addConnectionEventListener(this);
-					inUse_.add(pc);
-
-					TrafT4Connection c = (TrafT4Connection) pc.getConnection();
-					try {
-						c.ic_.enforceT4ConnectionTimeout(c);
-						validConnection = true;
-					} catch (SQLException sqlEx) {
-						try {
-							pc.close();
-						} catch (Exception e) {
-						} // cleanup, ignore any errors
-					}
-				} else {
-					throw HPT4Messages.createSQLException(null, null, "max_pool_size_reached", null);
-				}
-			} else {
-				pc = (PooledConnection) free_.get(0);
-				if (removeFreeConnection(pc, true)) {
-					TrafT4Connection c = (TrafT4Connection) pc.getConnection();
-					try {
-						c.ic_.enforceT4ConnectionTimeout(c);
-						validConnection = true;
-					} catch (SQLException sqlEx) {
-						try {
-							pc.close();
-						} catch (Exception e) {
-						} // cleanup, ignore any errors
-					}
-				}
-			}
-		} while (!validConnection);
-
-		return pc.getConnection();
-	}
-
-	private synchronized boolean removeFreeConnection(PooledConnection pc, boolean addToUsePool) {
-		boolean wasPresent = free_.remove(pc);
-		hashTab_.remove(pc);
-		if (wasPresent) {
-			if (addToUsePool) {
-				inUse_.add(pc);
-			} else {
-				count_--;
-			}
-		}
-		return wasPresent;
-	}
-
-	private synchronized boolean removeInUseConnection(PooledConnection pc, boolean addToFreePool) {
-		boolean wasPresent = inUse_.remove(pc);
-		hashTab_.remove(pc);
-		if (wasPresent) {
-			if (addToFreePool) {
-				hashTab_.put(pc, new Long(System.currentTimeMillis() + (1000 * maxIdleTime_)));
-				free_.add(pc);
-			} else {
-				count_--;
-			}
-		}
-		return wasPresent;
-	}
-
-	private void createInitialPool(int initialPoolSize) throws SQLException {
-		if (initialPoolSize <= 0) {
-			return;
-		}
-
-		int limit = initialPoolSize > maxPoolSize_ ? maxPoolSize_ : initialPoolSize;
-		Connection initPool_[] = new Connection[limit];
-		int created = 0;
-		try {
-			// Set initialPoolInCreation to indicate that an initial pool is in
-			// the
-			// process of being created.
-			initialPoolCreationFlag_ = true;
-
-			for (int i = 0; i < limit; i++) {
-				initPool_[i] = getConnection();
-				created++;
-			}
-		} catch (SQLException se) {
-			SQLException head = HPT4Messages.createSQLException(null, null, "initial_pool_creation_error", "" + limit);
-			head.setNextException(se);
-			throw head;
-		} finally {
-			for (int i = 0; i < created; i++) {
-				try {
-					if (initPool_[i] != null)
-						initPool_[i].close();
-				} catch (SQLException se) {
-					// ignore
-				}
-			}
-			// Ensuring that the initialPoolInCreation has been set to false to
-			// indicate
-			// that the initial pool creation process has occured.
-			initialPoolCreationFlag_ = false;
-		}
-	}
-
-	void setLogWriter(PrintWriter out) {
-		out_ = out;
-	}
-
-	HPT4PooledConnectionManager(HPT4ConnectionPoolDataSource pds, Level traceLevel) throws SQLException {
-		String className = getClass().getName();
-		pds_ = pds;
-		inUse_ = Collections.synchronizedList(new LinkedList());
-		free_ = Collections.synchronizedList(new LinkedList());
-		maxPoolSize_ = pds.getMaxPoolSize();
-		minPoolSize_ = pds.getMinPoolSize();
-		maxIdleTime_ = pds.getMaxIdleTime();
-		connectionTimeout_ = pds.getConnectionTimeout();
-		traceLevel_ = traceLevel;
-		timer_ = null;
-		if (maxIdleTime_ > 0 && maxPoolSize_ > 0) {
-			IdleConnectionCleanupTask timerTask_ = new IdleConnectionCleanupTask();
-			timer_ = new Timer(true);
-			timer_.schedule(timerTask_, (maxIdleTime_ * 1000), (maxIdleTime_ * 500));
-		}
-		if (connectionTimeout_ > 0 && maxPoolSize_ > 0) {
-			ConnectionTimeoutCleanupTask timerTask_ = new ConnectionTimeoutCleanupTask();
-			if (timer_ == null) {
-				timer_ = new Timer(true);
-			}
-			timer_.schedule(timerTask_, (connectionTimeout_ * 1000), (connectionTimeout_ * 500));
-		}
-		createInitialPool(pds.getInitialPoolSize());
-		traceId_ = "jdbcTrace:[" + Thread.currentThread() + "]:[" + hashCode() + "]:" + className + ".";
-	}
-
-	ConnectionPoolDataSource pds_;
-	// LinkedList inUse_;
-	// LinkedList free_;
-	List inUse_;
-	List free_;
-	int count_;
-
-	int maxPoolSize_;
-	int minPoolSize_;
-	long maxIdleTime_;
-	int connectionTimeout_;
-	Level traceLevel_;
-	PrintWriter out_;
-	String traceId_;
-	Timer timer_;
-	Hashtable hashTab_ = new java.util.Hashtable(); // synchronized
-	// We keep a flag to indicate to this class that an initial pool is in the
-	// process
-	// of being created
-	boolean initialPoolCreationFlag_ = false;
-
-	/*
-	 * Private class used to clean up the connections that have surpassed
-	 * maxIdleTime
-	 */
-	/* Start TimerTask definition */
-	private class IdleConnectionCleanupTask extends TimerTask {
-		Vector toRemove = null;
-
-		IdleConnectionCleanupTask() {
-			toRemove = new Vector();
-		}
-
-		public void run() {
-			cleanUp();
-		}
-
-		private void cleanUp() {
-			toRemove.clear();
-			synchronized (free_) {
-				try {
-					Iterator it_ = free_.iterator();
-					while (it_.hasNext()) {
-						PooledConnection tempPC = (PooledConnection) it_.next();
-						Long timeOutVal = (Long) hashTab_.get(tempPC);
-						if (System.currentTimeMillis() > timeOutVal.longValue()) {
-							toRemove.add(tempPC);
-						}
-					}
-				} catch (Throwable t) {
-					if (T4Properties.t4GlobalLogger.isLoggable(Level.WARNING) == true) {
-						T4Properties.t4GlobalLogger.logp(Level.WARNING, "IdleConnectionCleanupTask", "cleanUp", t
-								.getMessage());
-					}
-				}
-			} // synchronized block
-			for (int i = 0; i < toRemove.size(); i++) {
-				PooledConnection pc = (PooledConnection) toRemove.get(i);
-				boolean wasPresent = removeFreeConnection(pc, false);
-				if (wasPresent) {
-					// close it to cleanup
-					try {
-						/*
-						 * System.out.println("Closing connection : " + (
-						 * (HPT4Connection) ( (HPT4PooledConnection)
-						 * pc).getConnection()).getDialogueId());
-						 */
-						pc.close();
-					} catch (SQLException se) {
-						// Ignore
-					}
-				}
-			}
-		}
-	}
-
-	/* End TimerTask definition */
-	/*
-	 * Private class used to clean up the connections that have surpassed
-	 * connectionTimeout
-	 */
-	/* Start TimerTask definition */
-	private class ConnectionTimeoutCleanupTask extends TimerTask {
-		Vector toRemove = null;
-
-		ConnectionTimeoutCleanupTask() {
-			toRemove = new Vector();
-		}
-
-		public void run() {
-			cleanUp();
-		}
-
-		private void cleanUp() {
-			toRemove.clear();
-			synchronized (inUse_) {
-				Iterator it_ = inUse_.iterator();
-				while (it_.hasNext()) {
-					try {
-						PooledConnection tempPC = (PooledConnection) it_.next();
-						InterfaceConnection ic = ((HPT4PooledConnection) tempPC).getTrafT4ConnectionReference().ic_;
-						if (ic != null) {
-							T4Connection tconn = ic.getT4Connection();
-							if (tconn != null) {
-								if (tconn.connectionIdleTimeoutOccured()) {
-									// System.out.println("********* Found a
-									// timed out connection **********");
-									toRemove.add(tempPC);
-								}
-							}
-						}
-					} catch (Throwable t) {
-						if (T4Properties.t4GlobalLogger.isLoggable(Level.WARNING) == true) {
-							T4Properties.t4GlobalLogger.logp(Level.WARNING, "ConnectionTimeoutCleanupTask", "cleanUp",
-									t.getMessage());
-						}
-					}
-				}
-			} // synchronized block
-			for (int i = 0; i < toRemove.size(); i++) {
-				PooledConnection pc = (PooledConnection) toRemove.get(i);
-				removeInUseConnection(pc, false);
-				// do not close the connections because:
-				// 1.> Corresponding NCS server is already gone
-				// 2.> We need to give a timeout error when user uses this
-				// connection
-			}
-		}
-	}
-	/* End TimerTask definition */
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/38e49cf7/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/HPT4ResultSetMetaData.java
----------------------------------------------------------------------
diff --git a/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/HPT4ResultSetMetaData.java b/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/HPT4ResultSetMetaData.java
deleted file mode 100644
index d1f1f7e..0000000
--- a/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/HPT4ResultSetMetaData.java
+++ /dev/null
@@ -1,309 +0,0 @@
-// @@@ START COPYRIGHT @@@
-//
-// 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.
-//
-// @@@ END COPYRIGHT @@@
-
-package org.trafodion.jdbc.t4;
-
-import java.sql.SQLException;
-import java.util.logging.Level;
-
-public class HPT4ResultSetMetaData implements java.sql.ResultSetMetaData {
-
-	// begin required methods
-	public String getCatalogName(int column) throws SQLException {
-		if (column > outputDesc_.length) {
-			throw HPT4Messages.createSQLException(connection_.props_, connection_.getLocale(), "invalid_desc_index",
-					null);
-		}
-		return outputDesc_[column - 1].catalogName_;
-	}
-
-	public String getColumnClassName(int column) throws SQLException {
-		if (column > outputDesc_.length) {
-			throw HPT4Messages.createSQLException(connection_.props_, connection_.getLocale(), "invalid_desc_index",
-					null);
-		}
-		return outputDesc_[column - 1].getColumnClassName();
-	}
-
-	public int getColumnCount() throws SQLException {
-		return outputDesc_.length;
-	}
-
-	public int getColumnDisplaySize(int column) throws SQLException {
-		if (column > outputDesc_.length) {
-			throw HPT4Messages.createSQLException(connection_.props_, connection_.getLocale(), "invalid_desc_index",
-					null);
-		}
-		return outputDesc_[column - 1].displaySize_;
-	}
-
-	public String getColumnLabel(int column) throws SQLException {
-		if (column > outputDesc_.length) {
-			throw HPT4Messages.createSQLException(connection_.props_, connection_.getLocale(), "invalid_desc_index",
-					null);
-		}
-
-		return (outputDesc_[column - 1].columnLabel_ == null) ? outputDesc_[column - 1].name_
-				: outputDesc_[column - 1].columnLabel_;
-	}
-
-	public String getColumnName(int column) throws SQLException {
-		if (column > outputDesc_.length) {
-			throw HPT4Messages.createSQLException(connection_.props_, connection_.getLocale(), "invalid_desc_index",
-					null);
-		}
-		return outputDesc_[column - 1].name_;
-	}
-
-	public int getColumnType(int column) throws SQLException {
-		if (column > outputDesc_.length) {
-			throw HPT4Messages.createSQLException(connection_.props_, connection_.getLocale(), "invalid_desc_index",
-					null);
-		}
-		return outputDesc_[column - 1].dataType_;
-	}
-
-	public String getColumnTypeName(int column) throws SQLException {
-		if (column > outputDesc_.length) {
-			throw HPT4Messages.createSQLException(connection_.props_, connection_.getLocale(), "invalid_desc_index",
-					null);
-		}
-		return outputDesc_[column - 1].getColumnTypeName(connection_.getLocale());
-	}
-
-	public int getPrecision(int column) throws SQLException {
-		if (column > outputDesc_.length) {
-			throw HPT4Messages.createSQLException(connection_.props_, connection_.getLocale(), "invalid_desc_index",
-					null);
-		}
-		return outputDesc_[column - 1].precision_;
-	}
-
-	public int getScale(int column) throws SQLException {
-		if (column > outputDesc_.length) {
-			throw HPT4Messages.createSQLException(connection_.props_, connection_.getLocale(), "invalid_desc_index",
-					null);
-		}
-		return outputDesc_[column - 1].scale_;
-	}
-
-	public String getSchemaName(int column) throws SQLException {
-		if (column > outputDesc_.length) {
-			throw HPT4Messages.createSQLException(connection_.props_, connection_.getLocale(), "invalid_desc_index",
-					null);
-		}
-		return outputDesc_[column - 1].schemaName_;
-	}
-
-	public String getTableName(int column) throws SQLException {
-		if (column > outputDesc_.length) {
-			throw HPT4Messages.createSQLException(connection_.props_, connection_.getLocale(), "invalid_desc_index",
-					null);
-		}
-		return outputDesc_[column - 1].tableName_;
-	}
-
-	public boolean isAutoIncrement(int column) throws SQLException {
-		if (column > outputDesc_.length) {
-			throw HPT4Messages.createSQLException(connection_.props_, connection_.getLocale(), "invalid_desc_index",
-					null);
-		}
-		return outputDesc_[column - 1].isAutoIncrement_;
-	}
-
-	public boolean isCaseSensitive(int column) throws SQLException {
-		if (column > outputDesc_.length) {
-			throw HPT4Messages.createSQLException(connection_.props_, connection_.getLocale(), "invalid_desc_index",
-					null);
-		}
-		return outputDesc_[column - 1].isCaseSensitive_;
-	}
-
-	public boolean isCurrency(int column) throws SQLException {
-		if (column > outputDesc_.length) {
-			throw HPT4Messages.createSQLException(connection_.props_, connection_.getLocale(), "invalid_desc_index",
-					null);
-		}
-		return outputDesc_[column - 1].isCurrency_;
-	}
-
-	public boolean isDefinitelyWritable(int column) throws SQLException {
-		return true;
-	}
-
-	public int isNullable(int column) throws SQLException {
-		if (column > outputDesc_.length) {
-			throw HPT4Messages.createSQLException(connection_.props_, connection_.getLocale(), "invalid_desc_index",
-					null);
-		}
-		return outputDesc_[column - 1].isNullable_;
-	}
-
-	public boolean isReadOnly(int column) throws SQLException {
-		return false;
-	}
-
-	public boolean isSearchable(int column) throws SQLException {
-		if (column > outputDesc_.length) {
-			throw HPT4Messages.createSQLException(connection_.props_, connection_.getLocale(), "invalid_desc_index",
-					null);
-		}
-		return outputDesc_[column - 1].isSearchable_;
-	}
-
-	public boolean isSigned(int column) throws SQLException {
-		if (column > outputDesc_.length) {
-			throw HPT4Messages.createSQLException(connection_.props_, connection_.getLocale(), "invalid_desc_index",
-					null);
-		}
-		return outputDesc_[column - 1].isSigned_;
-	}
-
-	public boolean isWritable(int column) throws SQLException {
-		return true;
-	}
-
-	// ////////////////////////
-	// begin custom accessors//
-	// ////////////////////////
-
-	public int getFSDataType(int column) throws SQLException {
-		if (column > outputDesc_.length) {
-			throw HPT4Messages.createSQLException(connection_.props_, connection_.getLocale(), "invalid_desc_index",
-					null);
-		}
-		return outputDesc_[column - 1].fsDataType_;
-	}
-
-	public int getMaxLength(int column) throws SQLException {
-		if (column > outputDesc_.length) {
-			throw HPT4Messages.createSQLException(connection_.props_, connection_.getLocale(), "invalid_desc_index",
-					null);
-		}
-		return outputDesc_[column - 1].maxLen_;
-	}
-
-	public int getOdbcCharset(int column) throws SQLException {
-		if (column > outputDesc_.length) {
-			throw HPT4Messages.createSQLException(connection_.props_, connection_.getLocale(), "invalid_desc_index",
-					null);
-		}
-		return outputDesc_[column - 1].odbcCharset_;
-	}
-
-	public int getRowLength() throws SQLException {
-		// this is the same for all params
-		// only if we have no input params will we throw an error
-		if (outputDesc_.length == 0) {
-			throw HPT4Messages.createSQLException(connection_.props_, connection_.props_.getLocale(),
-					"invalid_desc_index", null);
-		}
-
-		return outputDesc_[0].rowLength_;
-	}
-
-	public int getSqlCharset(int column) throws SQLException {
-		if (column > outputDesc_.length) {
-			throw HPT4Messages.createSQLException(connection_.props_, connection_.getLocale(), "invalid_desc_index",
-					null);
-		}
-		return outputDesc_[column - 1].sqlCharset_;
-	}
-
-	public int getSqlPrecision(int column) throws SQLException {
-		if (column > outputDesc_.length) {
-			throw HPT4Messages.createSQLException(connection_.props_, connection_.getLocale(), "invalid_desc_index",
-					null);
-		}
-		return outputDesc_[column - 1].sqlPrecision_;
-	}
-
-	public int getSqlDatetimeCode(int param) throws SQLException {
-		return stmt_.ist_.pr_.outputDesc[param - 1].datetimeCode_;
-	}
-
-	// /////////////////////////////////
-	// these are legacy names...do not remove these yet even though they are
-	// duplicate
-	// ///////////////////////////////
-
-	/**
-	 * @deprecated
-	 */
-	public String cpqGetCharacterSet(int column) throws SQLException {
-		if ((column > outputDesc_.length) || (column <= 0)) {
-			throw HPT4Messages.createSQLException(connection_.props_, connection_.getLocale(), "invalid_desc_index",
-					null);
-		}
-		return outputDesc_[column - 1].getCharacterSetName();
-	}
-
-	/**
-	 * @deprecated
-	 */
-	public int getSqlTypeCode(int param) throws SQLException {
-		return stmt_.ist_.pr_.outputDesc[param - 1].dataType_;
-	} // end getSqlTypeCode
-
-	/**
-	 * @deprecated
-	 */
-	public int getSqlLength(int param) throws SQLException {
-		return stmt_.ist_.pr_.outputDesc[param - 1].maxLen_;
-	} // end getSqlTypeCode
-
-	HPT4ResultSetMetaData(TrafT4Statement stmt, HPT4Desc[] outputDesc) {
-		if (stmt.connection_.props_.t4Logger_.isLoggable(Level.FINE) == true) {
-			Object p[] = T4LoggingUtilities.makeParams(stmt.connection_.props_, stmt, outputDesc);
-			stmt.connection_.props_.t4Logger_.logp(Level.FINE, "HPT4ResultSetMetaData", "", "", p);
-		}
-
-		connection_ = stmt.connection_;
-		outputDesc_ = outputDesc;
-		stmt_ = stmt;
-	}
-
-	HPT4ResultSetMetaData(TrafT4ResultSet resultSet, HPT4Desc[] outputDesc) {
-		if (resultSet.connection_.props_.t4Logger_.isLoggable(Level.FINE) == true) {
-			Object p[] = T4LoggingUtilities.makeParams(resultSet.connection_.props_, resultSet, outputDesc);
-			resultSet.connection_.props_.t4Logger_.logp(Level.FINE, "HPT4ResultSetMetaData", "", "", p);
-		}
-
-		resultSet_ = resultSet;
-		connection_ = resultSet_.connection_;
-		outputDesc_ = outputDesc;
-		stmt_ = resultSet.stmt_;
-	}
-
-	TrafT4ResultSet resultSet_;
-	TrafT4Connection connection_;
-	HPT4Desc[] outputDesc_;
-	TrafT4Statement stmt_;
-	public Object unwrap(Class iface) throws SQLException {
-		// TODO Auto-generated method stub
-		return null;
-	}
-
-	public boolean isWrapperFor(Class iface) throws SQLException {
-		// TODO Auto-generated method stub
-		return false;
-	}
-}

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/38e49cf7/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/InitializeDialogueReply.java
----------------------------------------------------------------------
diff --git a/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/InitializeDialogueReply.java b/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/InitializeDialogueReply.java
index 5deb159..2d57f7b 100644
--- a/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/InitializeDialogueReply.java
+++ b/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/InitializeDialogueReply.java
@@ -76,12 +76,12 @@ class InitializeDialogueReply {
 			ic.outContext = new OUT_CONNECTION_CONTEXT_def();
 			ic.outContext.extractFromByteArray(buf, ic);
 			break;
-			//throw HPT4Messages.createSQLException(null, ic.getLocale(), "ids_28_000", null);
+			//throw TrafT4Messages.createSQLException(null, ic.getLocale(), "ids_28_000", null);
 		case odbc_SQLSvc_InitializeDialogue_ParamError_exn_:
 			ParamError = ic.decodeBytes(buf.extractString(), 1);
-			throw HPT4Messages.createSQLException(null, ic.getLocale(), "ids_program_error", ParamError, addr);
+			throw TrafT4Messages.createSQLException(null, ic.getLocale(), "ids_program_error", ParamError, addr);
 		case odbc_SQLSvc_InitializeDialogue_InvalidConnection_exn_:
-			throw HPT4Messages.createSQLException(null, ic.getLocale(), "ids_08_s01", null);
+			throw TrafT4Messages.createSQLException(null, ic.getLocale(), "ids_08_s01", null);
 		default:
 			clientErrorText = "unknown_initialize_dialogue_reply_error";
 			break;

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/38e49cf7/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/InputOutput.java
----------------------------------------------------------------------
diff --git a/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/InputOutput.java b/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/InputOutput.java
index 7062778..56111e9 100644
--- a/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/InputOutput.java
+++ b/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/InputOutput.java
@@ -260,7 +260,7 @@ class InputOutput {
 				// representitive of the problem
 				// with all addresses.
 				//
-				SQLException se = HPT4Messages.createSQLException(null, m_locale, "socket_open_error", eFirst
+				SQLException se = TrafT4Messages.createSQLException(null, m_locale, "socket_open_error", eFirst
 						.getMessage());
 
 				se.initCause(eFirst);
@@ -373,8 +373,8 @@ class InputOutput {
 			// We didn't even get the header back, so something is seriously
 			// wrong.
 			//
-			SQLException se = HPT4Messages.createSQLException(null, m_locale, "problem_with_server_read", null);
-			SQLException se2 = HPT4Messages.createSQLException(null, m_locale, "header_not_long_enough", null);
+			SQLException se = TrafT4Messages.createSQLException(null, m_locale, "problem_with_server_read", null);
+			SQLException se2 = TrafT4Messages.createSQLException(null, m_locale, "header_not_long_enough", null);
 
 			se.setNextException(se2);
 			throw se;
@@ -393,8 +393,8 @@ class InputOutput {
 					buffer.setByteSwap(true);
 					break;
 				default:
-					SQLException se = HPT4Messages.createSQLException(null, m_locale, "problem_with_server_read", null);
-					SQLException se2 = HPT4Messages.createSQLException(null, m_locale, "wrong_header_version", String.valueOf(m_rheader.version_));
+					SQLException se = TrafT4Messages.createSQLException(null, m_locale, "problem_with_server_read", null);
+					SQLException se2 = TrafT4Messages.createSQLException(null, m_locale, "wrong_header_version", String.valueOf(m_rheader.version_));
 		
 					se.setNextException(se2);
 					throw se;
@@ -402,8 +402,8 @@ class InputOutput {
 		}
 		
 		if (m_rheader.signature_ != Header.SIGNATURE) {
-			SQLException se = HPT4Messages.createSQLException(null, m_locale, "problem_with_server_read", null);
-			SQLException se2 = HPT4Messages.createSQLException(null, m_locale, "wrong_header_signature", String
+			SQLException se = TrafT4Messages.createSQLException(null, m_locale, "problem_with_server_read", null);
+			SQLException se2 = TrafT4Messages.createSQLException(null, m_locale, "wrong_header_signature", String
 					.valueOf(Header.SIGNATURE), String.valueOf(m_rheader.signature_));
 
 			se.setNextException(se2);
@@ -411,7 +411,7 @@ class InputOutput {
 		}
 
 		if (m_rheader.error_ != 0) {
-			SQLException se = HPT4Messages.createSQLException(null, m_locale, "driver_err_error_from_server", String
+			SQLException se = TrafT4Messages.createSQLException(null, m_locale, "driver_err_error_from_server", String
 					.valueOf(m_rheader.error_), String.valueOf(m_rheader.error_detail_));
 
 			throw se;
@@ -450,7 +450,7 @@ class InputOutput {
 			m_socket.close();
 			m_socket = null;
 		} catch (Exception e) {
-			SQLException se = HPT4Messages.createSQLException(null, m_locale, "session_close_error", e.getMessage());
+			SQLException se = TrafT4Messages.createSQLException(null, m_locale, "session_close_error", e.getMessage());
 			se.initCause(e);
 			throw se;
 		} finally {
@@ -461,8 +461,8 @@ class InputOutput {
 	void TCPIPWriteByteBuffer(ByteBuffer buffer) throws SQLException {
 
 		if (m_socket == null) {
-			SQLException se = HPT4Messages.createSQLException(null, m_locale, "socket_write_error", null);
-			SQLException se2 = HPT4Messages.createSQLException(null, m_locale, "socket_is_closed_error", null);
+			SQLException se = TrafT4Messages.createSQLException(null, m_locale, "socket_write_error", null);
+			SQLException se2 = TrafT4Messages.createSQLException(null, m_locale, "socket_is_closed_error", null);
 
 			se.setNextException(se2);
 			throw se;
@@ -472,7 +472,7 @@ class InputOutput {
 			m_wbc.write(buffer);
 			m_os.flush();
 		} catch (Exception e) {
-			SQLException se = HPT4Messages.createSQLException(null, m_locale, "socket_write_error", e.getMessage());
+			SQLException se = TrafT4Messages.createSQLException(null, m_locale, "socket_write_error", e.getMessage());
 
 			se.initCause(e);
 			throw se;
@@ -490,8 +490,8 @@ class InputOutput {
 		int data_length = 0;
 
 		if (m_socket == null) {
-			SQLException se = HPT4Messages.createSQLException(null, m_locale, "socket_write_error", null);
-			SQLException se2 = HPT4Messages.createSQLException(null, m_locale, "socket_is_closed_error", null);
+			SQLException se = TrafT4Messages.createSQLException(null, m_locale, "socket_write_error", null);
+			SQLException se2 = TrafT4Messages.createSQLException(null, m_locale, "socket_is_closed_error", null);
 
 			se.setNextException(se2);
 			throw se;
@@ -508,9 +508,9 @@ class InputOutput {
 			send_nblk(buffer.getBuffer(), buffer_index, data_length);
 			break;
 		default:
-			SQLException se = HPT4Messages.createSQLException(null, m_locale, "unknown_message_type_error", null);
-			SQLException se2 = HPT4Messages.createSQLException(null, m_locale, "internal_error", null);
-			SQLException se3 = HPT4Messages.createSQLException(null, m_locale, "cntact_hp_error", null);
+			SQLException se = TrafT4Messages.createSQLException(null, m_locale, "unknown_message_type_error", null);
+			SQLException se2 = TrafT4Messages.createSQLException(null, m_locale, "internal_error", null);
+			SQLException se3 = TrafT4Messages.createSQLException(null, m_locale, "cntact_traf_error", null);
 
 			se.setNextException(se2);
 			se2.setNextException(se3);
@@ -525,8 +525,8 @@ class InputOutput {
 		int numRead = 0;
 
 		if (m_socket == null) {
-			SQLException se = HPT4Messages.createSQLException(null, m_locale, "socket_read_error", null);
-			SQLException se2 = HPT4Messages.createSQLException(null, m_locale, "socket_is_closed_error", null);
+			SQLException se = TrafT4Messages.createSQLException(null, m_locale, "socket_read_error", null);
+			SQLException se2 = TrafT4Messages.createSQLException(null, m_locale, "socket_is_closed_error", null);
 
 			se.setNextException(se2);
 			throw se;
@@ -539,9 +539,9 @@ class InputOutput {
 //			buffer.setLocation(numRead);
 			break;
 		default:
-			SQLException se = HPT4Messages.createSQLException(null, m_locale, "unknown_message_type_error", null);
-			SQLException se2 = HPT4Messages.createSQLException(null, m_locale, "internal_error", null);
-			SQLException se3 = HPT4Messages.createSQLException(null, m_locale, "cntact_hp_error", null);
+			SQLException se = TrafT4Messages.createSQLException(null, m_locale, "unknown_message_type_error", null);
+			SQLException se2 = TrafT4Messages.createSQLException(null, m_locale, "internal_error", null);
+			SQLException se3 = TrafT4Messages.createSQLException(null, m_locale, "cntact_traf_error", null);
 
 			se.setNextException(se2);
 			se2.setNextException(se3);
@@ -558,7 +558,7 @@ class InputOutput {
 			m_os.write(buf, offset, len);
 			m_os.flush();
 		} catch (Exception e) {
-			SQLException se = HPT4Messages.createSQLException(null, m_locale, "socket_write_error", e.getMessage());
+			SQLException se = TrafT4Messages.createSQLException(null, m_locale, "socket_write_error", e.getMessage());
 
 			se.initCause(e);
 			throw se;
@@ -602,13 +602,13 @@ class InputOutput {
 	
 					throw ste;
 				} catch (Exception e) {
-					SQLException se = HPT4Messages
+					SQLException se = TrafT4Messages
 							.createSQLException(null, m_locale, "session_close_error", e.getMessage());
 					se.initCause(e);
 					throw se;
 				}
 			} catch (Exception e) {
-				SQLException se = HPT4Messages.createSQLException(null, m_locale, "socket_read_error", e.getMessage());
+				SQLException se = TrafT4Messages.createSQLException(null, m_locale, "socket_read_error", e.getMessage());
 	
 				se.initCause(e);
 				throw se;

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/38e49cf7/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/InterfaceConnection.java
----------------------------------------------------------------------
diff --git a/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/InterfaceConnection.java b/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/InterfaceConnection.java
index 4c1877f..b3c7f03 100644
--- a/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/InterfaceConnection.java
+++ b/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/InterfaceConnection.java
@@ -136,7 +136,7 @@ class InterfaceConnection {
 		gcConnections();
 
 		if (t4props.getSQLException() != null) {
-			throw HPT4Messages.createSQLException(t4props_, t4props.getLocale(), "invalid_property", t4props
+			throw TrafT4Messages.createSQLException(t4props_, t4props.getLocale(), "invalid_property", t4props
 					.getSQLException());
 		}
 
@@ -357,7 +357,7 @@ class InterfaceConnection {
 		try {
 			authentication = pwd.getBytes("US-ASCII");
 		} catch (UnsupportedEncodingException uex) {
-			throw HPT4Messages.createSQLException(t4props_, locale, uex.getMessage(), null);
+			throw TrafT4Messages.createSQLException(t4props_, locale, uex.getMessage(), null);
 		}
 
 		if (authentication.length > 0) {
@@ -505,7 +505,7 @@ class InterfaceConnection {
 					String temp = errorText;
 					t4props_.t4Logger_.logp(Level.FINEST, "InterfaceConnection", "cancel", temp, p);
 				}
-				throw HPT4Messages.createSQLException(t4props_, locale, "as_cancel_message_error", errorText);
+				throw TrafT4Messages.createSQLException(t4props_, locale, "as_cancel_message_error", errorText);
 			} // end switch
 	
 			currentTime = (new java.util.Date()).getTime();
@@ -538,9 +538,9 @@ class InterfaceConnection {
 				// exceptions.
 				//
 				int sc = se.getErrorCode();
-				int s1 = HPT4Messages.createSQLException(t4props_, locale, "socket_open_error", null).getErrorCode();
-				int s2 = HPT4Messages.createSQLException(t4props_, locale, "socket_write_error", null).getErrorCode();
-				int s3 = HPT4Messages.createSQLException(t4props_, locale, "socket_read_error", null).getErrorCode();
+				int s1 = TrafT4Messages.createSQLException(t4props_, locale, "socket_open_error", null).getErrorCode();
+				int s2 = TrafT4Messages.createSQLException(t4props_, locale, "socket_write_error", null).getErrorCode();
+				int s3 = TrafT4Messages.createSQLException(t4props_, locale, "socket_read_error", null).getErrorCode();
 
 				if (sc == s1 || sc == s2 || sc == s3) {
 					if (t4props_.t4Logger_.isLoggable(Level.INFO)) {
@@ -585,10 +585,10 @@ class InterfaceConnection {
 
 					if (ex_nr_d == odbc_SQLSvc_InitializeDialogue_exc_.SQL_PASSWORD_EXPIRING ||
 							ex_nr_d == odbc_SQLSvc_InitializeDialogue_exc_.SQL_PASSWORD_GRACEPERIOD) {
-						HPT4Messages.setSQLWarning(this.t4props_, this._t4Conn, idr.SQLError);
+						TrafT4Messages.setSQLWarning(this.t4props_, this._t4Conn, idr.SQLError);
 						done = true;
 					} else {
-						HPT4Messages.throwSQLException(t4props_, idr.SQLError);
+						TrafT4Messages.throwSQLException(t4props_, idr.SQLError);
 					}
 				}
 			}
@@ -606,12 +606,12 @@ class InterfaceConnection {
 			}
 
 			if (currentTime >= endTime) {
-				se1 = HPT4Messages.createSQLException(t4props_, locale, "ids_s1_t00", null);
+				se1 = TrafT4Messages.createSQLException(t4props_, locale, "ids_s1_t00", null);
 			} else if (tryNum >= retryCount) {
-				se1 = HPT4Messages.createSQLException(t4props_, locale, "as_connect_message_error",
+				se1 = TrafT4Messages.createSQLException(t4props_, locale, "as_connect_message_error",
 						"exceeded retry count");
 			} else {
-				se1 = HPT4Messages.createSQLException(t4props_, locale, "as_connect_message_error", null);
+				se1 = TrafT4Messages.createSQLException(t4props_, locale, "as_connect_message_error", null);
 			}
 			throw se1;
 		}
@@ -744,7 +744,7 @@ class InterfaceConnection {
 			initDiag(true,true);
 		}catch(SQLException e) {
 			if(outContext == null || outContext.certificate == null) {
-				SQLException he = HPT4Messages.createSQLException(t4props_, this.locale, "certificate_download_error", e.getMessage());
+				SQLException he = TrafT4Messages.createSQLException(t4props_, this.locale, "certificate_download_error", e.getMessage());
 				he.setNextException(e);
 				throw he;
 			}
@@ -801,7 +801,7 @@ class InterfaceConnection {
 				if (!cr.m_p4_dataSource.equals(t4props_.getServerDataSource())) {
 					Object[] messageArguments = new Object[1];
 					messageArguments[0] = cr.m_p4_dataSource;
-					sqlwarning_ = HPT4Messages.createSQLWarning(t4props_, "connected_to_Default_DS", messageArguments);
+					sqlwarning_ = TrafT4Messages.createSQLWarning(t4props_, "connected_to_Default_DS", messageArguments);
 				}
 				break;
 			case odbc_Dcs_GetObjRefHdl_exc_.odbc_Dcs_GetObjRefHdl_ASTryAgain_exn_:
@@ -856,7 +856,7 @@ class InterfaceConnection {
 					errorText = errorText + "  :" + "Error text = " + cr.m_p1_exception.ErrorText;
 
 				}
-				throw HPT4Messages.createSQLException(t4props_, locale, "as_connect_message_error", errorText);
+				throw TrafT4Messages.createSQLException(t4props_, locale, "as_connect_message_error", errorText);
 			}
 
 			if (done == false && t4props_.t4Logger_.isLoggable(Level.INFO)) {
@@ -872,11 +872,11 @@ class InterfaceConnection {
 			SQLException se2;
 
 			if (currentTime >= endTime) {
-				se1 = HPT4Messages.createSQLException(t4props_, locale, "ids_s1_t00", null);
-				se2 = HPT4Messages.createSQLException(t4props_, locale, errorMsg, errorMsg_detail);
+				se1 = TrafT4Messages.createSQLException(t4props_, locale, "ids_s1_t00", null);
+				se2 = TrafT4Messages.createSQLException(t4props_, locale, errorMsg, errorMsg_detail);
 				se1.setNextException(se2);
 			} else {
-				se1 = HPT4Messages.createSQLException(t4props_, locale, errorMsg, errorMsg_detail);
+				se1 = TrafT4Messages.createSQLException(t4props_, locale, errorMsg, errorMsg_detail);
 			}
 
 			throw se1;
@@ -912,14 +912,14 @@ class InterfaceConnection {
 	// @deprecated
 	void isConnectionClosed() throws SQLException {
 		if (isClosed_ == false) {
-			throw HPT4Messages.createSQLException(t4props_, locale, "invalid_connection", null);
+			throw TrafT4Messages.createSQLException(t4props_, locale, "invalid_connection", null);
 		}
 	}
 
 	// @deprecated
 	void isConnectionOpen() throws SQLException {
 		if (isClosed_) {
-			throw HPT4Messages.createSQLException(t4props_, locale, "invalid_connection", null);
+			throw TrafT4Messages.createSQLException(t4props_, locale, "invalid_connection", null);
 		}
 	}
 
@@ -1021,7 +1021,7 @@ class InterfaceConnection {
 
 			// do the warning processing
 			if (scr_.m_p2.length != 0) {
-				HPT4Messages.setSQLWarning(conn.props_, conn, scr_.m_p2);
+				TrafT4Messages.setSQLWarning(conn.props_, conn, scr_.m_p2);
 			}
 			if (t4props_.t4Logger_.isLoggable(Level.FINEST) == true) {
 				Object p[] = T4LoggingUtilities.makeParams(conn.props_, attr, valueNum, valueString);
@@ -1035,14 +1035,14 @@ class InterfaceConnection {
 				String temp = "odbc_SQLSvc_SetConnectionOption_SQLError_exn_ occurred.";
 				t4props_.t4Logger_.logp(Level.FINEST, "InterfaceConnection", "setConnectionAttr", temp, p);
 			}
-			HPT4Messages.throwSQLException(t4props_, scr_.m_p1.errorList);
+			TrafT4Messages.throwSQLException(t4props_, scr_.m_p1.errorList);
 		default:
 			if (t4props_.t4Logger_.isLoggable(Level.FINEST) == true) {
 				Object p[] = T4LoggingUtilities.makeParams(conn.props_, attr, valueNum, valueString);
 				String temp = "UnknownException occurred.";
 				t4props_.t4Logger_.logp(Level.FINEST, "InterfaceConnection", "setConnectionAttr", temp, p);
 			}
-			throw HPT4Messages.createSQLException(conn.props_, locale, "ids_unknown_reply_error", null);
+			throw TrafT4Messages.createSQLException(conn.props_, locale, "ids_unknown_reply_error", null);
 		}
 	};
 
@@ -1057,7 +1057,7 @@ class InterfaceConnection {
 		if (level != Connection.TRANSACTION_NONE && level != Connection.TRANSACTION_READ_COMMITTED
 				&& level != Connection.TRANSACTION_READ_UNCOMMITTED && level != Connection.TRANSACTION_REPEATABLE_READ
 				&& level != Connection.TRANSACTION_SERIALIZABLE) {
-			throw HPT4Messages.createSQLException(conn.props_, locale, "invalid_transaction_isolation", null);
+			throw TrafT4Messages.createSQLException(conn.props_, locale, "invalid_transaction_isolation", null);
 		}
 
 		txnIsolationLevel = level;
@@ -1215,7 +1215,7 @@ class InterfaceConnection {
 	void endTransaction(short commitOption) throws SQLException {
 		EndTransactionReply etr_ = null;
 		if (autoCommit && !_t4Conn.isBeginTransaction()) {
-			throw HPT4Messages.createSQLException(t4props_, locale, "invalid_commit_mode", null);
+			throw TrafT4Messages.createSQLException(t4props_, locale, "invalid_commit_mode", null);
 		}
 
 		isConnectionOpen();
@@ -1242,7 +1242,7 @@ class InterfaceConnection {
 				String temp = "odbc_SQLSvc_EndTransaction_ParamError_exn_ :";
 				t4props_.t4Logger_.logp(Level.FINEST, "InterfaceConnection", "endTransaction", temp, p);
 			}
-			throw HPT4Messages.createSQLException(t4props_, locale, "ParamError:" + etr_.m_p1.ParamError, null);
+			throw TrafT4Messages.createSQLException(t4props_, locale, "ParamError:" + etr_.m_p1.ParamError, null);
 		case odbc_SQLSvc_EndTransaction_exc_.odbc_SQLSvc_EndTransaction_InvalidConnection_exn_:
 			if (t4props_.t4Logger_.isLoggable(Level.FINEST) == true) {
 				Object p[] = T4LoggingUtilities.makeParams(t4props_, commitOption);
@@ -1256,7 +1256,7 @@ class InterfaceConnection {
 				String temp = "odbc_SQLSvc_EndTransaction_SQLError_exn_:" + etr_.m_p1.SQLError;
 				t4props_.t4Logger_.logp(Level.FINEST, "InterfaceConnection", "endTransaction", temp, p);
 			}
-			HPT4Messages.throwSQLException(t4props_, etr_.m_p1.SQLError);
+			TrafT4Messages.throwSQLException(t4props_, etr_.m_p1.SQLError);
 		case odbc_SQLSvc_EndTransaction_exc_.odbc_SQLSvc_EndTransaction_SQLInvalidHandle_exn_:
 			if (t4props_.t4Logger_.isLoggable(Level.FINEST) == true) {
 				Object p[] = T4LoggingUtilities.makeParams(t4props_, commitOption);

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/38e49cf7/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/InterfaceResultSet.java
----------------------------------------------------------------------
diff --git a/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/InterfaceResultSet.java b/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/InterfaceResultSet.java
index 8dbbc2f..2d2390b 100644
--- a/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/InterfaceResultSet.java
+++ b/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/InterfaceResultSet.java
@@ -173,7 +173,7 @@ class InterfaceResultSet {
 				break;
 			case SQLDTCODE_TIME:
 				if (ODBCDataType == java.sql.Types.OTHER) // For
-				// HPT4Desc.SQLDTCODE_HOUR_TO_FRACTION
+				// TrafT4Desc.SQLDTCODE_HOUR_TO_FRACTION
 				{
 					allocLength = SQLOctetLength;
 				} else {
@@ -250,13 +250,13 @@ class InterfaceResultSet {
 			case SQLDTCODE_TIME:
 
 				// Need to add code here to check if it's
-				// HPT4Desc.SQLDTCODE_HOUR_TO_FRACTION
+				// TrafT4Desc.SQLDTCODE_HOUR_TO_FRACTION
 				if (ODBCDataType != java.sql.Types.OTHER) {
 					retObj = Time.valueOf(tmpStr);
 					break;
 				} else {
 					// Do default processing as it is
-					// HPT4Desc.SQLDTCODE_HOUR_TO_FRACTION
+					// TrafT4Desc.SQLDTCODE_HOUR_TO_FRACTION
 				}
 			default:
 				retObj = tmpStr;
@@ -311,7 +311,7 @@ class InterfaceResultSet {
 				tmpStr = String.valueOf(Bytes.extractLong(ibuffer, byteIndex, this.ic_.getByteSwap()));
 				break;
 			default:
-				throw HPT4Messages.createSQLException(conn.props_, conn.getLocale(), "restricted_data_type", null);
+				throw TrafT4Messages.createSQLException(conn.props_, conn.getLocale(), "restricted_data_type", null);
 			}
 			retObj = new BigDecimal((new BigInteger(tmpStr)), scale);
 			break;
@@ -344,7 +344,7 @@ class InterfaceResultSet {
 		case SQLTYPECODE_BITVAR:
 		case SQLTYPECODE_BPINT_UNSIGNED:
 		default:
-			throw HPT4Messages.createSQLException(conn.props_, conn.getLocale(), "restricted_data_type", null);
+			throw TrafT4Messages.createSQLException(conn.props_, conn.getLocale(), "restricted_data_type", null);
 		}
 		return retObj;
 	} // end getFetchString
@@ -360,7 +360,7 @@ class InterfaceResultSet {
 
 	// -------------------------------------------------------------------
 	// get the column value data from Execute2 in String format
-	static Object getExecute2FetchString(TrafT4Connection conn, HPT4Desc desc, byte[] values, int noNullValue,
+	static Object getExecute2FetchString(TrafT4Connection conn, TrafT4Desc desc, byte[] values, int noNullValue,
 			int ODBCDataType, boolean useOldDateFormat, boolean swap) throws SQLException {
 		Object retObj;
 		String tmpStr;
@@ -452,7 +452,7 @@ class InterfaceResultSet {
 
 			case SQLDTCODE_TIME:
 				if (ODBCDataType == java.sql.Types.OTHER) // For
-				// HPT4Desc.SQLDTCODE_HOUR_TO_FRACTION
+				// TrafT4Desc.SQLDTCODE_HOUR_TO_FRACTION
 				{
 					length = desc.sqlOctetLength_;
 					retObj = new String(Bytes.read_chars(values, noNullValue, length));
@@ -573,7 +573,7 @@ class InterfaceResultSet {
 		case SQLTYPECODE_BITVAR:
 		case SQLTYPECODE_BPINT_UNSIGNED:
 		default:
-			throw HPT4Messages.createSQLException(conn.props_, conn.getLocale(), "restricted_data_type", null);
+			throw TrafT4Messages.createSQLException(conn.props_, conn.getLocale(), "restricted_data_type", null);
 		}
 		return retObj;
 	} // end getExecute2FetchString
@@ -661,7 +661,7 @@ class InterfaceResultSet {
 					}
 
 					if (columnValue == null) {
-						throw HPT4Messages
+						throw TrafT4Messages
 								.createSQLException(rs.connection_.props_, ic_.getLocale(), "null_data", null);
 					}
 				} else {
@@ -729,7 +729,7 @@ class InterfaceResultSet {
 					columnValue = getExecute2FetchString(rs.connection_, rs.outputDesc_[columnIndex], values,
 							noNullValueOffset, rs.outputDesc_[columnIndex].dataType_, rs.useOldDateFormat(), this.ic_.getByteSwap());
 					if (columnValue == null) {
-						throw HPT4Messages
+						throw TrafT4Messages
 								.createSQLException(rs.connection_.props_, ic_.getLocale(), "null_data", null);
 					}
 				} // end if else
@@ -791,7 +791,7 @@ class InterfaceResultSet {
 
 			// do warning processing
 			if (fr.errorList.length != 0) {
-				HPT4Messages.setSQLWarning(rs.connection_.props_, rs, fr.errorList);
+				TrafT4Messages.setSQLWarning(rs.connection_.props_, rs, fr.errorList);
 			}
 			//endOfData = (fr.rowsAffected < maxRowCnt) ? true : false;
 
@@ -818,7 +818,7 @@ class InterfaceResultSet {
 			break;
 
 		default:
-			HPT4Messages.throwSQLException(rs.connection_.props_, fr.errorList);
+			TrafT4Messages.throwSQLException(rs.connection_.props_, fr.errorList);
 
 		}
 
@@ -865,14 +865,14 @@ class InterfaceResultSet {
 					rs_.connection_.props_.t4Logger_.logp(Level.FINEST, "InterfaceResultSet", "close", temp, p);
 				}
 
-				HPT4Messages.throwSQLException(rs_.connection_.props_, cry_.m_p1.SQLError);
+				TrafT4Messages.throwSQLException(rs_.connection_.props_, cry_.m_p1.SQLError);
 			default:
 				if (ic_.t4props_.t4Logger_.isLoggable(Level.FINEST) == true) {
 					Object p[] = T4LoggingUtilities.makeParams(rs_.connection_.props_);
 					String temp = "UnknownException occurred during close.";
 					rs_.connection_.props_.t4Logger_.logp(Level.FINEST, "InterfaceResultSet", "close", temp, p);
 				}
-				throw HPT4Messages.createSQLException(rs_.connection_.props_, ic_.getLocale(),
+				throw TrafT4Messages.createSQLException(rs_.connection_.props_, ic_.getLocale(),
 						"ids_unknown_reply_error", null);
 			} // end switch
 		} // end if
@@ -885,7 +885,7 @@ class InterfaceResultSet {
 	};
 
 	// ----------------------------------------------------------------------------
-	static Object[] getExecute2Outputs(TrafT4Connection conn, HPT4Desc[] desc, byte[] values, boolean swap) throws SQLException
+	static Object[] getExecute2Outputs(TrafT4Connection conn, TrafT4Desc[] desc, byte[] values, boolean swap) throws SQLException
 
 	{
 		Object[] columnArray;
@@ -907,13 +907,13 @@ class InterfaceResultSet {
 			}
 
 			if ((nullValueOffset != -1 && Bytes.extractShort(values, nullValueOffset, swap) == -1)
-					|| (desc[columnIndex].paramMode_ == HPT4ParameterMetaData.parameterModeIn)) {
+					|| (desc[columnIndex].paramMode_ == TrafT4ParameterMetaData.parameterModeIn)) {
 				columnValue = null;
 			} else {
 				columnValue = getExecute2FetchString(conn, desc[columnIndex], values, noNullValueOffset,
 						desc[columnIndex].dataType_, false, swap);
 				if (columnValue == null) {
-					throw HPT4Messages.createSQLException(conn.props_, conn.getLocale(), "null_data", null);
+					throw TrafT4Messages.createSQLException(conn.props_, conn.getLocale(), "null_data", null);
 				}
 			} // end if else
 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/38e49cf7/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/InterfaceStatement.java
----------------------------------------------------------------------
diff --git a/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/InterfaceStatement.java b/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/InterfaceStatement.java
index e6c7af8..153394d 100644
--- a/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/InterfaceStatement.java
+++ b/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/InterfaceStatement.java
@@ -138,7 +138,7 @@ class InterfaceStatement {
 
 		if (paramValue == null) {
 			if (nullValue == -1) {
-				throw HPT4Messages.createSQLException(pstmt.connection_.props_, locale,
+				throw TrafT4Messages.createSQLException(pstmt.connection_.props_, locale,
 						"null_parameter_for_not_null_column", new Integer(paramNumber));
 			}
 
@@ -172,12 +172,12 @@ class InterfaceStatement {
 					}
 					tmpBarray = ((String) paramValue).getBytes(charSet);
 				} catch (Exception e) {
-					throw HPT4Messages.createSQLException(pstmt.connection_.props_, locale, "unsupported_encoding",
+					throw TrafT4Messages.createSQLException(pstmt.connection_.props_, locale, "unsupported_encoding",
 							charSet);
 				}
 			} // end if (paramValue instanceof String)
 			else {
-				throw HPT4Messages.createSQLException(pstmt.connection_.props_, locale, "invalid_parameter_value",
+				throw TrafT4Messages.createSQLException(pstmt.connection_.props_, locale, "invalid_parameter_value",
 						"CHAR data should be either bytes or String for column: " + paramNumber);
 			}
 
@@ -203,7 +203,7 @@ class InterfaceStatement {
 					}
 				}
 			} else {
-				throw HPT4Messages.createSQLException(pstmt.connection_.props_, locale, "invalid_string_parameter",
+				throw TrafT4Messages.createSQLException(pstmt.connection_.props_, locale, "invalid_string_parameter",
 						"CHAR input data is longer than the length for column: " + paramNumber);
 			}
 
@@ -227,13 +227,13 @@ class InterfaceStatement {
 					}
 					tmpBarray = ((String) paramValue).getBytes(charSet);
 				} catch (Exception e) {
-					throw HPT4Messages.createSQLException(pstmt.connection_.props_, locale, "unsupported_encoding",
+					throw TrafT4Messages.createSQLException(pstmt.connection_.props_, locale, "unsupported_encoding",
 							charSet);
 				}
 
 			} // end if (paramValue instanceof String)
 			else {
-				throw HPT4Messages.createSQLException(pstmt.connection_.props_, locale, "invalid_parameter_value",
+				throw TrafT4Messages.createSQLException(pstmt.connection_.props_, locale, "invalid_parameter_value",
 						"VARCHAR data should be either bytes or String for column: " + paramNumber);
 			}
 
@@ -242,7 +242,7 @@ class InterfaceStatement {
 				Bytes.insertShort(values, noNullValue, (short) dataLen, this.ic_.getByteSwap());
 				System.arraycopy(tmpBarray, 0, values, noNullValue + 2, dataLen);
 			} else {
-				throw HPT4Messages.createSQLException(pstmt.connection_.props_, locale, "invalid_parameter_value",
+				throw TrafT4Messages.createSQLException(pstmt.connection_.props_, locale, "invalid_parameter_value",
 						"VARCHAR input data is longer than the length for column: " + paramNumber);
 			}
 			break;
@@ -260,7 +260,7 @@ class InterfaceStatement {
 						throw new IllegalArgumentException();
 					}
 				} catch (IllegalArgumentException iex) {
-					throw HPT4Messages
+					throw TrafT4Messages
 							.createSQLException(
 									pstmt.connection_.props_,
 									locale,
@@ -274,7 +274,7 @@ class InterfaceStatement {
 				} catch (java.io.UnsupportedEncodingException e) {
 					Object[] messageArguments = new Object[1];
 					messageArguments[0] = e.getMessage();
-					throw HPT4Messages.createSQLException(pstmt.connection_.props_, locale, "unsupported_encoding",
+					throw TrafT4Messages.createSQLException(pstmt.connection_.props_, locale, "unsupported_encoding",
 							messageArguments);
 				}
 				break;
@@ -283,7 +283,7 @@ class InterfaceStatement {
 				try {
 					tmpts = Timestamp.valueOf((String) paramValue);
 				} catch (IllegalArgumentException iex) {
-					throw HPT4Messages.createSQLException(pstmt.connection_.props_, locale, "invalid_parameter_value",
+					throw TrafT4Messages.createSQLException(pstmt.connection_.props_, locale, "invalid_parameter_value",
 							"Timestamp data format is incorrect for column: " + paramNumber + " = " + paramValue);
 				}
 
@@ -295,7 +295,7 @@ class InterfaceStatement {
 				} catch (java.io.UnsupportedEncodingException e) {
 					Object[] messageArguments = new Object[1];
 					messageArguments[0] = e.getMessage();
-					throw HPT4Messages.createSQLException(pstmt.connection_.props_, locale, "unsupported_encoding",
+					throw TrafT4Messages.createSQLException(pstmt.connection_.props_, locale, "unsupported_encoding",
 							messageArguments);
 				}
 				dataLen = tmpBarray.length;
@@ -326,54 +326,54 @@ class InterfaceStatement {
 						byte[] tempb1 = tmptime.toString().getBytes("ASCII");
 						System.arraycopy(tempb1, 0, values, noNullValue, tempb1.length);
 					} catch (IllegalArgumentException iex) {
-						throw HPT4Messages.createSQLException(pstmt.connection_.props_, locale,
+						throw TrafT4Messages.createSQLException(pstmt.connection_.props_, locale,
 								"invalid_parameter_value", "Time data format is incorrect for column: " + paramNumber
 										+ " = " + paramValue);
 					} catch (java.io.UnsupportedEncodingException e) {
 						Object[] messageArguments = new Object[1];
 						messageArguments[0] = e.getMessage();
-						throw HPT4Messages.createSQLException(pstmt.connection_.props_, locale, "unsupported_encoding",
+						throw TrafT4Messages.createSQLException(pstmt.connection_.props_, locale, "unsupported_encoding",
 								messageArguments);
 					}
 					break;
 				} else {
-					// HPT4Desc.SQLDTCODE_HOUR_TO_FRACTION data type!!!
+					// TrafT4Desc.SQLDTCODE_HOUR_TO_FRACTION data type!!!
 					// let the next case structure handle it
 				}
-			case HPT4Desc.SQLDTCODE_YEAR:
-			case HPT4Desc.SQLDTCODE_YEAR_TO_MONTH:
-			case HPT4Desc.SQLDTCODE_MONTH:
-			case HPT4Desc.SQLDTCODE_MONTH_TO_DAY:
-			case HPT4Desc.SQLDTCODE_DAY:
-			case HPT4Desc.SQLDTCODE_HOUR:
-			case HPT4Desc.SQLDTCODE_HOUR_TO_MINUTE:
-			case HPT4Desc.SQLDTCODE_MINUTE:
-			case HPT4Desc.SQLDTCODE_MINUTE_TO_SECOND:
-				// case HPT4Desc.SQLDTCODE_MINUTE_TO_FRACTION:
-			case HPT4Desc.SQLDTCODE_SECOND:
-				// case HPT4Desc.SQLDTCODE_SECOND_TO_FRACTION:
-			case HPT4Desc.SQLDTCODE_YEAR_TO_HOUR:
-			case HPT4Desc.SQLDTCODE_YEAR_TO_MINUTE:
-			case HPT4Desc.SQLDTCODE_MONTH_TO_HOUR:
-			case HPT4Desc.SQLDTCODE_MONTH_TO_MINUTE:
-			case HPT4Desc.SQLDTCODE_MONTH_TO_SECOND:
-				// case HPT4Desc.SQLDTCODE_MONTH_TO_FRACTION:
-			case HPT4Desc.SQLDTCODE_DAY_TO_HOUR:
-			case HPT4Desc.SQLDTCODE_DAY_TO_MINUTE:
-			case HPT4Desc.SQLDTCODE_DAY_TO_SECOND:
-				// case HPT4Desc.SQLDTCODE_DAY_TO_FRACTION:
+			case TrafT4Desc.SQLDTCODE_YEAR:
+			case TrafT4Desc.SQLDTCODE_YEAR_TO_MONTH:
+			case TrafT4Desc.SQLDTCODE_MONTH:
+			case TrafT4Desc.SQLDTCODE_MONTH_TO_DAY:
+			case TrafT4Desc.SQLDTCODE_DAY:
+			case TrafT4Desc.SQLDTCODE_HOUR:
+			case TrafT4Desc.SQLDTCODE_HOUR_TO_MINUTE:
+			case TrafT4Desc.SQLDTCODE_MINUTE:
+			case TrafT4Desc.SQLDTCODE_MINUTE_TO_SECOND:
+				// case TrafT4Desc.SQLDTCODE_MINUTE_TO_FRACTION:
+			case TrafT4Desc.SQLDTCODE_SECOND:
+				// case TrafT4Desc.SQLDTCODE_SECOND_TO_FRACTION:
+			case TrafT4Desc.SQLDTCODE_YEAR_TO_HOUR:
+			case TrafT4Desc.SQLDTCODE_YEAR_TO_MINUTE:
+			case TrafT4Desc.SQLDTCODE_MONTH_TO_HOUR:
+			case TrafT4Desc.SQLDTCODE_MONTH_TO_MINUTE:
+			case TrafT4Desc.SQLDTCODE_MONTH_TO_SECOND:
+				// case TrafT4Desc.SQLDTCODE_MONTH_TO_FRACTION:
+			case TrafT4Desc.SQLDTCODE_DAY_TO_HOUR:
+			case TrafT4Desc.SQLDTCODE_DAY_TO_MINUTE:
+			case TrafT4Desc.SQLDTCODE_DAY_TO_SECOND:
+				// case TrafT4Desc.SQLDTCODE_DAY_TO_FRACTION:
 			default:
 				if (paramValue instanceof String) {
 					try {
 						tmpBarray = ((String) paramValue).getBytes("ASCII");
 					} catch (Exception e) {
-						throw HPT4Messages.createSQLException(pstmt.connection_.props_, locale, "unsupported_encoding",
+						throw TrafT4Messages.createSQLException(pstmt.connection_.props_, locale, "unsupported_encoding",
 								"ASCII");
 					}
 				} else if (paramValue instanceof byte[]) {
 					tmpBarray = (byte[]) paramValue;
 				} else {
-					throw HPT4Messages.createSQLException(pstmt.connection_.props_, locale,
+					throw TrafT4Messages.createSQLException(pstmt.connection_.props_, locale,
 							"invalid_cast_specification", "DATETIME data should be either bytes or String for column: "
 									+ paramNumber);
 				}
@@ -386,7 +386,7 @@ class InterfaceStatement {
 					// Don't know when we need this. padding blanks. Legacy??
 					Arrays.fill(values, (noNullValue + dataLen), (noNullValue + maxLength), (byte) ' ');
 				} else {
-					throw HPT4Messages.createSQLException(pstmt.connection_.props_, locale, "invalid_parameter_value",
+					throw TrafT4Messages.createSQLException(pstmt.connection_.props_, locale, "invalid_parameter_value",
 							"DATETIME data longer than column length: " + paramNumber);
 				}
 				break;
@@ -399,11 +399,11 @@ class InterfaceStatement {
 				try {
 					tmpBarray = ((String) paramValue).getBytes("ASCII");
 				} catch (Exception e) {
-					throw HPT4Messages.createSQLException(pstmt.connection_.props_, locale, "unsupported_encoding",
+					throw TrafT4Messages.createSQLException(pstmt.connection_.props_, locale, "unsupported_encoding",
 							"ASCII");
 				}
 			} else {
-				throw HPT4Messages.createSQLException(pstmt.connection_.props_, locale, "invalid_cast_specification",
+				throw TrafT4Messages.createSQLException(pstmt.connection_.props_, locale, "invalid_cast_specification",
 						"INTERVAL data should be either bytes or String for column: " + paramNumber);
 			}
 
@@ -419,7 +419,7 @@ class InterfaceStatement {
 					Arrays.fill(values, (noNullValue + dataLen), (noNullValue + maxLength), (byte) ' ');
 				}
 			} else {
-				throw HPT4Messages.createSQLException(pstmt.connection_.props_, locale, "invalid_parameter_value",
+				throw TrafT4Messages.createSQLException(pstmt.connection_.props_, locale, "invalid_parameter_value",
 						"INTERVAL data longer than column length: " + paramNumber);
 			}
 
@@ -446,12 +446,12 @@ class InterfaceStatement {
 					}
 					tmpBarray = ((String) paramValue).getBytes(charSet);
 				} catch (Exception e) {
-					throw HPT4Messages.createSQLException(pstmt.connection_.props_, locale, "unsupported_encoding",
+					throw TrafT4Messages.createSQLException(pstmt.connection_.props_, locale, "unsupported_encoding",
 							charSet);
 				}
 			} // end if (paramValue instanceof String)
 			else {
-				throw HPT4Messages.createSQLException(pstmt.connection_.props_, locale, "invalid_cast_specification",
+				throw TrafT4Messages.createSQLException(pstmt.connection_.props_, locale, "invalid_cast_specification",
 						"VARCHAR data should be either bytes or String for column: " + paramNumber);
 			}
 
@@ -466,7 +466,7 @@ class InterfaceStatement {
                                 }
 				System.arraycopy(tmpBarray, 0, values, (noNullValue + dataOffset), dataLen);
 			} else {
-				throw HPT4Messages.createSQLException(pstmt.connection_.props_, locale, "invalid_string_parameter",
+				throw TrafT4Messages.createSQLException(pstmt.connection_.props_, locale, "invalid_string_parameter",
 						"VARCHAR data longer than column length: " + paramNumber);
 			}
 			break;
@@ -580,11 +580,11 @@ class InterfaceStatement {
 				} catch (java.io.UnsupportedEncodingException e) {
 					Object[] messageArguments = new Object[1];
 					messageArguments[0] = e.getMessage();
-					throw HPT4Messages.createSQLException(pstmt.connection_.props_, locale, "unsupported_encoding",
+					throw TrafT4Messages.createSQLException(pstmt.connection_.props_, locale, "unsupported_encoding",
 							messageArguments);
 				}
 			} catch (NumberFormatException nex) {
-				throw HPT4Messages.createSQLException(pstmt.connection_.props_, locale, "invalid_parameter_value",
+				throw TrafT4Messages.createSQLException(pstmt.connection_.props_, locale, "invalid_parameter_value",
 						"DECIMAL data format incorrect for column: " + paramNumber + ". Error is: " + nex.getMessage());
 			}
 
@@ -607,7 +607,7 @@ class InterfaceStatement {
 
 			// DataTruncation is happening.
 			if (numOfZeros < 0) {
-				throw HPT4Messages.createSQLException(pstmt.connection_.props_, locale, "data_truncation_exceed", new int[]{dataLen, maxLength});
+				throw TrafT4Messages.createSQLException(pstmt.connection_.props_, locale, "data_truncation_exceed", new int[]{dataLen, maxLength});
 			}
 
 			for (i = 0; i < numOfZeros; i++) {
@@ -661,7 +661,7 @@ class InterfaceStatement {
 				ic_.t4props_.t4Logger_.logp(Level.FINEST, "InterfaceStatement", "convertObjectToSQL2", temp, p);
 			}
 
-			throw HPT4Messages.createSQLException(pstmt.connection_.props_, locale, "restricted_data_type", null);
+			throw TrafT4Messages.createSQLException(pstmt.connection_.props_, locale, "restricted_data_type", null);
 		}
 		if (ic_.t4props_.t4Logger_.isLoggable(Level.FINEST) == true) {
 			Object p[] = T4LoggingUtilities
@@ -735,7 +735,7 @@ class InterfaceStatement {
 					try {
 						convertObjectToSQL2(locale, stmt, paramValues[row * paramCount + col], paramRowCount, col,
 								dataValue.buffer, row - clientErrors.size());
-					} catch (HPT4Exception e) {
+					} catch (TrafT4Exception e) {
 						if (paramRowCount == 1) // for single rows we need to
 							// throw immediately
 							throw e;
@@ -958,40 +958,40 @@ class InterfaceStatement {
 	}
 
 	// -------------------------------------------------------------
-	static HPT4Desc[] NewDescArray(SQLItemDescList_def desc) {
+	static TrafT4Desc[] NewDescArray(SQLItemDescList_def desc) {
 		int index;
-		HPT4Desc[] HPT4DescArray;
+		TrafT4Desc[] trafT4DescArray;
 		SQLItemDesc_def SQLDesc;
 
 		if (desc.list == null || desc.list.length == 0) {
 			return null;
 		}
 
-		HPT4DescArray = new HPT4Desc[desc.list.length];
+		trafT4DescArray = new TrafT4Desc[desc.list.length];
 
 		for (index = 0; index < desc.list.length; index++) {
 			SQLDesc = desc.list[index];
 			boolean nullInfo = (((new Byte(SQLDesc.nullInfo)).shortValue()) == 1) ? true : false;
 			boolean signType = (((new Byte(SQLDesc.signType)).shortValue()) == 1) ? true : false;
-			HPT4DescArray[index] = new HPT4Desc(SQLDesc.dataType, (short) SQLDesc.datetimeCode, SQLDesc.maxLen,
+			trafT4DescArray[index] = new TrafT4Desc(SQLDesc.dataType, (short) SQLDesc.datetimeCode, SQLDesc.maxLen,
 					SQLDesc.precision, SQLDesc.scale, nullInfo, SQLDesc.colHeadingNm, signType, SQLDesc.ODBCDataType,
 					SQLDesc.ODBCPrecision, SQLDesc.SQLCharset, SQLDesc.ODBCCharset, SQLDesc.CatalogName,
 					SQLDesc.SchemaName, SQLDesc.TableName, SQLDesc.dataType, SQLDesc.intLeadPrec, SQLDesc.paramMode);
 		}
-		return HPT4DescArray;
+		return trafT4DescArray;
 	}
 
 	// -------------------------------------------------------------
-	static HPT4Desc[] NewDescArray(Descriptor2[] descArray) {
+	static TrafT4Desc[] NewDescArray(Descriptor2[] descArray) {
 		int index;
-		HPT4Desc[] HPT4DescArray;
+		TrafT4Desc[] trafT4DescArray;
 		Descriptor2 desc;
 
 		if (descArray == null || descArray.length == 0) {
 			return null;
 		}
 
-		HPT4DescArray = new HPT4Desc[descArray.length];
+		trafT4DescArray = new TrafT4Desc[descArray.length];
 
 		for (index = 0; index < descArray.length; index++) {
 			desc = descArray[index];
@@ -1005,13 +1005,13 @@ class InterfaceStatement {
 				signType = true;
 
 			}
-			HPT4DescArray[index] = new HPT4Desc(desc.noNullValue_, desc.nullValue_, desc.version_, desc.dataType_,
+			trafT4DescArray[index] = new TrafT4Desc(desc.noNullValue_, desc.nullValue_, desc.version_, desc.dataType_,
 					(short) desc.datetimeCode_, desc.maxLen_, (short) desc.precision_, (short) desc.scale_, nullInfo,
 					signType, desc.odbcDataType_, desc.odbcPrecision_, desc.sqlCharset_, desc.odbcCharset_,
 					desc.colHeadingNm_, desc.tableName_, desc.catalogName_, desc.schemaName_, desc.headingName_,
 					desc.intLeadPrec_, desc.paramMode_, desc.dataType_, desc.getRowLength());
 		}
-		return HPT4DescArray;
+		return trafT4DescArray;
 	}
 
 	// -------------------------------------------------------------
@@ -1049,9 +1049,9 @@ class InterfaceStatement {
 			// ignore the SQLWarning for the static close
 			break;
 		case odbc_SQLSvc_Close_exc_.odbc_SQLSvc_Close_SQLError_exn_:
-			HPT4Messages.throwSQLException(stmt_.connection_.props_, cry_.m_p1.SQLError);
+			TrafT4Messages.throwSQLException(stmt_.connection_.props_, cry_.m_p1.SQLError);
 		default:
-			throw HPT4Messages.createSQLException(stmt_.connection_.props_, ic_.getLocale(), "ids_unknown_reply_error",
+			throw TrafT4Messages.createSQLException(stmt_.connection_.props_, ic_.getLocale(), "ids_unknown_reply_error",
 					null);
 		} // end switch
 
@@ -1091,10 +1091,10 @@ class InterfaceStatement {
 		txId = Bytes.createIntBytes(0, false);
 
 		if (sqlStmtType_ == TRANSPORT.TYPE_STATS) {
-			throw HPT4Messages.createSQLException(pstmt.connection_.props_, ic_.getLocale(), "infostats_invalid_error",
+			throw TrafT4Messages.createSQLException(pstmt.connection_.props_, ic_.getLocale(), "infostats_invalid_error",
 					null);
 		} else if (sqlStmtType_ == TRANSPORT.TYPE_CONFIG) {
-			throw HPT4Messages.createSQLException(pstmt.connection_.props_, ic_.getLocale(),
+			throw TrafT4Messages.createSQLException(pstmt.connection_.props_, ic_.getLocale(),
 					"config_cmd_invalid_error", null);
 		}
 
@@ -1108,13 +1108,13 @@ class InterfaceStatement {
 		switch (pr.returnCode) {
 		case TRANSPORT.SQL_SUCCESS:
 		case TRANSPORT.SQL_SUCCESS_WITH_INFO:
-			HPT4Desc[] OutputDesc = InterfaceStatement.NewDescArray(pr.outputDesc);
-			HPT4Desc[] InputDesc = InterfaceStatement.NewDescArray(pr.inputDesc);
+			TrafT4Desc[] OutputDesc = InterfaceStatement.NewDescArray(pr.outputDesc);
+			TrafT4Desc[] InputDesc = InterfaceStatement.NewDescArray(pr.inputDesc);
 			pstmt.setPrepareOutputs2(InputDesc, OutputDesc, pr.inputNumberParams, pr.outputNumberParams,
 					pr.inputParamLength, pr.outputParamLength, pr.inputDescLength, pr.outputDescLength);
 
 			if (pr.errorList != null && pr.errorList.length > 0) {
-				HPT4Messages.setSQLWarning(stmt_.connection_.props_, pstmt, pr.errorList);
+				TrafT4Messages.setSQLWarning(stmt_.connection_.props_, pstmt, pr.errorList);
 			}
 
 			this.stmtHandle_ = pr.stmtHandle;
@@ -1124,7 +1124,7 @@ class InterfaceStatement {
 		case odbc_SQLSvc_Prepare_exc_.odbc_SQLSvc_Prepare_SQLError_exn_:
 
 		default:
-			HPT4Messages.throwSQLException(stmt_.connection_.props_, pr.errorList);
+			TrafT4Messages.throwSQLException(stmt_.connection_.props_, pr.errorList);
 		}
 
 		if (ic_.t4props_.t4Logger_.isLoggable(Level.FINEST) == true) {
@@ -1325,11 +1325,11 @@ class InterfaceStatement {
 			}
 
 			// get the descriptors from the proper location
-			HPT4Desc[][] desc = null;
+			TrafT4Desc[][] desc = null;
 
 			// try from execute data first
 			if (er.outputDesc != null && er.outputDesc.length > 0) {
-				desc = new HPT4Desc[er.outputDesc.length][];
+				desc = new TrafT4Desc[er.outputDesc.length][];
 
 				for (int i = 0; i < er.outputDesc.length; i++) {
 					desc[i] = InterfaceStatement.NewDescArray(er.outputDesc[i]);
@@ -1337,7 +1337,7 @@ class InterfaceStatement {
 			}
 			// try from the prepare data
 			else if (stmt.outputDesc_ != null && stmt.outputDesc_.length > 0) {
-				desc = new HPT4Desc[1][];
+				desc = new TrafT4Desc[1][];
 				desc[0] = stmt.outputDesc_;
 			}
 
@@ -1368,15 +1368,15 @@ class InterfaceStatement {
 				}
 			}
 			if (er.errorList != null) {
-				HPT4Messages.setSQLWarning(stmt_.connection_.props_, stmt, er.errorList);
+				TrafT4Messages.setSQLWarning(stmt_.connection_.props_, stmt, er.errorList);
 			}
 		} else {
 			Arrays.fill(stmt.batchRowCount_, -3); // fill with failed
-			HPT4Messages.throwSQLException(stmt_.connection_.props_, er.errorList);
+			TrafT4Messages.throwSQLException(stmt_.connection_.props_, er.errorList);
 		}
 	    //3164
 	    if (batchException) {
-	    	HPT4Messages.throwSQLException(stmt_.connection_.props_, er.errorList);
+	    	TrafT4Messages.throwSQLException(stmt_.connection_.props_, er.errorList);
 	    }
 	}
 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/38e49cf7/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/NCSAddress.java
----------------------------------------------------------------------
diff --git a/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/NCSAddress.java b/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/NCSAddress.java
index a23c7e6..5e5b7a6 100644
--- a/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/NCSAddress.java
+++ b/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/NCSAddress.java
@@ -62,7 +62,7 @@ final class NCSAddress extends Address {
 		m_locale = locale;
 
 		if (addr == null) {
-			SQLException se = HPT4Messages.createSQLException(m_t4props, m_locale, "address_null_error", null);
+			SQLException se = TrafT4Messages.createSQLException(m_t4props, m_locale, "address_null_error", null);
 			throw se;
 		}
 
@@ -75,16 +75,16 @@ final class NCSAddress extends Address {
 			//
 			m_type = OS_type;
 			if (addr.endsWith(ODBCServerSuffix) == false) {
-				SQLException se = HPT4Messages.createSQLException(m_t4props, m_locale, "address_parsing_error", addr);
-				SQLException se2 = HPT4Messages.createSQLException(m_t4props, m_locale, "odbc_server_suffix_error",
+				SQLException se = TrafT4Messages.createSQLException(m_t4props, m_locale, "address_parsing_error", addr);
+				SQLException se2 = TrafT4Messages.createSQLException(m_t4props, m_locale, "odbc_server_suffix_error",
 						ODBCServerSuffix);
 
 				se.setNextException(se2);
 				throw se;
 			}
 			if (addr.length() < minODBCServerAddrLen) {
-				SQLException se = HPT4Messages.createSQLException(m_t4props, m_locale, "address_parsing_error", addr);
-				SQLException se2 = HPT4Messages.createSQLException(m_t4props, m_locale, "min_address_length_error",
+				SQLException se = TrafT4Messages.createSQLException(m_t4props, m_locale, "address_parsing_error", addr);
+				SQLException se2 = TrafT4Messages.createSQLException(m_t4props, m_locale, "min_address_length_error",
 						null);
 
 				se.setNextException(se2);
@@ -100,8 +100,8 @@ final class NCSAddress extends Address {
 				interpretAddress(t4props, locale, addr);
 
 			if ((m_machineName == null && m_ipAddress == null) || m_processName == null || m_portNumber == null) {
-				SQLException se = HPT4Messages.createSQLException(m_t4props, m_locale, "address_parsing_error", addr);
-				SQLException se2 = HPT4Messages.createSQLException(m_t4props, m_locale, "address_format_1_error", null);
+				SQLException se = TrafT4Messages.createSQLException(m_t4props, m_locale, "address_parsing_error", addr);
+				SQLException se2 = TrafT4Messages.createSQLException(m_t4props, m_locale, "address_format_1_error", null);
 
 				se.setNextException(se2);
 				throw se;
@@ -125,8 +125,8 @@ final class NCSAddress extends Address {
 		int index2 = addr.lastIndexOf(".", index3);
 
 		if ((-1 < index1 && index1 < index2 && index2 < index3 && index3 < addr.length()) == false) {
-			SQLException se = HPT4Messages.createSQLException(m_t4props, m_locale, "address_parsing_error", addr);
-			SQLException se2 = HPT4Messages.createSQLException(m_t4props, m_locale, "address_format_1_error", null);
+			SQLException se = TrafT4Messages.createSQLException(m_t4props, m_locale, "address_parsing_error", addr);
+			SQLException se2 = TrafT4Messages.createSQLException(m_t4props, m_locale, "address_format_1_error", null);
 
 			se.setNextException(se2);
 			throw se;
@@ -162,8 +162,8 @@ final class NCSAddress extends Address {
 		int index2 = addr.indexOf(".", 0);
 
 		if ((/*-1 < index1 && index1 < index2 &&*/ index2 < index4 && index4 < index3 && index3 < addr.length()) == false) {
-			SQLException se = HPT4Messages.createSQLException(m_t4props, m_locale, "address_parsing_error", addr);
-			SQLException se2 = HPT4Messages.createSQLException(m_t4props, m_locale, "address_format_1_error", null);
+			SQLException se = TrafT4Messages.createSQLException(m_t4props, m_locale, "address_parsing_error", addr);
+			SQLException se2 = TrafT4Messages.createSQLException(m_t4props, m_locale, "address_format_1_error", null);
 
 			se.setNextException(se2);
 			throw se;

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/38e49cf7/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/PreparedStatementManager.java
----------------------------------------------------------------------
diff --git a/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/PreparedStatementManager.java b/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/PreparedStatementManager.java
index 801a4b1..9ca149b 100644
--- a/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/PreparedStatementManager.java
+++ b/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/PreparedStatementManager.java
@@ -28,7 +28,7 @@ import java.util.Hashtable;
 import java.util.Iterator;
 import java.util.logging.Level;
 
-public abstract class PreparedStatementManager extends HPT4Handle {
+public abstract class PreparedStatementManager extends TrafT4Handle {
 
 	boolean isStatementCachingEnabled() {
 		if (maxStatements_ < 1) {

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/38e49cf7/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/T4Address.java
----------------------------------------------------------------------
diff --git a/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/T4Address.java b/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/T4Address.java
index 6cc2085..2bc145c 100644
--- a/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/T4Address.java
+++ b/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/T4Address.java
@@ -66,7 +66,7 @@ final class T4Address extends Address {
 		super(t4props, locale, addr);
 
 		if (addr == null) {
-			SQLException se = HPT4Messages.createSQLException(m_t4props, m_locale, "address_null_error", null);
+			SQLException se = TrafT4Messages.createSQLException(m_t4props, m_locale, "address_null_error", null);
 			throw se;
 		}
 
@@ -80,8 +80,8 @@ final class T4Address extends Address {
 		// We don't recognize this address syntax
 		//
 		if (acceptsURL(addr) == false) {
-			SQLException se = HPT4Messages.createSQLException(m_t4props, m_locale, "address_parsing_error", addr);
-			SQLException se2 = HPT4Messages.createSQLException(m_t4props, m_locale, "unknown_prefix_error", null);
+			SQLException se = TrafT4Messages.createSQLException(m_t4props, m_locale, "address_parsing_error", addr);
+			SQLException se2 = TrafT4Messages.createSQLException(m_t4props, m_locale, "unknown_prefix_error", null);
 
 			se.setNextException(se2);
 			throw se;
@@ -157,8 +157,8 @@ final class T4Address extends Address {
 	 */
 	private String extractHostFromUrl(String url) throws SQLException {
 		if (url.length() < minT4ConnectionAddrLen) {
-			SQLException se = HPT4Messages.createSQLException(m_t4props, m_locale, "address_parsing_error", url);
-			SQLException se2 = HPT4Messages.createSQLException(m_t4props, m_locale, "min_address_length_error", null);
+			SQLException se = TrafT4Messages.createSQLException(m_t4props, m_locale, "address_parsing_error", url);
+			SQLException se2 = TrafT4Messages.createSQLException(m_t4props, m_locale, "min_address_length_error", null);
 
 			se.setNextException(se2);
 			throw se;
@@ -173,8 +173,8 @@ final class T4Address extends Address {
 
 		}
 		if (hostEndIndex < 0) {
-			SQLException se = HPT4Messages.createSQLException(m_t4props, m_locale, "address_parsing_error", url);
-			SQLException se2 = HPT4Messages.createSQLException(m_t4props, m_locale, "address_format_error", url);
+			SQLException se = TrafT4Messages.createSQLException(m_t4props, m_locale, "address_parsing_error", url);
+			SQLException se2 = TrafT4Messages.createSQLException(m_t4props, m_locale, "address_format_error", url);
 
 			se.setNextException(se2);
 			throw se;
@@ -182,9 +182,9 @@ final class T4Address extends Address {
 
 		String host = url.substring(hostStartIndex, hostEndIndex);
 		if ((host == null) || (host.length() == 0)) {
-			SQLException se = HPT4Messages.createSQLException(m_t4props, m_locale, "address_parsing_error", url);
-			SQLException se2 = HPT4Messages.createSQLException(m_t4props, m_locale, "address_format_error", null);
-			SQLException se3 = HPT4Messages.createSQLException(m_t4props, m_locale, "missing_ip_or_name_error", null);
+			SQLException se = TrafT4Messages.createSQLException(m_t4props, m_locale, "address_parsing_error", url);
+			SQLException se2 = TrafT4Messages.createSQLException(m_t4props, m_locale, "address_format_error", null);
+			SQLException se3 = TrafT4Messages.createSQLException(m_t4props, m_locale, "missing_ip_or_name_error", null);
 			se.setNextException(se2);
 			se2.setNextException(se3);
 			throw se;
@@ -232,8 +232,8 @@ final class T4Address extends Address {
 	 */
 	private boolean isIPV6(String url) throws SQLException {
 		if (url == null) {
-			SQLException se = HPT4Messages.createSQLException(m_t4props, m_locale, "address_parsing_error", url);
-			SQLException se2 = HPT4Messages.createSQLException(m_t4props, m_locale, "address_format_2_error", null);
+			SQLException se = TrafT4Messages.createSQLException(m_t4props, m_locale, "address_parsing_error", url);
+			SQLException se2 = TrafT4Messages.createSQLException(m_t4props, m_locale, "address_format_2_error", null);
 			se.setNextException(se2);
 			throw se;
 

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/38e49cf7/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/T4Connection.java
----------------------------------------------------------------------
diff --git a/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/T4Connection.java b/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/T4Connection.java
index d1ce34f..e9ab242 100644
--- a/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/T4Connection.java
+++ b/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/T4Connection.java
@@ -118,7 +118,7 @@ class T4Connection {
 			} catch (SQLException sqex) {
 				// ignores
 			}
-			throw HPT4Messages.createSQLException(m_ic.t4props_, m_locale, "ids_s1_t00", null);
+			throw TrafT4Messages.createSQLException(m_ic.t4props_, m_locale, "ids_s1_t00", null);
 		}
 	}
 
@@ -139,8 +139,8 @@ class T4Connection {
 			tempP = m_ic.t4props_;
 
 		}
-		SQLException se = HPT4Messages.createSQLException(tempP, m_locale, "internal_error", null);
-		SQLException se2 = HPT4Messages.createSQLException(tempP, m_locale, "contact_hp_error", null);
+		SQLException se = TrafT4Messages.createSQLException(tempP, m_locale, "internal_error", null);
+		SQLException se2 = TrafT4Messages.createSQLException(tempP, m_locale, "contact_traf_error", null);
 
 		se.setNextException(se2);
 		throw se;
@@ -228,19 +228,19 @@ class T4Connection {
 		} catch (SQLException se) {
 			throw se;
 		} catch (CharacterCodingException e) {
-			SQLException se = HPT4Messages.createSQLException(m_ic.t4props_, m_locale,
+			SQLException se = TrafT4Messages.createSQLException(m_ic.t4props_, m_locale,
 					"translation_of_parameter_failed", "InitializeDialogueMessage", e.getMessage());
 			se.initCause(e);
 			throw se;
 		} catch (UnsupportedCharsetException e) {
-			SQLException se = HPT4Messages.createSQLException(m_ic.t4props_, m_locale, "unsupported_encoding", e
+			SQLException se = TrafT4Messages.createSQLException(m_ic.t4props_, m_locale, "unsupported_encoding", e
 					.getCharsetName());
 			se.initCause(e);
 			throw se;
 		}
 
 		catch (Exception e) {
-			SQLException se = HPT4Messages.createSQLException(m_ic.t4props_, m_locale,
+			SQLException se = TrafT4Messages.createSQLException(m_ic.t4props_, m_locale,
 					"initialize_dialogue_message_error", e.getMessage());
 
 			se.initCause(e);
@@ -303,17 +303,17 @@ class T4Connection {
 		catch (SQLException se) {
 			throw se;
 		} catch (CharacterCodingException e) {
-			SQLException se = HPT4Messages.createSQLException(m_ic.t4props_, m_locale,
+			SQLException se = TrafT4Messages.createSQLException(m_ic.t4props_, m_locale,
 					"translation_of_parameter_failed", "TerminateDialogMessage", e.getMessage());
 			se.initCause(e);
 			throw se;
 		} catch (UnsupportedCharsetException e) {
-			SQLException se = HPT4Messages.createSQLException(m_ic.t4props_, m_locale, "unsupported_encoding", e
+			SQLException se = TrafT4Messages.createSQLException(m_ic.t4props_, m_locale, "unsupported_encoding", e
 					.getCharsetName());
 			se.initCause(e);
 			throw se;
 		} catch (Exception e) {
-			SQLException se = HPT4Messages.createSQLException(m_ic.t4props_, m_locale,
+			SQLException se = TrafT4Messages.createSQLException(m_ic.t4props_, m_locale,
 					"terminate_dialogue_message_error", e.getMessage());
 
 			se.initCause(e);
@@ -360,17 +360,17 @@ class T4Connection {
 		catch (SQLException se) {
 			throw se;
 		} catch (CharacterCodingException e) {
-			SQLException se = HPT4Messages.createSQLException(m_ic.t4props_, m_locale,
+			SQLException se = TrafT4Messages.createSQLException(m_ic.t4props_, m_locale,
 					"translation_of_parameter_failed", "SetConnectionOptionReply", e.getMessage());
 			se.initCause(e);
 			throw se;
 		} catch (UnsupportedCharsetException e) {
-			SQLException se = HPT4Messages.createSQLException(m_ic.t4props_, m_locale, "unsupported_encoding", e
+			SQLException se = TrafT4Messages.createSQLException(m_ic.t4props_, m_locale, "unsupported_encoding", e
 					.getCharsetName());
 			se.initCause(e);
 			throw se;
 		} catch (Exception e) {
-			SQLException se = HPT4Messages.createSQLException(m_ic.t4props_, m_locale,
+			SQLException se = TrafT4Messages.createSQLException(m_ic.t4props_, m_locale,
 					"set_connection_option_message_error", e.getMessage());
 
 			se.initCause(e);
@@ -406,17 +406,17 @@ class T4Connection {
 		catch (SQLException se) {
 			throw se;
 		} catch (CharacterCodingException e) {
-			SQLException se = HPT4Messages.createSQLException(m_ic.t4props_, m_locale,
+			SQLException se = TrafT4Messages.createSQLException(m_ic.t4props_, m_locale,
 					"translation_of_parameter_failed", "EndTransactionMessage", e.getMessage());
 			se.initCause(e);
 			throw se;
 		} catch (UnsupportedCharsetException e) {
-			SQLException se = HPT4Messages.createSQLException(m_ic.t4props_, m_locale, "unsupported_encoding", e
+			SQLException se = TrafT4Messages.createSQLException(m_ic.t4props_, m_locale, "unsupported_encoding", e
 					.getCharsetName());
 			se.initCause(e);
 			throw se;
 		} catch (Exception e) {
-			SQLException se = HPT4Messages.createSQLException(m_ic.t4props_, m_locale, "end_transaction_message_error",
+			SQLException se = TrafT4Messages.createSQLException(m_ic.t4props_, m_locale, "end_transaction_message_error",
 					e.getMessage());
 
 			se.initCause(e);
@@ -483,17 +483,17 @@ class T4Connection {
 		catch (SQLException se) {
 			throw se;
 		} catch (CharacterCodingException e) {
-			SQLException se = HPT4Messages.createSQLException(m_ic.t4props_, m_locale,
+			SQLException se = TrafT4Messages.createSQLException(m_ic.t4props_, m_locale,
 					"translation_of_parameter_failed", "GetSQLCatalogsMessage", e.getMessage());
 			se.initCause(e);
 			throw se;
 		} catch (UnsupportedCharsetException e) {
-			SQLException se = HPT4Messages.createSQLException(m_ic.t4props_, m_locale, "unsupported_encoding", e
+			SQLException se = TrafT4Messages.createSQLException(m_ic.t4props_, m_locale, "unsupported_encoding", e
 					.getCharsetName());
 			se.initCause(e);
 			throw se;
 		} catch (Exception e) {
-			SQLException se = HPT4Messages.createSQLException(m_ic.t4props_, m_locale,
+			SQLException se = TrafT4Messages.createSQLException(m_ic.t4props_, m_locale,
 					"get_sql_catalogs_message_error", e.getMessage());
 
 			se.initCause(e);

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/38e49cf7/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/T4DSProperties.java
----------------------------------------------------------------------
diff --git a/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/T4DSProperties.java b/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/T4DSProperties.java
index a44d0f3..c16ab8e 100644
--- a/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/T4DSProperties.java
+++ b/core/conn/jdbcT4/src/main/java/org/trafodion/jdbc/t4/T4DSProperties.java
@@ -33,8 +33,8 @@ import java.util.logging.Level;
  * <p>
  * Description: The <code>T4DSProperties</code> class contains all the
  * properties associated with Type 4 data source connection.
- * <code>T4DSProperties</code> is inherited by the <code>HPT4DataSource,
- * HPT4ConnectionPooledDataSource</code>
+ * <code>T4DSProperties</code> is inherited by the <code>TrafT4DataSource,
+ * TrafT4ConnectionPooledDataSource</code>
  * classes for configuring Type 4 connection properties.
  * <p>
  * The properties passed to the Type 4 driver have this precedence order in
@@ -157,7 +157,7 @@ public class T4DSProperties extends T4Properties {
 	 * Gets the default catalog that will be used to access SQL objects
 	 * referenced in SQL statements if the SQL objects are not fully qualified.
 	 * 
-	 * @return HPT4 catalog name.
+	 * @return TrafT4 catalog name.
 	 * @see #setCatalog(String)
 	 */
 	public String getCatalog() {