You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@commons.apache.org by gg...@apache.org on 2017/10/16 02:41:52 UTC

[3/5] commons-dbutils git commit: Remove trailing white spaces on all lines.

http://git-wip-us.apache.org/repos/asf/commons-dbutils/blob/084f286a/src/test/java/org/apache/commons/dbutils/DbUtilsTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/commons/dbutils/DbUtilsTest.java b/src/test/java/org/apache/commons/dbutils/DbUtilsTest.java
index 33660ef..78e9081 100644
--- a/src/test/java/org/apache/commons/dbutils/DbUtilsTest.java
+++ b/src/test/java/org/apache/commons/dbutils/DbUtilsTest.java
@@ -1,285 +1,285 @@
-/*
- * 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.commons.dbutils;
-
-import org.junit.Test;
-
-import java.sql.Connection;
-import java.sql.ResultSet;
-import java.sql.SQLException;
-import java.sql.Statement;
-
-import static org.junit.Assert.assertFalse;
-import static org.junit.Assert.fail;
-import static org.mockito.Mockito.*;
-
-public class DbUtilsTest {
-
-    @Test
-    public void closeNullConnection() throws Exception {
-        DbUtils.close((Connection) null);
-    }
-
-    @Test
-    public void closeConnection() throws Exception {
-        Connection mockCon = mock(Connection.class);
-        DbUtils.close(mockCon);
-        verify(mockCon).close();
-    }
-
-    @Test
-    public void closeNullResultSet() throws Exception {
-        DbUtils.close((ResultSet) null);
-    }
-
-    @Test
-    public void closeResultSet() throws Exception {
-        ResultSet mockResultSet = mock(ResultSet.class);
-        DbUtils.close(mockResultSet);
-        verify(mockResultSet).close();
-    }
-
-    @Test
-    public void closeNullStatement() throws Exception {
-        DbUtils.close((Statement) null);
-    }
-
-    @Test
-    public void closeStatement() throws Exception {
-        Statement mockStatement = mock(Statement.class);
-        DbUtils.close(mockStatement);
-        verify(mockStatement).close();
-    }
-
-    @Test
-    public void closeQuietlyNullConnection() throws Exception {
-        DbUtils.closeQuietly((Connection) null);
-    }
-
-    @Test
-    public void closeQuietlyConnection() throws Exception {
-        Connection mockConnection = mock(Connection.class);
-        DbUtils.closeQuietly(mockConnection);
-        verify(mockConnection).close();
-    }
-
-    @Test
-    public void closeQuietlyConnectionThrowingException() throws Exception {
-        Connection mockConnection = mock(Connection.class);
-        doThrow(SQLException.class).when(mockConnection).close();
-        DbUtils.closeQuietly(mockConnection);
-    }
-
-    @Test
-    public void closeQuietlyNullResultSet() throws Exception {
-        DbUtils.closeQuietly((ResultSet) null);
-    }
-
-    @Test
-    public void closeQuietlyResultSet() throws Exception {
-        ResultSet mockResultSet = mock(ResultSet.class);
-        DbUtils.closeQuietly(mockResultSet);
-        verify(mockResultSet).close();
-    }
-
-    @Test
-    public void closeQuietlyResultSetThrowingException() throws Exception {
-        ResultSet mockResultSet = mock(ResultSet.class);
-        doThrow(SQLException.class).when(mockResultSet).close();
-        DbUtils.closeQuietly(mockResultSet);
-    }
-
-    @Test
-    public void closeQuietlyNullStatement() throws Exception {
-        DbUtils.closeQuietly((Statement) null);
-    }
-
-    @Test
-    public void closeQuietlyStatement() throws Exception {
-        Statement mockStatement = mock(Statement.class);
-        DbUtils.closeQuietly(mockStatement);
-        verify(mockStatement).close();
-    }
-
-    @Test
-    public void closeQuietlyStatementThrowingException() throws Exception {
-        Statement mockStatement = mock(Statement.class);
-        doThrow(SQLException.class).when(mockStatement).close();
-        DbUtils.closeQuietly(mockStatement);
-    }
-
-    @Test
-    public void closeQuietlyConnectionResultSetStatement() throws Exception {
-        Connection mockConnection = mock(Connection.class);
-        ResultSet mockResultSet = mock(ResultSet.class);
-        Statement mockStatement = mock(Statement.class);
-        DbUtils.closeQuietly(mockConnection, mockStatement, mockResultSet);
-        verify(mockConnection).close();
-        verify(mockResultSet).close();
-        verify(mockStatement).close();
-    }
-
-    @Test
-    public void closeQuietlyConnectionThrowingExceptionResultSetStatement() throws Exception {
-        Connection mockConnection = mock(Connection.class);
-        doThrow(SQLException.class).when(mockConnection).close();
-        ResultSet mockResultSet = mock(ResultSet.class);
-        Statement mockStatement = mock(Statement.class);
-        DbUtils.closeQuietly(mockConnection, mockStatement, mockResultSet);
-        verify(mockConnection).close();
-        verify(mockResultSet).close();
-        verify(mockStatement).close();
-    }
-
-    @Test
-    public void closeQuietlyConnectionResultSetThrowingExceptionStatement() throws Exception {
-        Connection mockConnection = mock(Connection.class);
-        ResultSet mockResultSet = mock(ResultSet.class);
-        doThrow(SQLException.class).when(mockResultSet).close();
-        Statement mockStatement = mock(Statement.class);
-        DbUtils.closeQuietly(mockConnection, mockStatement, mockResultSet);
-        verify(mockConnection).close();
-        verify(mockResultSet).close();
-        verify(mockStatement).close();
-    }
-
-    @Test
-    public void closeQuietlyConnectionResultSetStatementThrowingException() throws Exception {
-        Connection mockConnection = mock(Connection.class);
-        ResultSet mockResultSet = mock(ResultSet.class);
-        Statement mockStatement = mock(Statement.class);
-        doThrow(SQLException.class).when(mockStatement).close();
-        DbUtils.closeQuietly(mockConnection, mockStatement, mockResultSet);
-        verify(mockConnection).close();
-        verify(mockResultSet).close();
-        verify(mockStatement).close();
-    }
-
-    @Test
-    public void commitAndClose() throws Exception {
-        Connection mockConnection = mock(Connection.class);
-        DbUtils.commitAndClose(mockConnection);
-        verify(mockConnection).commit();
-        verify(mockConnection).close();
-    }
-
-    @Test
-    public void commitAndCloseWithException() throws Exception {
-        Connection mockConnection = mock(Connection.class);
-        doThrow(SQLException.class).when(mockConnection).commit();
-        try {
-            DbUtils.commitAndClose(mockConnection);
-            fail("DbUtils.commitAndClose() swallowed SQLEception!");
-        } catch (SQLException e) {
-            // we expect this exception
-        }
-        verify(mockConnection).close();
-    }
-
-    @Test
-    public void commitAndCloseQuietly() throws Exception {
-        Connection mockConnection = mock(Connection.class);
-        DbUtils.commitAndClose(mockConnection);
-        verify(mockConnection).commit();
-        verify(mockConnection).close();
-    }
-
-    @Test
-    public void commitAndCloseQuietlyWithException() throws Exception {
-        Connection mockConnection = mock(Connection.class);
-        doThrow(SQLException.class).when(mockConnection).close();
-        DbUtils.commitAndCloseQuietly(mockConnection);
-        verify(mockConnection).commit();
-        verify(mockConnection).close();
-    }
-
-    @Test
-    public void rollbackNull() throws Exception {
-        DbUtils.rollback(null);
-    }
-
-    @Test
-    public void rollback() throws Exception {
-        Connection mockConnection = mock(Connection.class);
-        DbUtils.rollback(mockConnection);
-        verify(mockConnection).rollback();
-    }
-
-    @Test
-    public void rollbackAndCloseNull() throws Exception {
-        DbUtils.rollbackAndClose(null);
-    }
-
-    @Test
-    public void rollbackAndClose() throws Exception {
-        Connection mockConnection = mock(Connection.class);
-        DbUtils.rollbackAndClose(mockConnection);
-        verify(mockConnection).rollback();
-        verify(mockConnection).close();
-    }
-
-    @Test
-    public void rollbackAndCloseWithException() throws Exception {
-        Connection mockConnection = mock(Connection.class);
-        doThrow(SQLException.class).when(mockConnection).rollback();
-        try {
-            DbUtils.rollbackAndClose(mockConnection);
-            fail("DbUtils.rollbackAndClose() swallowed SQLException!");
-        } catch (SQLException e) {
-            // we expect this exeption
-        }
-        verify(mockConnection).rollback();
-        verify(mockConnection).close();
-    }
-
-    @Test
-    public void rollbackAndCloseQuietlyNull() throws Exception {
-        DbUtils.rollbackAndCloseQuietly(null);
-    }
-
-    @Test
-    public void rollbackAndCloseQuietly() throws Exception {
-        Connection mockConnection = mock(Connection.class);
-        DbUtils.rollbackAndCloseQuietly(mockConnection);
-        verify(mockConnection).rollback();
-        verify(mockConnection).close();
-    }
-
-    @Test
-    public void rollbackAndCloseQuietlyWithException() throws Exception {
-        Connection mockConnection = mock(Connection.class);
-        doThrow(SQLException.class).when(mockConnection).rollback();
-        DbUtils.rollbackAndCloseQuietly(mockConnection);
-        verify(mockConnection).rollback();
-        verify(mockConnection).close();
-    }
-
-    @Test
-    public void testLoadDriverReturnsFalse() {
-        
-        assertFalse(DbUtils.loadDriver(""));
-
-    }
-
-    @Test
-    public void testCommitAndCloseQuietlyWithNullDoesNotThrowAnSQLException() {
-
-        DbUtils.commitAndCloseQuietly(null);
-
-    }
-    
-}
+/*
+ * 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.commons.dbutils;
+
+import org.junit.Test;
+
+import java.sql.Connection;
+import java.sql.ResultSet;
+import java.sql.SQLException;
+import java.sql.Statement;
+
+import static org.junit.Assert.assertFalse;
+import static org.junit.Assert.fail;
+import static org.mockito.Mockito.*;
+
+public class DbUtilsTest {
+
+    @Test
+    public void closeNullConnection() throws Exception {
+        DbUtils.close((Connection) null);
+    }
+
+    @Test
+    public void closeConnection() throws Exception {
+        Connection mockCon = mock(Connection.class);
+        DbUtils.close(mockCon);
+        verify(mockCon).close();
+    }
+
+    @Test
+    public void closeNullResultSet() throws Exception {
+        DbUtils.close((ResultSet) null);
+    }
+
+    @Test
+    public void closeResultSet() throws Exception {
+        ResultSet mockResultSet = mock(ResultSet.class);
+        DbUtils.close(mockResultSet);
+        verify(mockResultSet).close();
+    }
+
+    @Test
+    public void closeNullStatement() throws Exception {
+        DbUtils.close((Statement) null);
+    }
+
+    @Test
+    public void closeStatement() throws Exception {
+        Statement mockStatement = mock(Statement.class);
+        DbUtils.close(mockStatement);
+        verify(mockStatement).close();
+    }
+
+    @Test
+    public void closeQuietlyNullConnection() throws Exception {
+        DbUtils.closeQuietly((Connection) null);
+    }
+
+    @Test
+    public void closeQuietlyConnection() throws Exception {
+        Connection mockConnection = mock(Connection.class);
+        DbUtils.closeQuietly(mockConnection);
+        verify(mockConnection).close();
+    }
+
+    @Test
+    public void closeQuietlyConnectionThrowingException() throws Exception {
+        Connection mockConnection = mock(Connection.class);
+        doThrow(SQLException.class).when(mockConnection).close();
+        DbUtils.closeQuietly(mockConnection);
+    }
+
+    @Test
+    public void closeQuietlyNullResultSet() throws Exception {
+        DbUtils.closeQuietly((ResultSet) null);
+    }
+
+    @Test
+    public void closeQuietlyResultSet() throws Exception {
+        ResultSet mockResultSet = mock(ResultSet.class);
+        DbUtils.closeQuietly(mockResultSet);
+        verify(mockResultSet).close();
+    }
+
+    @Test
+    public void closeQuietlyResultSetThrowingException() throws Exception {
+        ResultSet mockResultSet = mock(ResultSet.class);
+        doThrow(SQLException.class).when(mockResultSet).close();
+        DbUtils.closeQuietly(mockResultSet);
+    }
+
+    @Test
+    public void closeQuietlyNullStatement() throws Exception {
+        DbUtils.closeQuietly((Statement) null);
+    }
+
+    @Test
+    public void closeQuietlyStatement() throws Exception {
+        Statement mockStatement = mock(Statement.class);
+        DbUtils.closeQuietly(mockStatement);
+        verify(mockStatement).close();
+    }
+
+    @Test
+    public void closeQuietlyStatementThrowingException() throws Exception {
+        Statement mockStatement = mock(Statement.class);
+        doThrow(SQLException.class).when(mockStatement).close();
+        DbUtils.closeQuietly(mockStatement);
+    }
+
+    @Test
+    public void closeQuietlyConnectionResultSetStatement() throws Exception {
+        Connection mockConnection = mock(Connection.class);
+        ResultSet mockResultSet = mock(ResultSet.class);
+        Statement mockStatement = mock(Statement.class);
+        DbUtils.closeQuietly(mockConnection, mockStatement, mockResultSet);
+        verify(mockConnection).close();
+        verify(mockResultSet).close();
+        verify(mockStatement).close();
+    }
+
+    @Test
+    public void closeQuietlyConnectionThrowingExceptionResultSetStatement() throws Exception {
+        Connection mockConnection = mock(Connection.class);
+        doThrow(SQLException.class).when(mockConnection).close();
+        ResultSet mockResultSet = mock(ResultSet.class);
+        Statement mockStatement = mock(Statement.class);
+        DbUtils.closeQuietly(mockConnection, mockStatement, mockResultSet);
+        verify(mockConnection).close();
+        verify(mockResultSet).close();
+        verify(mockStatement).close();
+    }
+
+    @Test
+    public void closeQuietlyConnectionResultSetThrowingExceptionStatement() throws Exception {
+        Connection mockConnection = mock(Connection.class);
+        ResultSet mockResultSet = mock(ResultSet.class);
+        doThrow(SQLException.class).when(mockResultSet).close();
+        Statement mockStatement = mock(Statement.class);
+        DbUtils.closeQuietly(mockConnection, mockStatement, mockResultSet);
+        verify(mockConnection).close();
+        verify(mockResultSet).close();
+        verify(mockStatement).close();
+    }
+
+    @Test
+    public void closeQuietlyConnectionResultSetStatementThrowingException() throws Exception {
+        Connection mockConnection = mock(Connection.class);
+        ResultSet mockResultSet = mock(ResultSet.class);
+        Statement mockStatement = mock(Statement.class);
+        doThrow(SQLException.class).when(mockStatement).close();
+        DbUtils.closeQuietly(mockConnection, mockStatement, mockResultSet);
+        verify(mockConnection).close();
+        verify(mockResultSet).close();
+        verify(mockStatement).close();
+    }
+
+    @Test
+    public void commitAndClose() throws Exception {
+        Connection mockConnection = mock(Connection.class);
+        DbUtils.commitAndClose(mockConnection);
+        verify(mockConnection).commit();
+        verify(mockConnection).close();
+    }
+
+    @Test
+    public void commitAndCloseWithException() throws Exception {
+        Connection mockConnection = mock(Connection.class);
+        doThrow(SQLException.class).when(mockConnection).commit();
+        try {
+            DbUtils.commitAndClose(mockConnection);
+            fail("DbUtils.commitAndClose() swallowed SQLEception!");
+        } catch (SQLException e) {
+            // we expect this exception
+        }
+        verify(mockConnection).close();
+    }
+
+    @Test
+    public void commitAndCloseQuietly() throws Exception {
+        Connection mockConnection = mock(Connection.class);
+        DbUtils.commitAndClose(mockConnection);
+        verify(mockConnection).commit();
+        verify(mockConnection).close();
+    }
+
+    @Test
+    public void commitAndCloseQuietlyWithException() throws Exception {
+        Connection mockConnection = mock(Connection.class);
+        doThrow(SQLException.class).when(mockConnection).close();
+        DbUtils.commitAndCloseQuietly(mockConnection);
+        verify(mockConnection).commit();
+        verify(mockConnection).close();
+    }
+
+    @Test
+    public void rollbackNull() throws Exception {
+        DbUtils.rollback(null);
+    }
+
+    @Test
+    public void rollback() throws Exception {
+        Connection mockConnection = mock(Connection.class);
+        DbUtils.rollback(mockConnection);
+        verify(mockConnection).rollback();
+    }
+
+    @Test
+    public void rollbackAndCloseNull() throws Exception {
+        DbUtils.rollbackAndClose(null);
+    }
+
+    @Test
+    public void rollbackAndClose() throws Exception {
+        Connection mockConnection = mock(Connection.class);
+        DbUtils.rollbackAndClose(mockConnection);
+        verify(mockConnection).rollback();
+        verify(mockConnection).close();
+    }
+
+    @Test
+    public void rollbackAndCloseWithException() throws Exception {
+        Connection mockConnection = mock(Connection.class);
+        doThrow(SQLException.class).when(mockConnection).rollback();
+        try {
+            DbUtils.rollbackAndClose(mockConnection);
+            fail("DbUtils.rollbackAndClose() swallowed SQLException!");
+        } catch (SQLException e) {
+            // we expect this exeption
+        }
+        verify(mockConnection).rollback();
+        verify(mockConnection).close();
+    }
+
+    @Test
+    public void rollbackAndCloseQuietlyNull() throws Exception {
+        DbUtils.rollbackAndCloseQuietly(null);
+    }
+
+    @Test
+    public void rollbackAndCloseQuietly() throws Exception {
+        Connection mockConnection = mock(Connection.class);
+        DbUtils.rollbackAndCloseQuietly(mockConnection);
+        verify(mockConnection).rollback();
+        verify(mockConnection).close();
+    }
+
+    @Test
+    public void rollbackAndCloseQuietlyWithException() throws Exception {
+        Connection mockConnection = mock(Connection.class);
+        doThrow(SQLException.class).when(mockConnection).rollback();
+        DbUtils.rollbackAndCloseQuietly(mockConnection);
+        verify(mockConnection).rollback();
+        verify(mockConnection).close();
+    }
+
+    @Test
+    public void testLoadDriverReturnsFalse() {
+
+        assertFalse(DbUtils.loadDriver(""));
+
+    }
+
+    @Test
+    public void testCommitAndCloseQuietlyWithNullDoesNotThrowAnSQLException() {
+
+        DbUtils.commitAndCloseQuietly(null);
+
+    }
+
+}

http://git-wip-us.apache.org/repos/asf/commons-dbutils/blob/084f286a/src/test/java/org/apache/commons/dbutils/GenerousBeanProcessorTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/commons/dbutils/GenerousBeanProcessorTest.java b/src/test/java/org/apache/commons/dbutils/GenerousBeanProcessorTest.java
index 20aed1b..2013627 100644
--- a/src/test/java/org/apache/commons/dbutils/GenerousBeanProcessorTest.java
+++ b/src/test/java/org/apache/commons/dbutils/GenerousBeanProcessorTest.java
@@ -30,7 +30,7 @@ import static org.mockito.Mockito.when;
 
 
 public class GenerousBeanProcessorTest {
-    
+
     GenerousBeanProcessor processor = new GenerousBeanProcessor();
     @Mock ResultSetMetaData metaData;
     PropertyDescriptor[] propDescriptors;
@@ -38,9 +38,9 @@ public class GenerousBeanProcessorTest {
     @Before
     public void setUp() throws Exception {
         MockitoAnnotations.initMocks(this);
-        
+
         propDescriptors = new PropertyDescriptor[3];
-        
+
         propDescriptors[0] = new PropertyDescriptor("one", TestBean.class);
         propDescriptors[1] = new PropertyDescriptor("two", TestBean.class);
         propDescriptors[2] = new PropertyDescriptor("three", TestBean.class);
@@ -50,13 +50,13 @@ public class GenerousBeanProcessorTest {
     @Test
     public void testMapColumnsToPropertiesWithOutUnderscores() throws Exception {
         when(metaData.getColumnCount()).thenReturn(3);
-        
+
         when(metaData.getColumnLabel(1)).thenReturn("three");
         when(metaData.getColumnLabel(2)).thenReturn("one");
         when(metaData.getColumnLabel(3)).thenReturn("two");
-        
+
         int[] ret = processor.mapColumnsToProperties(metaData, propDescriptors);
-        
+
         assertNotNull(ret);
         assertEquals(4, ret.length);
         assertEquals(-1, ret[0]);
@@ -88,13 +88,13 @@ public class GenerousBeanProcessorTest {
     @Test
     public void testMapColumnsToPropertiesWithUnderscores() throws Exception {
         when(metaData.getColumnCount()).thenReturn(3);
-        
+
         when(metaData.getColumnLabel(1)).thenReturn("t_h_r_e_e");
         when(metaData.getColumnLabel(2)).thenReturn("o_n_e");
         when(metaData.getColumnLabel(3)).thenReturn("t_w_o");
-        
+
         int[] ret = processor.mapColumnsToProperties(metaData, propDescriptors);
-        
+
         assertNotNull(ret);
         assertEquals(4, ret.length);
         assertEquals(-1, ret[0]);
@@ -127,27 +127,27 @@ public class GenerousBeanProcessorTest {
         private String one;
         private int two;
         private long three;
-        
+
         public String getOne() {
             return one;
         }
-        
+
         public void setOne(String one) {
             this.one = one;
         }
-        
+
         public int getTwo() {
             return two;
         }
-        
+
         public void setTwo(int two) {
             this.two = two;
         }
-        
+
         public long getThree() {
             return three;
         }
-        
+
         public void setThree(long three) {
             this.three = three;
         }

http://git-wip-us.apache.org/repos/asf/commons-dbutils/blob/084f286a/src/test/java/org/apache/commons/dbutils/MockResultSet.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/commons/dbutils/MockResultSet.java b/src/test/java/org/apache/commons/dbutils/MockResultSet.java
index 39b8547..e1d2e49 100644
--- a/src/test/java/org/apache/commons/dbutils/MockResultSet.java
+++ b/src/test/java/org/apache/commons/dbutils/MockResultSet.java
@@ -218,7 +218,7 @@ public class MockResultSet implements InvocationHandler {
     }
 
     /**
-     * @throws SQLException  
+     * @throws SQLException
      */
     protected ResultSetMetaData getMetaData() throws SQLException {
         return this.metaData;
@@ -328,14 +328,14 @@ public class MockResultSet implements InvocationHandler {
     }
 
     /**
-     * @throws SQLException  
+     * @throws SQLException
      */
     protected Boolean isLast() throws SQLException {
         return this.iter.hasNext() ? Boolean.FALSE : Boolean.TRUE;
     }
 
     /**
-     * @throws SQLException  
+     * @throws SQLException
      */
     protected Boolean next() throws SQLException {
         if (!this.iter.hasNext()) {
@@ -355,7 +355,7 @@ public class MockResultSet implements InvocationHandler {
     }
 
     /**
-     * @throws SQLException  
+     * @throws SQLException
      */
     protected Boolean wasNull() throws SQLException {
         return this.wasNull;