You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by cl...@apache.org on 2018/08/28 15:28:28 UTC

[2/3] activemq-artemis git commit: ARTEMIS-2051 add trace logging for JDBC

ARTEMIS-2051 add trace logging for JDBC

Activate by enabling TRACE logging for:
org.apache.activemq.artemis.jdbc.store.drivers.AbstractJDBCDriver
This doesn't log *all* JDBC operations, just those that are used by the
JDBC store.


Project: http://git-wip-us.apache.org/repos/asf/activemq-artemis/repo
Commit: http://git-wip-us.apache.org/repos/asf/activemq-artemis/commit/41b094df
Tree: http://git-wip-us.apache.org/repos/asf/activemq-artemis/tree/41b094df
Diff: http://git-wip-us.apache.org/repos/asf/activemq-artemis/diff/41b094df

Branch: refs/heads/master
Commit: 41b094df2bf564631c53f5dcbfeb4c2b1e815747
Parents: a8dad35
Author: Justin Bertram <jb...@apache.org>
Authored: Wed Aug 22 22:10:37 2018 -0500
Committer: Clebert Suconic <cl...@apache.org>
Committed: Tue Aug 28 11:28:18 2018 -0400

----------------------------------------------------------------------
 .../jdbc/store/drivers/AbstractJDBCDriver.java  |   23 +-
 .../jdbc/store/logging/LoggingConnection.java   |  436 ++++++
 .../store/logging/LoggingPreparedStatement.java |  406 ++++++
 .../jdbc/store/logging/LoggingResultSet.java    | 1338 ++++++++++++++++++
 .../jdbc/store/logging/LoggingStatement.java    |  400 ++++++
 .../artemis/jdbc/store/logging/LoggingUtil.java |   24 +
 6 files changed, 2625 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/41b094df/artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/drivers/AbstractJDBCDriver.java
----------------------------------------------------------------------
diff --git a/artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/drivers/AbstractJDBCDriver.java b/artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/drivers/AbstractJDBCDriver.java
index 262cf2e..ceb0967 100644
--- a/artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/drivers/AbstractJDBCDriver.java
+++ b/artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/drivers/AbstractJDBCDriver.java
@@ -30,6 +30,7 @@ import java.util.concurrent.Executor;
 import java.util.stream.Collectors;
 import java.util.stream.Stream;
 
+import org.apache.activemq.artemis.jdbc.store.logging.LoggingConnection;
 import org.apache.activemq.artemis.jdbc.store.sql.SQLProvider;
 import org.apache.activemq.artemis.journal.ActiveMQJournalLogger;
 import org.jboss.logging.Logger;
@@ -85,7 +86,11 @@ public abstract class AbstractJDBCDriver {
    }
 
    public AbstractJDBCDriver(Connection connection, SQLProvider sqlProvider) {
-      this.connection = connection;
+      if (logger.isTraceEnabled() && !(connection instanceof LoggingConnection)) {
+         this.connection = new LoggingConnection(connection, logger);
+      } else {
+         this.connection = connection;
+      }
       this.sqlProvider = sqlProvider;
       this.networkTimeoutExecutor = null;
       this.networkTimeoutMillis = -1;
@@ -118,6 +123,11 @@ public abstract class AbstractJDBCDriver {
          if (dataSource != null) {
             try {
                connection = dataSource.getConnection();
+
+               if (logger.isTraceEnabled() && !(connection instanceof LoggingConnection)) {
+                  this.connection = new LoggingConnection(connection, logger);
+               }
+
             } catch (SQLException e) {
                logger.error(JDBCUtils.appendSQLExceptionDetails(new StringBuilder(), e));
                throw e;
@@ -132,6 +142,11 @@ public abstract class AbstractJDBCDriver {
                }
                final Driver dbDriver = getDriver(jdbcDriverClass);
                connection = dbDriver.connect(jdbcConnectionUrl, new Properties());
+
+               if (logger.isTraceEnabled() && !(connection instanceof LoggingConnection)) {
+                  this.connection = new LoggingConnection(connection, logger);
+               }
+
                if (connection == null) {
                   throw new IllegalStateException("the driver: " + jdbcDriverClass + " isn't able to connect to the requested url: " + jdbcConnectionUrl);
                }
@@ -293,7 +308,11 @@ public abstract class AbstractJDBCDriver {
 
    public final void setConnection(Connection connection) {
       if (this.connection == null) {
-         this.connection = connection;
+         if (logger.isTraceEnabled() && !(connection instanceof LoggingConnection)) {
+            this.connection = new LoggingConnection(connection, logger);
+         } else {
+            this.connection = connection;
+         }
       }
    }
 

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/41b094df/artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/logging/LoggingConnection.java
----------------------------------------------------------------------
diff --git a/artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/logging/LoggingConnection.java b/artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/logging/LoggingConnection.java
new file mode 100644
index 0000000..8a9284a
--- /dev/null
+++ b/artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/logging/LoggingConnection.java
@@ -0,0 +1,436 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements. See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License. You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.activemq.artemis.jdbc.store.logging;
+
+import java.sql.Array;
+import java.sql.Blob;
+import java.sql.CallableStatement;
+import java.sql.Clob;
+import java.sql.Connection;
+import java.sql.DatabaseMetaData;
+import java.sql.NClob;
+import java.sql.PreparedStatement;
+import java.sql.SQLClientInfoException;
+import java.sql.SQLException;
+import java.sql.SQLWarning;
+import java.sql.SQLXML;
+import java.sql.Savepoint;
+import java.sql.Statement;
+import java.sql.Struct;
+import java.util.Arrays;
+import java.util.Map;
+import java.util.Properties;
+import java.util.concurrent.Executor;
+
+import org.jboss.logging.Logger;
+
+public class LoggingConnection implements Connection {
+
+   private final Connection connection;
+
+   private final String connectionID;
+
+   private Logger logger;
+
+   private Logger.Level level = Logger.Level.TRACE;
+
+   public LoggingConnection(Connection connection, Logger logger) {
+      this.connection = connection;
+      this.logger = logger;
+      this.connectionID = LoggingUtil.getID(connection);
+   }
+
+   public Connection getConnection() {
+      return connection;
+   }
+
+   public String getConnectionID() {
+      return connectionID;
+   }
+
+   @Override
+   public Statement createStatement() throws SQLException {
+      LoggingStatement statement = new LoggingStatement(connection.createStatement(), logger);
+      logger.logf(level, "%s.createStatement() = %s", connectionID, statement.getStatementID());
+      return statement;
+   }
+
+   @Override
+   public PreparedStatement prepareStatement(String sql) throws SQLException {
+      LoggingPreparedStatement statement = new LoggingPreparedStatement(connection.prepareStatement(sql), logger);
+      logger.logf(level, "%s.prepareStatement(%s) = %s", connectionID, sql, statement.getStatementID());
+      return statement;
+   }
+
+   @Override
+   public CallableStatement prepareCall(String sql) throws SQLException {
+      CallableStatement statement = connection.prepareCall(sql);
+      logger.logf(level, "%s.prepareCall(%s) = %s", connectionID, sql, LoggingUtil.getID(statement));
+      return statement;
+   }
+
+   @Override
+   public String nativeSQL(String sql) throws SQLException {
+      String x = connection.nativeSQL(sql);
+      logger.logf(level, "%s.nativeSQL(%s) = %s", connectionID, sql, x);
+      return x;
+   }
+
+   @Override
+   public void setAutoCommit(boolean autoCommit) throws SQLException {
+      logger.logf(level, "%s.setAutoCommit(%s)", connectionID, autoCommit);
+      connection.setAutoCommit(autoCommit);
+   }
+
+   @Override
+   public boolean getAutoCommit() throws SQLException {
+      boolean x = connection.getAutoCommit();
+      logger.logf(level, "%s.getAutoCommit() = %s", connectionID, x);
+      return x;
+   }
+
+   @Override
+   public void commit() throws SQLException {
+      logger.logf(level, "%s.commit()", connectionID);
+      connection.commit();
+   }
+
+   @Override
+   public void rollback() throws SQLException {
+      logger.logf(level, "%s.rollback()", connectionID);
+      connection.rollback();
+   }
+
+   @Override
+   public void close() throws SQLException {
+      logger.logf(level, "%s.close()", connectionID);
+      connection.close();
+   }
+
+   @Override
+   public boolean isClosed() throws SQLException {
+      boolean x = connection.isClosed();
+      logger.logf(level, "%s.isClosed() = %s", connectionID, x);
+      return x;
+   }
+
+   @Override
+   public DatabaseMetaData getMetaData() throws SQLException {
+      DatabaseMetaData x = connection.getMetaData();
+      logger.logf(level, "%s.getMetaData() = %s", connectionID, x);
+      return x;
+   }
+
+   @Override
+   public void setReadOnly(boolean readOnly) throws SQLException {
+      logger.logf(level, "%s.setReadOnly(%s)", connectionID, readOnly);
+      connection.setReadOnly(readOnly);
+   }
+
+   @Override
+   public boolean isReadOnly() throws SQLException {
+      boolean x = connection.isReadOnly();
+      logger.logf(level, "%s.isReadOnly() = %s", connectionID, x);
+      return x;
+   }
+
+   @Override
+   public void setCatalog(String catalog) throws SQLException {
+      logger.logf(level, "%s.setCatalog(%s)", connectionID, catalog);
+      connection.setCatalog(catalog);
+   }
+
+   @Override
+   public String getCatalog() throws SQLException {
+      String x = connection.getCatalog();
+      logger.logf(level, "%s.getCatalog() = %s", connectionID, x);
+      return x;
+   }
+
+   @Override
+   public void setTransactionIsolation(int level) throws SQLException {
+      logger.logf(this.level, "%s.setTransactionIsolation(%s)", connectionID, level);
+      connection.setTransactionIsolation(level);
+   }
+
+   @Override
+   public int getTransactionIsolation() throws SQLException {
+      int x = connection.getTransactionIsolation();
+      logger.logf(level, "%s.getTransactionIsolation() = %s", connectionID, x);
+      return x;
+   }
+
+   @Override
+   public SQLWarning getWarnings() throws SQLException {
+      SQLWarning x = connection.getWarnings();
+      logger.logf(level, "%s.getWarnings() = %s", connectionID, x);
+      return x;
+   }
+
+   @Override
+   public void clearWarnings() throws SQLException {
+      logger.logf(level, "%s.clearWarnings()", connectionID);
+      connection.clearWarnings();
+   }
+
+   @Override
+   public Statement createStatement(int resultSetType, int resultSetConcurrency) throws SQLException {
+      LoggingStatement statement = new LoggingStatement(connection.createStatement(resultSetType, resultSetConcurrency), logger);
+      logger.logf(level, "%s.createStatement(%s, %s) = %s", connectionID, resultSetType, resultSetConcurrency, statement.getStatementID());
+      return statement;
+   }
+
+   @Override
+   public PreparedStatement prepareStatement(String sql,
+                                             int resultSetType,
+                                             int resultSetConcurrency) throws SQLException {
+      LoggingPreparedStatement statement = new LoggingPreparedStatement(connection.prepareStatement(sql, resultSetType, resultSetConcurrency), logger);
+      logger.logf(level, "%s.prepareStatement(%s, %s, %s) = %s", connectionID, sql, resultSetType, resultSetConcurrency, statement.getStatementID());
+      return statement;
+   }
+
+   @Override
+   public CallableStatement prepareCall(String sql, int resultSetType, int resultSetConcurrency) throws SQLException {
+      CallableStatement statement = connection.prepareCall(sql, resultSetType, resultSetConcurrency);
+      logger.logf(level, "%s.createStatement(%s, %s) = %s", connectionID, sql, resultSetType, resultSetConcurrency, LoggingUtil.getID(statement));
+      return statement;
+   }
+
+   @Override
+   public Map<String, Class<?>> getTypeMap() throws SQLException {
+      Map<String, Class<?>> x = connection.getTypeMap();
+      logger.logf(level, "%s.getTypeMap() = %s", connectionID, x);
+      return x;
+   }
+
+   @Override
+   public void setTypeMap(Map<String, Class<?>> map) throws SQLException {
+      logger.logf(level, "%s.setTypeMap(%s)", connectionID, map);
+      connection.setTypeMap(map);
+   }
+
+   @Override
+   public void setHoldability(int holdability) throws SQLException {
+      logger.logf(level, "%s.setHoldability(%s)", connectionID, holdability);
+      connection.setHoldability(holdability);
+   }
+
+   @Override
+   public int getHoldability() throws SQLException {
+      int x = connection.getHoldability();
+      logger.logf(level, "%s.getHoldability() = %s", connectionID, x);
+      return x;
+   }
+
+   @Override
+   public Savepoint setSavepoint() throws SQLException {
+      Savepoint x = connection.setSavepoint();
+      logger.logf(level, "%s.setSavepoint() = %s", connectionID, x);
+      return x;
+   }
+
+   @Override
+   public Savepoint setSavepoint(String name) throws SQLException {
+      Savepoint x = connection.setSavepoint(name);
+      logger.logf(level, "%s.setSavepoint(%s) = %s", connectionID, name, x);
+      return x;
+   }
+
+   @Override
+   public void rollback(Savepoint savepoint) throws SQLException {
+      logger.logf(level, "%s.rollback(%s)", connectionID, savepoint);
+      connection.rollback(savepoint);
+   }
+
+   @Override
+   public void releaseSavepoint(Savepoint savepoint) throws SQLException {
+      logger.logf(level, "%s.releaseSavepoint(%s)", connectionID, savepoint);
+      connection.releaseSavepoint(savepoint);
+   }
+
+   @Override
+   public Statement createStatement(int resultSetType,
+                                    int resultSetConcurrency,
+                                    int resultSetHoldability) throws SQLException {
+      LoggingStatement statement = new LoggingStatement(connection.createStatement(resultSetType, resultSetConcurrency, resultSetHoldability), logger);
+      logger.logf(level, "%s.createStatement(%s, %s, %s) = %s", connectionID, resultSetType, resultSetConcurrency, resultSetHoldability, statement.getStatementID());
+      return statement;
+   }
+
+   @Override
+   public PreparedStatement prepareStatement(String sql,
+                                             int resultSetType,
+                                             int resultSetConcurrency,
+                                             int resultSetHoldability) throws SQLException {
+      LoggingPreparedStatement statement = new LoggingPreparedStatement(connection.prepareStatement(sql, resultSetType, resultSetConcurrency, resultSetHoldability), logger);
+      logger.logf(level, "%s.prepareStatement(%s, %s, %s, %s) = %s", connectionID, sql, resultSetType, resultSetConcurrency, resultSetHoldability, statement.getStatementID());
+      return statement;
+   }
+
+   @Override
+   public CallableStatement prepareCall(String sql,
+                                        int resultSetType,
+                                        int resultSetConcurrency,
+                                        int resultSetHoldability) throws SQLException {
+      CallableStatement statement = connection.prepareCall(sql, resultSetType, resultSetConcurrency, resultSetHoldability);
+      logger.logf(level, "%s.prepareCall(%s, %s, %s, %s) = %s", connectionID, sql, resultSetType, resultSetConcurrency, resultSetHoldability, LoggingUtil.getID(statement));
+      return statement;
+   }
+
+   @Override
+   public PreparedStatement prepareStatement(String sql, int autoGeneratedKeys) throws SQLException {
+      LoggingPreparedStatement preparedStatement = new LoggingPreparedStatement(connection.prepareStatement(sql, autoGeneratedKeys), logger);
+      logger.logf(level, "%s.prepareStatement(%s, %s) = %s", connectionID, sql, autoGeneratedKeys, preparedStatement.getStatementID());
+      return preparedStatement;
+   }
+
+   @Override
+   public PreparedStatement prepareStatement(String sql, int[] columnIndexes) throws SQLException {
+      LoggingPreparedStatement statement = new LoggingPreparedStatement(connection.prepareStatement(sql, columnIndexes), logger);
+      logger.logf(level, "%s.prepareStatement(%s, %s) = %s", connectionID, sql, Arrays.toString(columnIndexes), statement.getStatementID());
+      return statement;
+   }
+
+   @Override
+   public PreparedStatement prepareStatement(String sql, String[] columnNames) throws SQLException {
+      LoggingPreparedStatement statement = new LoggingPreparedStatement(connection.prepareStatement(sql, columnNames), logger);
+      logger.logf(level, "%s.prepareStatement(%s, %s) = %s", connectionID, sql, Arrays.toString(columnNames), statement.getStatementID());
+      return statement;
+   }
+
+   @Override
+   public Clob createClob() throws SQLException {
+      Clob x = connection.createClob();
+      logger.logf(level, "%s.createClob() = %s", connectionID, x);
+      return x;
+   }
+
+   @Override
+   public Blob createBlob() throws SQLException {
+      Blob x = connection.createBlob();
+      logger.logf(level, "%s.createBlob() = %s", connectionID, x);
+      return x;
+   }
+
+   @Override
+   public NClob createNClob() throws SQLException {
+      NClob x = connection.createNClob();
+      logger.logf(level, "%s.createNClob() = %s", connectionID, x);
+      return x;
+   }
+
+   @Override
+   public SQLXML createSQLXML() throws SQLException {
+      SQLXML x = connection.createSQLXML();
+      logger.logf(level, "%s.createSQLXML() = %s", connectionID, x);
+      return x;
+   }
+
+   @Override
+   public boolean isValid(int timeout) throws SQLException {
+      boolean x = connection.isValid(timeout);
+      logger.logf(level, "%s.isValid(%s) = %s", connectionID, timeout, x);
+      return x;
+   }
+
+   @Override
+   public void setClientInfo(String name, String value) throws SQLClientInfoException {
+      logger.logf(level, "%s.setClientInfo(%s, %s)", connectionID, name, value);
+      connection.setClientInfo(name, value);
+   }
+
+   @Override
+   public void setClientInfo(Properties properties) throws SQLClientInfoException {
+      logger.logf(level, "%s.setClientInfo(%s)", connectionID, properties);
+      connection.setClientInfo(properties);
+   }
+
+   @Override
+   public String getClientInfo(String name) throws SQLException {
+      String x = connection.getClientInfo(name);
+      logger.logf(level, "%s.getClientInfo(%s) = %s", connectionID, name, x);
+      return x;
+   }
+
+   @Override
+   public Properties getClientInfo() throws SQLException {
+      Properties x = connection.getClientInfo();
+      logger.logf(level, "%s.getClientInfo() = %s", connectionID, x);
+      return x;
+   }
+
+   @Override
+   public Array createArrayOf(String typeName, Object[] elements) throws SQLException {
+      Array x = connection.createArrayOf(typeName, elements);
+      logger.logf(level, "%s.createArrayOf(%s, %s) = %s", connectionID, typeName, Arrays.toString(elements), x);
+      return x;
+   }
+
+   @Override
+   public Struct createStruct(String typeName, Object[] attributes) throws SQLException {
+      Struct x = connection.createStruct(typeName, attributes);
+      logger.logf(level, "%s.createStruct(%s, %s) = %s", connectionID, typeName, Arrays.toString(attributes), x);
+      return x;
+   }
+
+   @Override
+   public void setSchema(String schema) throws SQLException {
+      logger.logf(level, "%s.setSchema(%s)", connectionID, schema);
+      connection.setSchema(schema);
+   }
+
+   @Override
+   public String getSchema() throws SQLException {
+      String x = connection.getSchema();
+      logger.logf(level, "%s.getSchema() = %s", connectionID, x);
+      return x;
+   }
+
+   @Override
+   public void abort(Executor executor) throws SQLException {
+      logger.logf(level, "%s.abort(%s)", connectionID, executor);
+      connection.abort(executor);
+   }
+
+   @Override
+   public void setNetworkTimeout(Executor executor, int milliseconds) throws SQLException {
+      logger.logf(level, "%s.setNetworkTimeout(%s, %d)", connectionID, executor, milliseconds);
+      connection.setNetworkTimeout(executor, milliseconds);
+   }
+
+   @Override
+   public int getNetworkTimeout() throws SQLException {
+      int x = connection.getNetworkTimeout();
+      logger.logf(level, "%s.getNetworkTimeout() = %s", connectionID, x);
+      return x;
+   }
+
+   @Override
+   public <T> T unwrap(Class<T> iface) throws SQLException {
+      T x = connection.unwrap(iface);
+      logger.logf(level, "%s.unwrap(%s) = %s", connectionID, iface, x);
+      return x;
+   }
+
+   @Override
+   public boolean isWrapperFor(Class<?> iface) throws SQLException {
+      boolean x = connection.isWrapperFor(iface);
+      logger.logf(level, "%s.isWrapperFor() = %s", connectionID, iface, x);
+      return x;
+   }
+}

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/41b094df/artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/logging/LoggingPreparedStatement.java
----------------------------------------------------------------------
diff --git a/artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/logging/LoggingPreparedStatement.java b/artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/logging/LoggingPreparedStatement.java
new file mode 100644
index 0000000..4cf270d
--- /dev/null
+++ b/artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/logging/LoggingPreparedStatement.java
@@ -0,0 +1,406 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements. See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License. You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.activemq.artemis.jdbc.store.logging;
+
+import java.io.InputStream;
+import java.io.Reader;
+import java.math.BigDecimal;
+import java.net.URL;
+import java.sql.Array;
+import java.sql.Blob;
+import java.sql.Clob;
+import java.sql.Date;
+import java.sql.NClob;
+import java.sql.ParameterMetaData;
+import java.sql.PreparedStatement;
+import java.sql.Ref;
+import java.sql.ResultSet;
+import java.sql.ResultSetMetaData;
+import java.sql.RowId;
+import java.sql.SQLException;
+import java.sql.SQLType;
+import java.sql.SQLXML;
+import java.sql.Time;
+import java.sql.Timestamp;
+import java.util.Calendar;
+
+import org.jboss.logging.Logger;
+
+public class LoggingPreparedStatement extends LoggingStatement implements PreparedStatement {
+
+   private final PreparedStatement preparedStatement;
+
+   public LoggingPreparedStatement(PreparedStatement preparedStatement, Logger logger) {
+      super(preparedStatement, logger);
+      this.preparedStatement = preparedStatement;
+   }
+
+   @Override
+   public ResultSet executeQuery() throws SQLException {
+      LoggingResultSet rs = new LoggingResultSet(preparedStatement.executeQuery(), logger);
+      logger.logf(level, "%s.executeQuery() = %s", statementID, rs.getResultSetID());
+      return rs;
+   }
+
+   @Override
+   public int executeUpdate() throws SQLException {
+      int i = preparedStatement.executeUpdate();
+      logger.logf(level, "%s.executeUpdate() = %s", statementID, i);
+      return i;
+   }
+
+   @Override
+   public void setNull(int parameterIndex, int sqlType) throws SQLException {
+      logger.logf(level, "%s.setNull(%d, %d)", statementID, parameterIndex, sqlType);
+      preparedStatement.setNull(parameterIndex, sqlType);
+   }
+
+   @Override
+   public void setBoolean(int parameterIndex, boolean x) throws SQLException {
+      logger.logf(level, "%s.setBoolean(%d, %s)", statementID, parameterIndex, x);
+      preparedStatement.setBoolean(parameterIndex, x);
+   }
+
+   @Override
+   public void setByte(int parameterIndex, byte x) throws SQLException {
+      logger.logf(level, "%s.setByte(%d, %s)", statementID, parameterIndex, x);
+      preparedStatement.setByte(parameterIndex, x);
+   }
+
+   @Override
+   public void setShort(int parameterIndex, short x) throws SQLException {
+      logger.logf(level, "%s.setShort(%d, %d)", statementID, parameterIndex, x);
+      preparedStatement.setShort(parameterIndex, x);
+   }
+
+   @Override
+   public void setInt(int parameterIndex, int x) throws SQLException {
+      logger.logf(level, "%s.setInt(%d, %d)", statementID, parameterIndex, x);
+      preparedStatement.setInt(parameterIndex, x);
+   }
+
+   @Override
+   public void setLong(int parameterIndex, long x) throws SQLException {
+      logger.logf(level, "%s.setLong(%d, %s)", statementID, parameterIndex, x);
+      preparedStatement.setLong(parameterIndex, x);
+   }
+
+   @Override
+   public void setFloat(int parameterIndex, float x) throws SQLException {
+      logger.logf(level, "%s.setFloat(%d, %f)", statementID, parameterIndex, x);
+      preparedStatement.setFloat(parameterIndex, x);
+   }
+
+   @Override
+   public void setDouble(int parameterIndex, double x) throws SQLException {
+      logger.logf(level, "%s.setDouble(%d, %d)", statementID, parameterIndex, x);
+      preparedStatement.setDouble(parameterIndex, x);
+   }
+
+   @Override
+   public void setBigDecimal(int parameterIndex, BigDecimal x) throws SQLException {
+      logger.logf(level, "%s.setBigDecimal(%d, %s)", statementID, parameterIndex, x);
+      preparedStatement.setBigDecimal(parameterIndex, x);
+   }
+
+   @Override
+   public void setString(int parameterIndex, String x) throws SQLException {
+      logger.logf(level, "%s.setString(%d, %s)", statementID, parameterIndex, x);
+      preparedStatement.setString(parameterIndex, x);
+   }
+
+   @Override
+   public void setBytes(int parameterIndex, byte[] x) throws SQLException {
+      logger.logf(level, "%s.setBytes(%d, %s)", statementID, parameterIndex, x);
+      preparedStatement.setBytes(parameterIndex, x);
+   }
+
+   @Override
+   public void setDate(int parameterIndex, Date x) throws SQLException {
+      logger.logf(level, "%s.setDate(%d, %s)", statementID, parameterIndex, x);
+      preparedStatement.setDate(parameterIndex, x);
+   }
+
+   @Override
+   public void setTime(int parameterIndex, Time x) throws SQLException {
+      logger.logf(level, "%s.setTime(%d, %s)", statementID, parameterIndex, x);
+      preparedStatement.setTime(parameterIndex, x);
+   }
+
+   @Override
+   public void setTimestamp(int parameterIndex, Timestamp x) throws SQLException {
+      logger.logf(level, "%s.setTimestamp(%d, %s)", statementID, parameterIndex, x);
+      preparedStatement.setTimestamp(parameterIndex, x);
+   }
+
+   @Override
+   public void setAsciiStream(int parameterIndex, InputStream x, int length) throws SQLException {
+      logger.logf(level, "%s.setAsciiStream(%d, %s, %d)", statementID, parameterIndex, x, length);
+      preparedStatement.setAsciiStream(parameterIndex, x, length);
+   }
+
+   @Override
+   public void setUnicodeStream(int parameterIndex, InputStream x, int length) throws SQLException {
+      logger.logf(level, "%s.setUnicodeStream(%d, %s, %d)", statementID, parameterIndex, x, length);
+      preparedStatement.setUnicodeStream(parameterIndex, x, length);
+   }
+
+   @Override
+   public void setBinaryStream(int parameterIndex, InputStream x, int length) throws SQLException {
+      logger.logf(level, "%s.setBinaryStream(%d, %s, %d)", statementID, parameterIndex, x, length);
+      preparedStatement.setBinaryStream(parameterIndex, x, length);
+   }
+
+   @Override
+   public void clearParameters() throws SQLException {
+      logger.logf(level, "%s.clearParameters()", statementID);
+      preparedStatement.clearParameters();
+   }
+
+   @Override
+   public void setObject(int parameterIndex, Object x, int targetSqlType) throws SQLException {
+      logger.logf(level, "%s.setObject(%d, %s, %d)", statementID, parameterIndex, x, targetSqlType);
+      preparedStatement.setObject(parameterIndex, x, targetSqlType);
+   }
+
+   @Override
+   public void setObject(int parameterIndex, Object x) throws SQLException {
+      logger.logf(level, "%s.setObject(%d, %s)", statementID, parameterIndex, x);
+      preparedStatement.setObject(parameterIndex, x);
+   }
+
+   @Override
+   public boolean execute() throws SQLException {
+      boolean b = preparedStatement.execute();
+      logger.logf(level, "%s.execute() = %s", statementID, b);
+      return b;
+   }
+
+   @Override
+   public void addBatch() throws SQLException {
+      logger.logf(level, "%s.addBatch()", statementID);
+      preparedStatement.addBatch();
+   }
+
+   @Override
+   public void setCharacterStream(int parameterIndex, Reader reader, int length) throws SQLException {
+      logger.logf(level, "%s.setCharacterStream(%d, %s, %d)", statementID, parameterIndex, reader, length);
+      preparedStatement.setCharacterStream(parameterIndex, reader, length);
+   }
+
+   @Override
+   public void setRef(int parameterIndex, Ref x) throws SQLException {
+      logger.logf(level, "%s.setRef(%d, %s)", statementID, parameterIndex, x);
+      preparedStatement.setRef(parameterIndex, x);
+   }
+
+   @Override
+   public void setBlob(int parameterIndex, Blob x) throws SQLException {
+      logger.logf(level, "%s.setBlob(%d, %s)", statementID, parameterIndex, x);
+      preparedStatement.setBlob(parameterIndex, x);
+   }
+
+   @Override
+   public void setClob(int parameterIndex, Clob x) throws SQLException {
+      logger.logf(level, "%s.setClob(%d, %x)", statementID, parameterIndex, x);
+      preparedStatement.setClob(parameterIndex, x);
+   }
+
+   @Override
+   public void setArray(int parameterIndex, Array x) throws SQLException {
+      logger.logf(level, "%s.setArray(%d, %s)", statementID, parameterIndex, x);
+      preparedStatement.setArray(parameterIndex, x);
+   }
+
+   @Override
+   public ResultSetMetaData getMetaData() throws SQLException {
+      ResultSetMetaData resultSetMetaData = preparedStatement.getMetaData();
+      logger.logf(level, "%s.getMetaData() = %s", statementID, LoggingUtil.getID(resultSetMetaData));
+      return resultSetMetaData;
+   }
+
+   @Override
+   public void setDate(int parameterIndex, Date x, Calendar cal) throws SQLException {
+      logger.logf(level, "%s.setDate(%d, %s, %s)", statementID, parameterIndex, x, cal);
+      preparedStatement.setDate(parameterIndex, x, cal);
+   }
+
+   @Override
+   public void setTime(int parameterIndex, Time x, Calendar cal) throws SQLException {
+      logger.logf(level, "%s.setTime(%d, %s, %s)", statementID, parameterIndex, x, cal);
+      preparedStatement.setTime(parameterIndex, x, cal);
+   }
+
+   @Override
+   public void setTimestamp(int parameterIndex, Timestamp x, Calendar cal) throws SQLException {
+      logger.logf(level, "%s.setTimestamp(%d, %s, %s)", statementID, parameterIndex, x, cal);
+      preparedStatement.setTimestamp(parameterIndex, x, cal);
+   }
+
+   @Override
+   public void setNull(int parameterIndex, int sqlType, String typeName) throws SQLException {
+      logger.logf(level, "%s.setNull(%d, %d, %s)", statementID, parameterIndex, sqlType, typeName);
+      preparedStatement.setNull(parameterIndex, sqlType, typeName);
+   }
+
+   @Override
+   public void setURL(int parameterIndex, URL x) throws SQLException {
+      logger.logf(level, "%s.setURL(%d, %s)", statementID, parameterIndex, x);
+      preparedStatement.setURL(parameterIndex, x);
+   }
+
+   @Override
+   public ParameterMetaData getParameterMetaData() throws SQLException {
+      ParameterMetaData x = preparedStatement.getParameterMetaData();
+      logger.logf(level, "%s.getParameterMetaData() = %s", statementID, x);
+      return x;
+   }
+
+   @Override
+   public void setRowId(int parameterIndex, RowId x) throws SQLException {
+      logger.logf(level, "%s.setRowId(%d, %s)", statementID, parameterIndex, x);
+      preparedStatement.setRowId(parameterIndex, x);
+   }
+
+   @Override
+   public void setNString(int parameterIndex, String value) throws SQLException {
+      logger.logf(level, "%s.setNString(%d, %s)", statementID, parameterIndex, value);
+      preparedStatement.setNString(parameterIndex, value);
+   }
+
+   @Override
+   public void setNCharacterStream(int parameterIndex, Reader value, long length) throws SQLException {
+      logger.logf(level, "%s.setNCharacterStream(%d, %s, %d)", statementID, parameterIndex, value, length);
+      preparedStatement.setNCharacterStream(parameterIndex, value, length);
+   }
+
+   @Override
+   public void setNClob(int parameterIndex, NClob value) throws SQLException {
+      logger.logf(level, "%s.setNClob(%d, %s)", statementID, parameterIndex, value);
+      preparedStatement.setNClob(parameterIndex, value);
+   }
+
+   @Override
+   public void setClob(int parameterIndex, Reader reader, long length) throws SQLException {
+      logger.logf(level, "%s.setClob(%d, %s, %s)", statementID, parameterIndex, reader, length);
+      preparedStatement.setClob(parameterIndex, reader, length);
+   }
+
+   @Override
+   public void setBlob(int parameterIndex, InputStream inputStream, long length) throws SQLException {
+      logger.logf(level, "%s.setBlob(%d, %s, %d)", statementID, parameterIndex, inputStream, length);
+      preparedStatement.setBlob(parameterIndex, inputStream, length);
+   }
+
+   @Override
+   public void setNClob(int parameterIndex, Reader reader, long length) throws SQLException {
+      logger.logf(level, "%s.setNClob(%d, %s, %d)", statementID, parameterIndex, reader, length);
+      preparedStatement.setNClob(parameterIndex, reader, length);
+   }
+
+   @Override
+   public void setSQLXML(int parameterIndex, SQLXML xmlObject) throws SQLException {
+      logger.logf(level, "%s.setSQLXML(%d, %s)", statementID, parameterIndex, xmlObject);
+      preparedStatement.setSQLXML(parameterIndex, xmlObject);
+   }
+
+   @Override
+   public void setObject(int parameterIndex, Object x, int targetSqlType, int scaleOrLength) throws SQLException {
+      logger.logf(level, "%s.setNull(%d, %d)", statementID, parameterIndex, x);
+      preparedStatement.setObject(parameterIndex, x, targetSqlType, scaleOrLength);
+   }
+
+   @Override
+   public void setAsciiStream(int parameterIndex, InputStream x, long length) throws SQLException {
+      logger.logf(level, "%s.setNull(%d, %d)", statementID, parameterIndex, x);
+      preparedStatement.setAsciiStream(parameterIndex, x, length);
+   }
+
+   @Override
+   public void setBinaryStream(int parameterIndex, InputStream x, long length) throws SQLException {
+      logger.logf(level, "%s.setNull(%d, %d)", statementID, parameterIndex, x);
+      preparedStatement.setBinaryStream(parameterIndex, x, length);
+   }
+
+   @Override
+   public void setCharacterStream(int parameterIndex, Reader reader, long length) throws SQLException {
+      logger.logf(level, "%s.setCharacterStream(%d, %s, %d)", statementID, parameterIndex, reader, length);
+      preparedStatement.setCharacterStream(parameterIndex, reader, length);
+   }
+
+   @Override
+   public void setAsciiStream(int parameterIndex, InputStream x) throws SQLException {
+      logger.logf(level, "%s.setAsciiStream(%d, %d)", statementID, parameterIndex, x);
+      preparedStatement.setAsciiStream(parameterIndex, x);
+   }
+
+   @Override
+   public void setBinaryStream(int parameterIndex, InputStream x) throws SQLException {
+      logger.logf(level, "%s.setBinaryStream(%d, %s)", statementID, parameterIndex, x);
+      preparedStatement.setBinaryStream(parameterIndex, x);
+   }
+
+   @Override
+   public void setCharacterStream(int parameterIndex, Reader reader) throws SQLException {
+      logger.logf(level, "%s.setCharacterStream(%d, %s)", statementID, parameterIndex, reader);
+      preparedStatement.setCharacterStream(parameterIndex, reader);
+   }
+
+   @Override
+   public void setNCharacterStream(int parameterIndex, Reader value) throws SQLException {
+      logger.logf(level, "%s.setNCharacterStream(%d, %s)", statementID, parameterIndex, value);
+      preparedStatement.setNCharacterStream(parameterIndex, value);
+   }
+
+   @Override
+   public void setClob(int parameterIndex, Reader reader) throws SQLException {
+      logger.logf(level, "%s.setClob(%d, %s)", statementID, parameterIndex, reader);
+      preparedStatement.setClob(parameterIndex, reader);
+   }
+
+   @Override
+   public void setBlob(int parameterIndex, InputStream inputStream) throws SQLException {
+      logger.logf(level, "%s.setBlob(%d, %s)", statementID, parameterIndex, inputStream);
+      preparedStatement.setBlob(parameterIndex, inputStream);
+   }
+
+   @Override
+   public void setNClob(int parameterIndex, Reader reader) throws SQLException {
+      logger.logf(level, "%s.setNClob(%d, %s)", statementID, parameterIndex, reader);
+      preparedStatement.setNClob(parameterIndex, reader);
+   }
+
+   @Override
+   public void setObject(int parameterIndex, Object x, SQLType targetSqlType, int scaleOrLength) throws SQLException {
+      logger.logf(level, "%s.setObject(%d, %s, %s, %d)", statementID, parameterIndex, x, targetSqlType, scaleOrLength);
+      preparedStatement.setObject(parameterIndex, x, targetSqlType, scaleOrLength);
+   }
+
+   @Override
+   public void setObject(int parameterIndex, Object x, SQLType targetSqlType) throws SQLException {
+      logger.logf(level, "%s.setObject(%d, %s, %d)", statementID, parameterIndex, x, targetSqlType);
+      preparedStatement.setObject(parameterIndex, x, targetSqlType);
+   }
+
+   @Override
+   public long executeLargeUpdate() throws SQLException {
+      long l = preparedStatement.executeLargeUpdate();
+      logger.logf(level, "%s.executeLargeUpdate() = %s", statementID, l);
+      return l;
+   }
+}

http://git-wip-us.apache.org/repos/asf/activemq-artemis/blob/41b094df/artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/logging/LoggingResultSet.java
----------------------------------------------------------------------
diff --git a/artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/logging/LoggingResultSet.java b/artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/logging/LoggingResultSet.java
new file mode 100644
index 0000000..7453360
--- /dev/null
+++ b/artemis-jdbc-store/src/main/java/org/apache/activemq/artemis/jdbc/store/logging/LoggingResultSet.java
@@ -0,0 +1,1338 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements. See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License. You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.activemq.artemis.jdbc.store.logging;
+
+import java.io.InputStream;
+import java.io.Reader;
+import java.math.BigDecimal;
+import java.net.URL;
+import java.sql.Array;
+import java.sql.Blob;
+import java.sql.Clob;
+import java.sql.Date;
+import java.sql.NClob;
+import java.sql.Ref;
+import java.sql.ResultSet;
+import java.sql.ResultSetMetaData;
+import java.sql.RowId;
+import java.sql.SQLException;
+import java.sql.SQLType;
+import java.sql.SQLWarning;
+import java.sql.SQLXML;
+import java.sql.Statement;
+import java.sql.Time;
+import java.sql.Timestamp;
+import java.util.Arrays;
+import java.util.Calendar;
+import java.util.Map;
+
+import org.jboss.logging.Logger;
+
+public class LoggingResultSet implements ResultSet {
+
+   private final ResultSet resultSet;
+
+   private final String resultSetID;
+
+   private final Logger logger;
+
+   private static final Logger.Level level = Logger.Level.TRACE;
+
+   public LoggingResultSet(ResultSet resultSet, Logger logger) {
+      this.resultSet = resultSet;
+      this.logger = logger;
+      this.resultSetID = LoggingUtil.getID(resultSet);
+   }
+
+   public ResultSet getResultSet() {
+      return resultSet;
+   }
+
+   public String getResultSetID() {
+      return resultSetID;
+   }
+
+   @Override
+   public boolean next() throws SQLException {
+      boolean b = resultSet.next();
+      logger.logf(level, "%s.next() = %s", resultSetID, b);
+      return b;
+   }
+
+   @Override
+   public void close() throws SQLException {
+      logger.logf(level, "%s.close()", resultSetID);
+      resultSet.close();
+   }
+
+   @Override
+   public boolean wasNull() throws SQLException {
+      boolean b = resultSet.wasNull();
+      logger.logf(level, "%s.wasNull() = %s", resultSetID, b);
+      return b;
+   }
+
+   @Override
+   public String getString(int columnIndex) throws SQLException {
+      String x = resultSet.getString(columnIndex);
+      logger.logf(level, "%s.getString(%s) = %s", resultSetID, columnIndex, x);
+      return x;
+   }
+
+   @Override
+   public boolean getBoolean(int columnIndex) throws SQLException {
+      boolean x = resultSet.getBoolean(columnIndex);
+      logger.logf(level, "%s.getBoolean(%s) = %s", resultSetID, columnIndex, x);
+      return x;
+   }
+
+   @Override
+   public byte getByte(int columnIndex) throws SQLException {
+      byte x = resultSet.getByte(columnIndex);
+      logger.logf(level, "%s.getByte(%s) = %s", resultSetID, columnIndex, x);
+      return x;
+   }
+
+   @Override
+   public short getShort(int columnIndex) throws SQLException {
+      short x = resultSet.getShort(columnIndex);
+      logger.logf(level, "%s.getShort(%s) = %s", resultSetID, columnIndex, x);
+      return x;
+   }
+
+   @Override
+   public int getInt(int columnIndex) throws SQLException {
+      int x = resultSet.getInt(columnIndex);
+      logger.logf(level, "%s.getInt(%s) = %s", resultSetID, columnIndex, x);
+      return x;
+   }
+
+   @Override
+   public long getLong(int columnIndex) throws SQLException {
+      long x = resultSet.getLong(columnIndex);
+      logger.logf(level, "%s.getLong(%s) = %s", resultSetID, columnIndex, x);
+      return x;
+   }
+
+   @Override
+   public float getFloat(int columnIndex) throws SQLException {
+      float x = resultSet.getFloat(columnIndex);
+      logger.logf(level, "%s.getFloat(%s) = %s", resultSetID, columnIndex, x);
+      return x;
+   }
+
+   @Override
+   public double getDouble(int columnIndex) throws SQLException {
+      double x = resultSet.getDouble(columnIndex);
+      logger.logf(level, "%s.getDouble(%s) = %s", resultSetID, columnIndex, x);
+      return x;
+   }
+
+   @Override
+   public BigDecimal getBigDecimal(int columnIndex, int scale) throws SQLException {
+      BigDecimal x = resultSet.getBigDecimal(columnIndex);
+      logger.logf(level, "%s.getBigDecimal(%s) = %s", resultSetID, columnIndex, x);
+      return x;
+   }
+
+   @Override
+   public byte[] getBytes(int columnIndex) throws SQLException {
+      byte[] x = resultSet.getBytes(columnIndex);
+      logger.logf(level, "%s.getBytes(%s) = %s", resultSetID, columnIndex, Arrays.toString(x));
+      return x;
+   }
+
+   @Override
+   public Date getDate(int columnIndex) throws SQLException {
+      Date x = resultSet.getDate(columnIndex);
+      logger.logf(level, "%s.getDate(%s) = %s", resultSetID, columnIndex, x);
+      return x;
+   }
+
+   @Override
+   public Time getTime(int columnIndex) throws SQLException {
+      Time x = resultSet.getTime(columnIndex);
+      logger.logf(level, "%s.getTime(%s) = %s", resultSetID, columnIndex, x);
+      return x;
+   }
+
+   @Override
+   public Timestamp getTimestamp(int columnIndex) throws SQLException {
+      Timestamp x = resultSet.getTimestamp(columnIndex);
+      logger.logf(level, "%s.getTimestamp(%s) = %s", resultSetID, columnIndex, x);
+      return x;
+   }
+
+   @Override
+   public InputStream getAsciiStream(int columnIndex) throws SQLException {
+      InputStream x = resultSet.getAsciiStream(columnIndex);
+      logger.logf(level, "%s.getAsciiStream(%s) = %s", resultSetID, columnIndex, x);
+      return x;
+   }
+
+   @Override
+   public InputStream getUnicodeStream(int columnIndex) throws SQLException {
+      InputStream x = resultSet.getUnicodeStream(columnIndex);
+      logger.logf(level, "%s.getUnicodeStream(%s) = %s", resultSetID, columnIndex, x);
+      return x;
+   }
+
+   @Override
+   public InputStream getBinaryStream(int columnIndex) throws SQLException {
+      InputStream x = resultSet.getBinaryStream(columnIndex);
+      logger.logf(level, "%s.getBinaryStream(%s) = %s", resultSetID, columnIndex, x);
+      return x;
+   }
+
+   @Override
+   public String getString(String columnLabel) throws SQLException {
+      String x = resultSet.getString(columnLabel);
+      logger.logf(level, "%s.getString(%s) = %s", resultSetID, columnLabel, x);
+      return x;
+   }
+
+   @Override
+   public boolean getBoolean(String columnLabel) throws SQLException {
+      boolean x = resultSet.getBoolean(columnLabel);
+      logger.logf(level, "%s.getBoolean(%s) = %s", resultSetID, columnLabel, x);
+      return x;
+   }
+
+   @Override
+   public byte getByte(String columnLabel) throws SQLException {
+      byte x = resultSet.getByte(columnLabel);
+      logger.logf(level, "%s.getByte(%s) = %s", resultSetID, columnLabel, x);
+      return x;
+   }
+
+   @Override
+   public short getShort(String columnLabel) throws SQLException {
+      short x = resultSet.getShort(columnLabel);
+      logger.logf(level, "%s.getShort(%s) = %s", resultSetID, columnLabel, x);
+      return x;
+   }
+
+   @Override
+   public int getInt(String columnLabel) throws SQLException {
+      int x = resultSet.getInt(columnLabel);
+      logger.logf(level, "%s.getInt(%s) = %s", resultSetID, columnLabel, x);
+      return x;
+   }
+
+   @Override
+   public long getLong(String columnLabel) throws SQLException {
+      long x = resultSet.getLong(columnLabel);
+      logger.logf(level, "%s.getLong(%s) = %s", resultSetID, columnLabel, x);
+      return x;
+   }
+
+   @Override
+   public float getFloat(String columnLabel) throws SQLException {
+      float x = resultSet.getFloat(columnLabel);
+      logger.logf(level, "%s.getFloat(%s) = %s", resultSetID, columnLabel, x);
+      return x;
+   }
+
+   @Override
+   public double getDouble(String columnLabel) throws SQLException {
+      double x = resultSet.getDouble(columnLabel);
+      logger.logf(level, "%s.getDouble(%s) = %s", resultSetID, columnLabel, x);
+      return x;
+   }
+
+   @Override
+   public BigDecimal getBigDecimal(String columnLabel, int scale) throws SQLException {
+      BigDecimal x = resultSet.getBigDecimal(columnLabel);
+      logger.logf(level, "%s.getBigDecimal(%s) = %s", resultSetID, columnLabel, x);
+      return x;
+   }
+
+   @Override
+   public byte[] getBytes(String columnLabel) throws SQLException {
+      byte[] x = resultSet.getBytes(columnLabel);
+      logger.logf(level, "%s.getBytes(%s) = %s", resultSetID, columnLabel, Arrays.toString(x));
+      return x;
+   }
+
+   @Override
+   public Date getDate(String columnLabel) throws SQLException {
+      Date x = resultSet.getDate(columnLabel);
+      logger.logf(level, "%s.getDate(%s) = %s", resultSetID, columnLabel, x);
+      return x;
+   }
+
+   @Override
+   public Time getTime(String columnLabel) throws SQLException {
+      Time x = resultSet.getTime(columnLabel);
+      logger.logf(level, "%s.getTime(%s) = %s", resultSetID, columnLabel, x);
+      return x;
+   }
+
+   @Override
+   public Timestamp getTimestamp(String columnLabel) throws SQLException {
+      Timestamp x = resultSet.getTimestamp(columnLabel);
+      logger.logf(level, "%s.getTimestamp(%s) = %s", resultSetID, columnLabel, x);
+      return x;
+   }
+
+   @Override
+   public InputStream getAsciiStream(String columnLabel) throws SQLException {
+      InputStream x = resultSet.getAsciiStream(columnLabel);
+      logger.logf(level, "%s.getAsciiStream(%s) = %s", resultSetID, columnLabel, x);
+      return x;
+   }
+
+   @Override
+   public InputStream getUnicodeStream(String columnLabel) throws SQLException {
+      InputStream x = resultSet.getUnicodeStream(columnLabel);
+      logger.logf(level, "%s.getUnicodeStream(%s) = %s", resultSetID, columnLabel, x);
+      return x;
+   }
+
+   @Override
+   public InputStream getBinaryStream(String columnLabel) throws SQLException {
+      InputStream x = resultSet.getBinaryStream(columnLabel);
+      logger.logf(level, "%s.getBinaryStream(%s) = %s", resultSetID, columnLabel, x);
+      return x;
+   }
+
+   @Override
+   public SQLWarning getWarnings() throws SQLException {
+      SQLWarning x = resultSet.getWarnings();
+      logger.logf(level, "%s.getWarnings) = %s", resultSetID, x);
+      return x;
+   }
+
+   @Override
+   public void clearWarnings() throws SQLException {
+      logger.logf(level, "%s.clearWarnings()", resultSetID);
+      resultSet.clearWarnings();
+   }
+
+   @Override
+   public String getCursorName() throws SQLException {
+      String x = resultSet.getCursorName();
+      logger.logf(level, "%s.getCursorName() = %s", resultSetID, x);
+      return x;
+   }
+
+   @Override
+   public ResultSetMetaData getMetaData() throws SQLException {
+      ResultSetMetaData x = resultSet.getMetaData();
+      logger.logf(level, "%s.getMetaData() = %s", resultSetID, x);
+      return x;
+   }
+
+   @Override
+   public Object getObject(int columnIndex) throws SQLException {
+      String x = resultSet.getString(columnIndex);
+      logger.logf(level, "%s.getString(%s) = %s", resultSetID, columnIndex, x);
+      return x;
+   }
+
+   @Override
+   public Object getObject(String columnLabel) throws SQLException {
+      Object x = resultSet.getObject(columnLabel);
+      logger.logf(level, "%s.getObject(%s) = %s", resultSetID, columnLabel, x);
+      return x;
+   }
+
+   @Override
+   public int findColumn(String columnLabel) throws SQLException {
+      int x = resultSet.findColumn(columnLabel);
+      logger.logf(level, "%s.findColumn(%s) = %s", resultSetID, columnLabel, x);
+      return x;
+   }
+
+   @Override
+   public Reader getCharacterStream(int columnIndex) throws SQLException {
+      Reader x = resultSet.getCharacterStream(columnIndex);
+      logger.logf(level, "%s.getCharacterStream(%s) = %s", resultSetID, columnIndex, x);
+      return x;
+   }
+
+   @Override
+   public Reader getCharacterStream(String columnLabel) throws SQLException {
+      Reader x = resultSet.getCharacterStream(columnLabel);
+      logger.logf(level, "%s.getCharacterStream(%s) = %s", resultSetID, columnLabel, x);
+      return x;
+   }
+
+   @Override
+   public BigDecimal getBigDecimal(int columnIndex) throws SQLException {
+      BigDecimal x = resultSet.getBigDecimal(columnIndex);
+      logger.logf(level, "%s.getBigDecimal(%s) = %s", resultSetID, columnIndex, x);
+      return x;
+   }
+
+   @Override
+   public BigDecimal getBigDecimal(String columnLabel) throws SQLException {
+      BigDecimal x = resultSet.getBigDecimal(columnLabel);
+      logger.logf(level, "%s.getBigDecimal(%s) = %s", resultSetID, columnLabel, x);
+      return x;
+   }
+
+   @Override
+   public boolean isBeforeFirst() throws SQLException {
+      boolean x = resultSet.isBeforeFirst();
+      logger.logf(level, "%s.isBeforeFirst() = %s", resultSetID, x);
+      return x;
+   }
+
+   @Override
+   public boolean isAfterLast() throws SQLException {
+      boolean x = resultSet.isAfterLast();
+      logger.logf(level, "%s.isAfterLast() = %s", resultSetID, x);
+      return x;
+   }
+
+   @Override
+   public boolean isFirst() throws SQLException {
+      boolean x = resultSet.isFirst();
+      logger.logf(level, "%s.isFirst() = %s", resultSetID, x);
+      return x;
+   }
+
+   @Override
+   public boolean isLast() throws SQLException {
+      boolean x = resultSet.isLast();
+      logger.logf(level, "%s.isLast() = %s", resultSetID, x);
+      return x;
+   }
+
+   @Override
+   public void beforeFirst() throws SQLException {
+      logger.logf(level, "%s.beforeFirst()", resultSetID);
+      resultSet.beforeFirst();
+   }
+
+   @Override
+   public void afterLast() throws SQLException {
+      logger.logf(level, "%s.afterLast()", resultSetID);
+      resultSet.afterLast();
+   }
+
+   @Override
+   public boolean first() throws SQLException {
+      boolean x = resultSet.first();
+      logger.logf(level, "%s.first() = %s", resultSetID, x);
+      return x;
+   }
+
+   @Override
+   public boolean last() throws SQLException {
+      boolean x = resultSet.last();
+      logger.logf(level, "%s.last() = %s", resultSetID, x);
+      return x;
+   }
+
+   @Override
+   public int getRow() throws SQLException {
+      int x = resultSet.getRow();
+      logger.logf(level, "%s.getRow() = %s", resultSetID, x);
+      return x;
+   }
+
+   @Override
+   public boolean absolute(int row) throws SQLException {
+      boolean x = resultSet.absolute(row);
+      logger.logf(level, "%s.absolute(%s) = %s", resultSetID, row, x);
+      return x;
+   }
+
+   @Override
+   public boolean relative(int rows) throws SQLException {
+      boolean x = resultSet.relative(rows);
+      logger.logf(level, "%s.relative(%s) = %s", resultSetID, rows, x);
+      return x;
+   }
+
+   @Override
+   public boolean previous() throws SQLException {
+      boolean x = resultSet.previous();
+      logger.logf(level, "%s.previous() = %s", resultSetID, x);
+      return x;
+   }
+
+   @Override
+   public void setFetchDirection(int direction) throws SQLException {
+      logger.logf(level, "%s.setFetchDirection(%s)", resultSetID, direction);
+      resultSet.setFetchDirection(direction);
+   }
+
+   @Override
+   public int getFetchDirection() throws SQLException {
+      int x = resultSet.getFetchDirection();
+      logger.logf(level, "%s.getFetchDirection() = %s", resultSetID, x);
+      return x;
+   }
+
+   @Override
+   public void setFetchSize(int rows) throws SQLException {
+      logger.logf(level, "%s.setFetchSize(%s)", resultSetID, rows);
+      resultSet.setFetchSize(rows);
+   }
+
+   @Override
+   public int getFetchSize() throws SQLException {
+      int x = resultSet.getFetchSize();
+      logger.logf(level, "%s.getFetchSize() = %s", resultSetID, x);
+      return x;
+   }
+
+   @Override
+   public int getType() throws SQLException {
+      int x = resultSet.getType();
+      logger.logf(level, "%s.getType() = %s", resultSetID, x);
+      return x;
+   }
+
+   @Override
+   public int getConcurrency() throws SQLException {
+      int x = resultSet.getConcurrency();
+      logger.logf(level, "%s.getConcurrency() = %s", resultSetID, x);
+      return x;
+   }
+
+   @Override
+   public boolean rowUpdated() throws SQLException {
+      boolean x = resultSet.rowUpdated();
+      logger.logf(level, "%s.rowUpdated() = %s", resultSetID, x);
+      return x;
+   }
+
+   @Override
+   public boolean rowInserted() throws SQLException {
+      boolean x = resultSet.rowInserted();
+      logger.logf(level, "%s.rowInserted() = %s", resultSetID, x);
+      return x;
+   }
+
+   @Override
+   public boolean rowDeleted() throws SQLException {
+      boolean x = resultSet.rowDeleted();
+      logger.logf(level, "%s.rowDeleted() = %s", resultSetID, x);
+      return x;
+   }
+
+   @Override
+   public void updateNull(int columnIndex) throws SQLException {
+      logger.logf(level, "%s.updateNull(%s)", resultSetID, columnIndex);
+      resultSet.updateNull(columnIndex);
+   }
+
+   @Override
+   public void updateBoolean(int columnIndex, boolean x) throws SQLException {
+      logger.logf(level, "%s.updateBoolean(%s, %s)", resultSetID, columnIndex, x);
+      resultSet.updateBoolean(columnIndex, x);
+   }
+
+   @Override
+   public void updateByte(int columnIndex, byte x) throws SQLException {
+      logger.logf(level, "%s.updateByte(%s, %s)", resultSetID, columnIndex, x);
+      resultSet.updateByte(columnIndex, x);
+   }
+
+   @Override
+   public void updateShort(int columnIndex, short x) throws SQLException {
+      logger.logf(level, "%s.updateShort(%s, %s)", resultSetID, columnIndex, x);
+      resultSet.updateShort(columnIndex, x);
+   }
+
+   @Override
+   public void updateInt(int columnIndex, int x) throws SQLException {
+      logger.logf(level, "%s.updateInt(%s, %s)", resultSetID, columnIndex, x);
+      resultSet.updateInt(columnIndex, x);
+   }
+
+   @Override
+   public void updateLong(int columnIndex, long x) throws SQLException {
+      logger.logf(level, "%s.updateLong(%s, %s)", resultSetID, columnIndex, x);
+      resultSet.updateLong(columnIndex, x);
+   }
+
+   @Override
+   public void updateFloat(int columnIndex, float x) throws SQLException {
+      logger.logf(level, "%s.updateFloat(%s, %s)", resultSetID, columnIndex, x);
+      resultSet.updateFloat(columnIndex, x);
+   }
+
+   @Override
+   public void updateDouble(int columnIndex, double x) throws SQLException {
+      logger.logf(level, "%s.updateDouble(%s, %s)", resultSetID, columnIndex, x);
+      resultSet.updateDouble(columnIndex, x);
+   }
+
+   @Override
+   public void updateBigDecimal(int columnIndex, BigDecimal x) throws SQLException {
+      logger.logf(level, "%s.updateBigDecimal(%s, %s)", resultSetID, columnIndex, x);
+      resultSet.updateBigDecimal(columnIndex, x);
+   }
+
+   @Override
+   public void updateString(int columnIndex, String x) throws SQLException {
+      logger.logf(level, "%s.updateString(%s, %s)", resultSetID, columnIndex, x);
+      resultSet.updateString(columnIndex, x);
+   }
+
+   @Override
+   public void updateBytes(int columnIndex, byte[] x) throws SQLException {
+      logger.logf(level, "%s.updateBytes(%s, %s)", resultSetID, columnIndex, x);
+      resultSet.updateBytes(columnIndex, x);
+   }
+
+   @Override
+   public void updateDate(int columnIndex, Date x) throws SQLException {
+      logger.logf(level, "%s.updateDate(%s, %s)", resultSetID, columnIndex, x);
+      resultSet.updateDate(columnIndex, x);
+   }
+
+   @Override
+   public void updateTime(int columnIndex, Time x) throws SQLException {
+      logger.logf(level, "%s.updateTime(%s, %s)", resultSetID, columnIndex, x);
+      resultSet.updateTime(columnIndex, x);
+   }
+
+   @Override
+   public void updateTimestamp(int columnIndex, Timestamp x) throws SQLException {
+      logger.logf(level, "%s.updateTimestamp(%s, %s)", resultSetID, columnIndex, x);
+      resultSet.updateTimestamp(columnIndex, x);
+   }
+
+   @Override
+   public void updateAsciiStream(int columnIndex, InputStream x, int length) throws SQLException {
+      logger.logf(level, "%s.updateAsciiStream(%s, %s, %s)", resultSetID, columnIndex, x, length);
+      resultSet.updateAsciiStream(columnIndex, x, length);
+   }
+
+   @Override
+   public void updateBinaryStream(int columnIndex, InputStream x, int length) throws SQLException {
+      logger.logf(level, "%s.updateBinaryStream(%s, %s, %s)", resultSetID, columnIndex, x, length);
+      resultSet.updateBinaryStream(columnIndex, x, length);
+   }
+
+   @Override
+   public void updateCharacterStream(int columnIndex, Reader x, int length) throws SQLException {
+      logger.logf(level, "%s.updateCharacterStream(%s, %s, %s)", resultSetID, columnIndex, x, length);
+      resultSet.updateCharacterStream(columnIndex, x, length);
+   }
+
+   @Override
+   public void updateObject(int columnIndex, Object x, int scaleOrLength) throws SQLException {
+      logger.logf(level, "%s.updateObject(%s, %s, %s)", resultSetID, columnIndex, x, scaleOrLength);
+      resultSet.updateObject(columnIndex, x, scaleOrLength);
+   }
+
+   @Override
+   public void updateObject(int columnIndex, Object x) throws SQLException {
+      logger.logf(level, "%s.updateObject(%s, %s)", resultSetID, columnIndex, x);
+      resultSet.updateObject(columnIndex, x);
+   }
+
+   @Override
+   public void updateNull(String columnLabel) throws SQLException {
+      logger.logf(level, "%s.updateNull(%s)", resultSetID, columnLabel);
+      resultSet.updateNull(columnLabel);
+   }
+
+   @Override
+   public void updateBoolean(String columnLabel, boolean x) throws SQLException {
+      logger.logf(level, "%s.updateBoolean(%s, %s)", resultSetID, columnLabel, x);
+      resultSet.updateBoolean(columnLabel, x);
+   }
+
+   @Override
+   public void updateByte(String columnLabel, byte x) throws SQLException {
+      logger.logf(level, "%s.updateByte(%s, %s)", resultSetID, columnLabel, x);
+      resultSet.updateByte(columnLabel, x);
+   }
+
+   @Override
+   public void updateShort(String columnLabel, short x) throws SQLException {
+      logger.logf(level, "%s.updateShort(%s, %s)", resultSetID, columnLabel, x);
+      resultSet.updateShort(columnLabel, x);
+   }
+
+   @Override
+   public void updateInt(String columnLabel, int x) throws SQLException {
+      logger.logf(level, "%s.updateInt(%s, %s)", resultSetID, columnLabel, x);
+      resultSet.updateInt(columnLabel, x);
+   }
+
+   @Override
+   public void updateLong(String columnLabel, long x) throws SQLException {
+      logger.logf(level, "%s.updateLong(%s, %s)", resultSetID, columnLabel, x);
+      resultSet.updateLong(columnLabel, x);
+   }
+
+   @Override
+   public void updateFloat(String columnLabel, float x) throws SQLException {
+      logger.logf(level, "%s.updateFloat(%s, %s)", resultSetID, columnLabel, x);
+      resultSet.updateFloat(columnLabel, x);
+   }
+
+   @Override
+   public void updateDouble(String columnLabel, double x) throws SQLException {
+      logger.logf(level, "%s.updateDouble(%s, %s)", resultSetID, columnLabel, x);
+      resultSet.updateDouble(columnLabel, x);
+   }
+
+   @Override
+   public void updateBigDecimal(String columnLabel, BigDecimal x) throws SQLException {
+      logger.logf(level, "%s.updateBigDecimal(%s, %s)", resultSetID, columnLabel, x);
+      resultSet.updateBigDecimal(columnLabel, x);
+   }
+
+   @Override
+   public void updateString(String columnLabel, String x) throws SQLException {
+      logger.logf(level, "%s.updateString(%s, %s)", resultSetID, columnLabel, x);
+      resultSet.updateString(columnLabel, x);
+   }
+
+   @Override
+   public void updateBytes(String columnLabel, byte[] x) throws SQLException {
+      logger.logf(level, "%s.updateBytes(%s, %s)", resultSetID, columnLabel, x);
+      resultSet.updateBytes(columnLabel, x);
+   }
+
+   @Override
+   public void updateDate(String columnLabel, Date x) throws SQLException {
+      logger.logf(level, "%s.updateDate(%s, %s)", resultSetID, columnLabel, x);
+      resultSet.updateDate(columnLabel, x);
+   }
+
+   @Override
+   public void updateTime(String columnLabel, Time x) throws SQLException {
+      logger.logf(level, "%s.updateTime(%s, %s)", resultSetID, columnLabel, x);
+      resultSet.updateTime(columnLabel, x);
+   }
+
+   @Override
+   public void updateTimestamp(String columnLabel, Timestamp x) throws SQLException {
+      logger.logf(level, "%s.updateTimestamp(%s, %s)", resultSetID, columnLabel, x);
+      resultSet.updateTimestamp(columnLabel, x);
+   }
+
+   @Override
+   public void updateAsciiStream(String columnLabel, InputStream x, int length) throws SQLException {
+      logger.logf(level, "%s.updateAsciiStream(%s, %s, %s)", resultSetID, columnLabel, x, length);
+      resultSet.updateAsciiStream(columnLabel, x, length);
+   }
+
+   @Override
+   public void updateBinaryStream(String columnLabel, InputStream x, int length) throws SQLException {
+      logger.logf(level, "%s.updateBinaryStream(%s, %s, %s)", resultSetID, columnLabel, x, length);
+      resultSet.updateBinaryStream(columnLabel, x, length);
+   }
+
+   @Override
+   public void updateCharacterStream(String columnLabel, Reader x, int length) throws SQLException {
+      logger.logf(level, "%s.updateCharacterStream(%s, %s, %s)", resultSetID, columnLabel, x, length);
+      resultSet.updateCharacterStream(columnLabel, x, length);
+   }
+
+   @Override
+   public void updateObject(String columnLabel, Object x, int scaleOrLength) throws SQLException {
+      logger.logf(level, "%s.updateObject(%s, %s, %s)", resultSetID, columnLabel, x, scaleOrLength);
+      resultSet.updateObject(columnLabel, x, scaleOrLength);
+   }
+
+   @Override
+   public void updateObject(String columnLabel, Object x) throws SQLException {
+      logger.logf(level, "%s.updateObject(%s, %s)", resultSetID, columnLabel, x);
+      resultSet.updateObject(columnLabel, x);
+   }
+
+   @Override
+   public void insertRow() throws SQLException {
+      logger.logf(level, "%s.insertRow()", resultSetID);
+      resultSet.insertRow();
+   }
+
+   @Override
+   public void updateRow() throws SQLException {
+      logger.logf(level, "%s.updateRow()", resultSetID);
+      resultSet.updateRow();
+   }
+
+   @Override
+   public void deleteRow() throws SQLException {
+      logger.logf(level, "%s.deleteRow()", resultSetID);
+      resultSet.deleteRow();
+   }
+
+   @Override
+   public void refreshRow() throws SQLException {
+      logger.logf(level, "%s.refreshRow()", resultSetID);
+      resultSet.refreshRow();
+   }
+
+   @Override
+   public void cancelRowUpdates() throws SQLException {
+      logger.logf(level, "%s.cancelRowUpdates()", resultSetID);
+      resultSet.cancelRowUpdates();
+   }
+
+   @Override
+   public void moveToInsertRow() throws SQLException {
+      logger.logf(level, "%s.moveToInsertRow()", resultSetID);
+      resultSet.moveToInsertRow();
+   }
+
+   @Override
+   public void moveToCurrentRow() throws SQLException {
+      logger.logf(level, "%s.moveToCurrentRow()", resultSetID);
+      resultSet.moveToCurrentRow();
+   }
+
+   @Override
+   public Statement getStatement() throws SQLException {
+      Statement x = resultSet.getStatement();
+      logger.logf(level, "%s.getStatement() = %s", resultSetID, x);
+      return x;
+   }
+
+   @Override
+   public Object getObject(int columnIndex, Map<String, Class<?>> map) throws SQLException {
+      Object x = resultSet.getObject(columnIndex, map);
+      logger.logf(level, "%s.getObject(%s, %s) = %s", resultSetID, columnIndex, map, x);
+      return x;
+   }
+
+   @Override
+   public Ref getRef(int columnIndex) throws SQLException {
+      Ref x = resultSet.getRef(columnIndex);
+      logger.logf(level, "%s.getRef(%s) = %s", resultSetID, columnIndex, x);
+      return x;
+   }
+
+   @Override
+   public Blob getBlob(int columnIndex) throws SQLException {
+      Blob x = resultSet.getBlob(columnIndex);
+      logger.logf(level, "%s.getBlob(%s) = %s (length: %d)", resultSetID, columnIndex, x, x.length());
+      return x;
+   }
+
+   @Override
+   public Clob getClob(int columnIndex) throws SQLException {
+      Clob x = resultSet.getClob(columnIndex);
+      logger.logf(level, "%s.getClob(%s) = %s (length: %d)", resultSetID, columnIndex, x, x.length());
+      return x;
+   }
+
+   @Override
+   public Array getArray(int columnIndex) throws SQLException {
+      Array x = resultSet.getArray(columnIndex);
+      logger.logf(level, "%s.getArray(%s) = %s", resultSetID, columnIndex, x);
+      return x;
+   }
+
+   @Override
+   public Object getObject(String columnLabel, Map<String, Class<?>> map) throws SQLException {
+      Object x = resultSet.getObject(columnLabel, map);
+      logger.logf(level, "%s.getObject(%s, %s) = %s", resultSetID, columnLabel, map, x);
+      return x;
+   }
+
+   @Override
+   public Ref getRef(String columnLabel) throws SQLException {
+      Ref x = resultSet.getRef(columnLabel);
+      logger.logf(level, "%s.getRef(%s) = %s", resultSetID, columnLabel, x);
+      return x;
+   }
+
+   @Override
+   public Blob getBlob(String columnLabel) throws SQLException {
+      Blob x = resultSet.getBlob(columnLabel);
+      logger.logf(level, "%s.getBlob(%s) = %s (length: %d)", resultSetID, columnLabel, x, x.length());
+      return x;
+   }
+
+   @Override
+   public Clob getClob(String columnLabel) throws SQLException {
+      Clob x = resultSet.getClob(columnLabel);
+      logger.logf(level, "%s.getClob(%s) = %s (length: %d)", resultSetID, columnLabel, x, x.length());
+      return x;
+   }
+
+   @Override
+   public Array getArray(String columnLabel) throws SQLException {
+      Array x = resultSet.getArray(columnLabel);
+      logger.logf(level, "%s.getArray(%s) = %s", resultSetID, columnLabel, x);
+      return x;
+   }
+
+   @Override
+   public Date getDate(int columnLabel, Calendar cal) throws SQLException {
+      Date x = resultSet.getDate(columnLabel, cal);
+      logger.logf(level, "%s.getDate(%s) = %s", resultSetID, columnLabel, cal, x);
+      return x;
+   }
+
+   @Override
+   public Date getDate(String columnLabel, Calendar cal) throws SQLException {
+      Date x = resultSet.getDate(columnLabel, cal);
+      logger.logf(level, "%s.getDate(%s) = %s", resultSetID, columnLabel, cal, x);
+      return x;
+   }
+
+   @Override
+   public Time getTime(int columnLabel, Calendar cal) throws SQLException {
+      Time x = resultSet.getTime(columnLabel, cal);
+      logger.logf(level, "%s.getTime(%s) = %s", resultSetID, columnLabel, cal, x);
+      return x;
+   }
+
+   @Override
+   public Time getTime(String columnLabel, Calendar cal) throws SQLException {
+      Time x = resultSet.getTime(columnLabel, cal);
+      logger.logf(level, "%s.getTime(%s) = %s", resultSetID, columnLabel, cal, x);
+      return x;
+   }
+
+   @Override
+   public Timestamp getTimestamp(int columnLabel, Calendar cal) throws SQLException {
+      Timestamp x = resultSet.getTimestamp(columnLabel, cal);
+      logger.logf(level, "%s.getTimestamp(%s) = %s", resultSetID, columnLabel, cal, x);
+      return x;
+   }
+
+   @Override
+   public Timestamp getTimestamp(String columnLabel, Calendar cal) throws SQLException {
+      Timestamp x = resultSet.getTimestamp(columnLabel, cal);
+      logger.logf(level, "%s.getTimestamp(%s) = %s", resultSetID, columnLabel, cal, x);
+      return x;
+   }
+
+   @Override
+   public URL getURL(int columnLabel) throws SQLException {
+      URL x = resultSet.getURL(columnLabel);
+      logger.logf(level, "%s.getURL(%s) = %s", resultSetID, columnLabel, x);
+      return x;
+   }
+
+   @Override
+   public URL getURL(String columnLabel) throws SQLException {
+      URL x = resultSet.getURL(columnLabel);
+      logger.logf(level, "%s.getURL(%s) = %s", resultSetID, columnLabel, x);
+      return x;
+   }
+
+   @Override
+   public void updateRef(int columnIndex, Ref x) throws SQLException {
+      logger.logf(level, "%s.updateRef(%s, %s) = %s", resultSetID, columnIndex, x);
+      resultSet.updateRef(columnIndex, x);
+   }
+
+   @Override
+   public void updateRef(String columnLabel, Ref x) throws SQLException {
+      logger.logf(level, "%s.updateRef(%s, %s) = %s", resultSetID, columnLabel, x);
+      resultSet.updateRef(columnLabel, x);
+   }
+
+   @Override
+   public void updateBlob(int columnIndex, Blob x) throws SQLException {
+      logger.logf(level, "%s.updateBlob(%s, %s) = %s", resultSetID, columnIndex, x);
+      resultSet.updateBlob(columnIndex, x);
+   }
+
+   @Override
+   public void updateBlob(String columnLabel, Blob x) throws SQLException {
+      logger.logf(level, "%s.updateBlob(%s, %s) = %s", resultSetID, columnLabel, x);
+      resultSet.updateBlob(columnLabel, x);
+   }
+
+   @Override
+   public void updateClob(int columnIndex, Clob x) throws SQLException {
+      logger.logf(level, "%s.updateClob(%s, %s) = %s", resultSetID, columnIndex, x);
+      resultSet.updateClob(columnIndex, x);
+   }
+
+   @Override
+   public void updateClob(String columnLabel, Clob x) throws SQLException {
+      logger.logf(level, "%s.updateClob(%s, %s) = %s", resultSetID, columnLabel, x);
+      resultSet.updateClob(columnLabel, x);
+   }
+
+   @Override
+   public void updateArray(int columnIndex, Array x) throws SQLException {
+      logger.logf(level, "%s.updateArray(%s, %s) = %s", resultSetID, columnIndex, x);
+      resultSet.updateArray(columnIndex, x);
+   }
+
+   @Override
+   public void updateArray(String columnLabel, Array x) throws SQLException {
+      logger.logf(level, "%s.updateArray(%s, %s) = %s", resultSetID, columnLabel, x);
+      resultSet.updateArray(columnLabel, x);
+   }
+
+   @Override
+   public RowId getRowId(int columnIndex) throws SQLException {
+      RowId x = resultSet.getRowId(columnIndex);
+      logger.logf(level, "%s.getRowId(%s) = %s", resultSetID, columnIndex, x);
+      return x;
+   }
+
+   @Override
+   public RowId getRowId(String columnLabel) throws SQLException {
+      RowId x = resultSet.getRowId(columnLabel);
+      logger.logf(level, "%s.getRowId(%s) = %s", resultSetID, columnLabel, x);
+      return x;
+   }
+
+   @Override
+   public void updateRowId(int columnIndex, RowId x) throws SQLException {
+      logger.logf(level, "%s.updateRowId(%s, %s) = %s", resultSetID, columnIndex, x);
+      resultSet.updateRowId(columnIndex, x);
+   }
+
+   @Override
+   public void updateRowId(String columnLabel, RowId x) throws SQLException {
+      logger.logf(level, "%s.updateRowId(%s, %s) = %s", resultSetID, columnLabel, x);
+      resultSet.updateRowId(columnLabel, x);
+   }
+
+   @Override
+   public int getHoldability() throws SQLException {
+      int x = resultSet.getHoldability();
+      logger.logf(level, "%s.getHoldability() = %s", resultSetID, x);
+      return x;
+   }
+
+   @Override
+   public boolean isClosed() throws SQLException {
+      boolean x = resultSet.isClosed();
+      logger.logf(level, "%s.isClosed() = %s", resultSetID, x);
+      return x;
+   }
+
+   @Override
+   public void updateNString(int columnIndex, String x) throws SQLException {
+      logger.logf(level, "%s.updateNString(%s, %s) = %s", resultSetID, columnIndex, x);
+      resultSet.updateNString(columnIndex, x);
+   }
+
+   @Override
+   public void updateNString(String columnLabel, String x) throws SQLException {
+      logger.logf(level, "%s.updateNString(%s, %s) = %s", resultSetID, columnLabel, x);
+      resultSet.updateNString(columnLabel, x);
+   }
+
+   @Override
+   public void updateNClob(int columnIndex, NClob x) throws SQLException {
+      logger.logf(level, "%s.updateNClob(%s, %s) = %s", resultSetID, columnIndex, x);
+      resultSet.updateNClob(columnIndex, x);
+   }
+
+   @Override
+   public void updateNClob(String columnLabel, NClob x) throws SQLException {
+      logger.logf(level, "%s.updateNClob(%s, %s) = %s", resultSetID, columnLabel, x);
+      resultSet.updateNClob(columnLabel, x);
+   }
+
+   @Override
+   public NClob getNClob(int columnIndex) throws SQLException {
+      NClob x = resultSet.getNClob(columnIndex);
+      logger.logf(level, "%s.getNClob(%s) = %s", resultSetID, columnIndex, x);
+      return x;
+   }
+
+   @Override
+   public NClob getNClob(String columnLabel) throws SQLException {
+      NClob x = resultSet.getNClob(columnLabel);
+      logger.logf(level, "%s.getNClob(%s) = %s", resultSetID, columnLabel, x);
+      return x;
+   }
+
+   @Override
+   public SQLXML getSQLXML(int columnIndex) throws SQLException {
+      SQLXML x = resultSet.getSQLXML(columnIndex);
+      logger.logf(level, "%s.getSQLXML(%s) = %s", resultSetID, columnIndex, x);
+      return x;
+   }
+
+   @Override
+   public SQLXML getSQLXML(String columnLabel) throws SQLException {
+      SQLXML x = resultSet.getSQLXML(columnLabel);
+      logger.logf(level, "%s.getSQLXML(%s) = %s", resultSetID, columnLabel, x);
+      return x;
+   }
+
+   @Override
+   public void updateSQLXML(int columnIndex, SQLXML x) throws SQLException {
+      logger.logf(level, "%s.updateSQLXML(%s, %s) = %s", resultSetID, columnIndex, x);
+      resultSet.updateSQLXML(columnIndex, x);
+   }
+
+   @Override
+   public void updateSQLXML(String columnLabel, SQLXML x) throws SQLException {
+      logger.logf(level, "%s.updateSQLXML(%s, %s) = %s", resultSetID, columnLabel, x);
+      resultSet.updateSQLXML(columnLabel, x);
+   }
+
+   @Override
+   public String getNString(int columnIndex) throws SQLException {
+      String x = resultSet.getNString(columnIndex);
+      logger.logf(level, "%s.getNString(%s) = %s", resultSetID, columnIndex, x);
+      return x;
+   }
+
+   @Override
+   public String getNString(String columnLabel) throws SQLException {
+      String x = resultSet.getNString(columnLabel);
+      logger.logf(level, "%s.getNString(%s) = %s", resultSetID, columnLabel, x);
+      return x;
+   }
+
+   @Override
+   public Reader getNCharacterStream(int columnIndex) throws SQLException {
+      Reader x = resultSet.getNCharacterStream(columnIndex);
+      logger.logf(level, "%s.getNCharacterStream(%s) = %s", resultSetID, columnIndex, x);
+      return x;
+   }
+
+   @Override
+   public Reader getNCharacterStream(String columnLabel) throws SQLException {
+      Reader x = resultSet.getNCharacterStream(columnLabel);
+      logger.logf(level, "%s.getNCharacterStream(%s) = %s", resultSetID, columnLabel, x);
+      return x;
+   }
+
+   @Override
+   public void updateNCharacterStream(int columnIndex, Reader x, long length) throws SQLException {
+      logger.logf(level, "%s.updateNCharacterStream(%s, %s, %s)", resultSetID, columnIndex, x, length);
+      resultSet.updateNCharacterStream(columnIndex, x, length);
+   }
+
+   @Override
+   public void updateNCharacterStream(String columnLabel, Reader reader, long length) throws SQLException {
+      logger.logf(level, "%s.updateNCharacterStream(%s, %s, %s)", resultSetID, columnLabel, reader, length);
+      resultSet.updateNCharacterStream(columnLabel, reader, length);
+   }
+
+   @Override
+   public void updateAsciiStream(int columnIndex, InputStream x, long length) throws SQLException {
+      logger.logf(level, "%s.updateAsciiStream(%s, %s, %s)", resultSetID, columnIndex, x, length);
+      resultSet.updateAsciiStream(columnIndex, x, length);
+   }
+
+   @Override
+   public void updateBinaryStream(int columnIndex, InputStream x, long length) throws SQLException {
+      logger.logf(level, "%s.updateBinaryStream(%s, %s, %s)", resultSetID, columnIndex, x, length);
+      resultSet.updateBinaryStream(columnIndex, x, length);
+   }
+
+   @Override
+   public void updateCharacterStream(int columnIndex, Reader x, long length) throws SQLException {
+      logger.logf(level, "%s.updateCharacterStream(%s, %s, %s)", resultSetID, columnIndex, x, length);
+      resultSet.updateCharacterStream(columnIndex, x, length);
+   }
+
+   @Override
+   public void updateAsciiStream(String columnLabel, InputStream x, long length) throws SQLException {
+      logger.logf(level, "%s.updateAsciiStream(%s, %s, %s)", resultSetID, columnLabel, x, length);
+      resultSet.updateAsciiStream(columnLabel, x, length);
+   }
+
+   @Override
+   public void updateBinaryStream(String columnLabel, InputStream x, long length) throws SQLException {
+      logger.logf(level, "%s.updateBinaryStream(%s, %s, %s)", resultSetID, columnLabel, x, length);
+      resultSet.updateBinaryStream(columnLabel, x, length);
+   }
+
+   @Override
+   public void updateCharacterStream(String columnLabel, Reader reader, long length) throws SQLException {
+      logger.logf(level, "%s.updateCharacterStream(%s, %s, %s)", resultSetID, columnLabel, reader, length);
+      resultSet.updateCharacterStream(columnLabel, reader);
+   }
+
+   @Override
+   public void updateBlob(int columnIndex, InputStream inputStream, long length) throws SQLException {
+      logger.logf(level, "%s.updateBlob(%s, %s, %s)", resultSetID, columnIndex, inputStream, length);
+      resultSet.updateBlob(columnIndex, inputStream, length);
+   }
+
+   @Override
+   public void updateBlob(String columnLabel, InputStream inputStream, long length) throws SQLException {
+      logger.logf(level, "%s.updateBlob(%s, %s, %s)", resultSetID, columnLabel, inputStream, length);
+      resultSet.updateBlob(columnLabel, inputStream, length);
+   }
+
+   @Override
+   public void updateClob(int columnIndex, Reader reader, long length) throws SQLException {
+      logger.logf(level, "%s.updateClob(%s, %s, %s)", resultSetID, columnIndex, reader, length);
+      resultSet.updateClob(columnIndex, reader, length);
+   }
+
+   @Override
+   public void updateClob(String columnLabel, Reader reader, long length) throws SQLException {
+      logger.logf(level, "%s.updateClob(%s, %s, %s)", resultSetID, columnLabel, reader, length);
+      resultSet.updateClob(columnLabel, reader, length);
+   }
+
+   @Override
+   public void updateNClob(int columnIndex, Reader reader, long length) throws SQLException {
+      logger.logf(level, "%s.updateNClob(%s, %s, %s)", resultSetID, columnIndex, reader, length);
+      resultSet.updateNClob(columnIndex, reader, length);
+   }
+
+   @Override
+   public void updateNClob(String columnLabel, Reader reader, long length) throws SQLException {
+      logger.logf(level, "%s.updateNClob(%s, %s, %s)", resultSetID, columnLabel, reader, length);
+      resultSet.updateNClob(columnLabel, reader, length);
+   }
+
+   @Override
+   public void updateNCharacterStream(int columnIndex, Reader x) throws SQLException {
+      logger.logf(level, "%s.updateNCharacterStream(%s, %s)", resultSetID, columnIndex, x);
+      resultSet.updateNCharacterStream(columnIndex, x);
+   }
+
+   @Override
+   public void updateNCharacterStream(String columnLabel, Reader reader) throws SQLException {
+      logger.logf(level, "%s.updateNCharacterStream(%s, %s)", resultSetID, columnLabel, reader);
+      resultSet.updateNCharacterStream(columnLabel, reader);
+   }
+
+   @Override
+   public void updateAsciiStream(int columnIndex, InputStream x) throws SQLException {
+      logger.logf(level, "%s.updateAsciiStream(%s, %s)", resultSetID, columnIndex, x);
+      resultSet.updateAsciiStream(columnIndex, x);
+   }
+
+   @Override
+   public void updateBinaryStream(int columnIndex, InputStream x) throws SQLException {
+      logger.logf(level, "%s.updateBinaryStream(%s, %s)", resultSetID, columnIndex, x);
+      resultSet.updateBinaryStream(columnIndex, x);
+   }
+
+   @Override
+   public void updateCharacterStream(int columnIndex, Reader x) throws SQLException {
+      logger.logf(level, "%s.updateCharacterStream(%s, %s)", resultSetID, columnIndex, x);
+      resultSet.updateCharacterStream(columnIndex, x);
+   }
+
+   @Override
+   public void updateAsciiStream(String columnLabel, InputStream x) throws SQLException {
+      logger.logf(level, "%s.updateAsciiStream(%s, %s)", resultSetID, columnLabel, x);
+      resultSet.updateAsciiStream(columnLabel, x);
+   }
+
+   @Override
+   public void updateBinaryStream(String columnLabel, InputStream x) throws SQLException {
+      logger.logf(level, "%s.updateBinaryStream(%s, %s)", resultSetID, columnLabel, x);
+      resultSet.updateBinaryStream(columnLabel, x);
+   }
+
+   @Override
+   public void updateCharacterStream(String columnLabel, Reader reader) throws SQLException {
+      logger.logf(level, "%s.updateCharacterStream(%s, %s)", resultSetID, columnLabel, reader);
+      resultSet.updateCharacterStream(columnLabel, reader);
+   }
+
+   @Override
+   public void updateBlob(int columnIndex, InputStream inputStream) throws SQLException {
+      logger.logf(level, "%s.updateBlob(%s, %s)", resultSetID, columnIndex, inputStream);
+      resultSet.updateBlob(columnIndex, inputStream);
+   }
+
+   @Override
+   public void updateBlob(String columnLabel, InputStream inputStream) throws SQLException {
+      logger.logf(level, "%s.updateBlob(%s, %s)", resultSetID, columnLabel, inputStream);
+      resultSet.updateBlob(columnLabel, inputStream);
+   }
+
+   @Override
+   public void updateClob(int columnIndex, Reader reader) throws SQLException {
+      logger.logf(level, "%s.updateClob(%s, %s)", resultSetID, columnIndex, reader);
+      resultSet.updateClob(columnIndex, reader);
+   }
+
+   @Override
+   public void updateClob(String columnLabel, Reader reader) throws SQLException {
+      logger.logf(level, "%s.updateClob(%s, %s)", resultSetID, columnLabel, reader);
+      resultSet.updateClob(columnLabel, reader);
+   }
+
+   @Override
+   public void updateNClob(int columnIndex, Reader reader) throws SQLException {
+      logger.logf(level, "%s.updateNClob(%s, %s)", resultSetID, columnIndex, reader);
+      resultSet.updateNClob(columnIndex, reader);
+   }
+
+   @Override
+   public void updateNClob(String columnLabel, Reader reader) throws SQLException {
+      logger.logf(level, "%s.updateNClob(%s, %s)", resultSetID, columnLabel, reader);
+      resultSet.updateNClob(columnLabel, reader);
+   }
+
+   @Override
+   public <T> T getObject(int columnIndex, Class<T> type) throws SQLException {
+      T x = resultSet.getObject(columnIndex, type);
+      logger.logf(level, "%s.getObject(%s, %s) = %s", resultSetID, columnIndex, type, x);
+      return x;
+   }
+
+   @Override
+   public <T> T getObject(String columnLabel, Class<T> type) throws SQLException {
+      T x = resultSet.getObject(columnLabel, type);
+      logger.logf(level, "%s.getObject(%s, %s) = %s", resultSetID, columnLabel, type, x);
+      return x;
+   }
+
+   @Override
+   public void updateObject(int columnIndex, Object x, SQLType targetSqlType, int scaleOrLength) throws SQLException {
+      logger.logf(level, "%s.updateObject(%s, %s, %s, %s) = %s", resultSetID, columnIndex, x, targetSqlType, scaleOrLength);
+      resultSet.updateObject(columnIndex, x, targetSqlType);
+   }
+
+   @Override
+   public void updateObject(String columnLabel,
+                            Object x,
+                            SQLType targetSqlType,
+                            int scaleOrLength) throws SQLException {
+      logger.logf(level, "%s.updateObject(%s, %s, %s, %s) = %s", resultSetID, columnLabel, x, targetSqlType, scaleOrLength);
+      resultSet.updateObject(columnLabel, x, targetSqlType, scaleOrLength);
+   }
+
+   @Override
+   public void updateObject(int columnIndex, Object x, SQLType targetSqlType) throws SQLException {
+      logger.logf(level, "%s.updateObject(%s, %s, %s) = %s", resultSetID, columnIndex, x, targetSqlType);
+      resultSet.updateObject(columnIndex, x, targetSqlType);
+   }
+
+   @Override
+   public void updateObject(String columnLabel, Object x, SQLType targetSqlType) throws SQLException {
+      logger.logf(level, "%s.updateObject(%s, %s, %s) = %s", resultSetID, columnLabel, x, targetSqlType);
+      resultSet.updateObject(columnLabel, x, targetSqlType);
+   }
+
+   @Override
+   public <T> T unwrap(Class<T> iface) throws SQLException {
+      T x = resultSet.unwrap(iface);
+      logger.logf(level, "%s.unwrap(%s) = %s", resultSetID, iface, x);
+      return x;
+   }
+
+   @Override
+   public boolean isWrapperFor(Class<?> iface) throws SQLException {
+      boolean x = resultSet.isWrapperFor(iface);
+      logger.logf(level, "%s.isWrapperFor(%s) = %s", resultSetID, iface, x);
+      return x;
+   }
+}