PageRenderTime 415ms CodeModel.GetById 21ms RepoModel.GetById 1ms app.codeStats 0ms

/jdbc/src/java/org/apache/hadoop/hive/jdbc/HiveBaseResultSet.java

http://github.com/apache/hive
Java | 987 lines | 757 code | 202 blank | 28 comment | 64 complexity | 875219978fd7e189c8e271cce8e014e4 MD5 | raw file
Possible License(s): Apache-2.0
  1. /**
  2. * Licensed to the Apache Software Foundation (ASF) under one
  3. * or more contributor license agreements. See the NOTICE file
  4. * distributed with this work for additional information
  5. * regarding copyright ownership. The ASF licenses this file
  6. * to you under the Apache License, Version 2.0 (the
  7. * "License"); you may not use this file except in compliance
  8. * with the License. You may obtain a copy of the License at
  9. *
  10. * http://www.apache.org/licenses/LICENSE-2.0
  11. *
  12. * Unless required by applicable law or agreed to in writing, software
  13. * distributed under the License is distributed on an "AS IS" BASIS,
  14. * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
  15. * See the License for the specific language governing permissions and
  16. * limitations under the License.
  17. */
  18. package org.apache.hadoop.hive.jdbc;
  19. import java.io.InputStream;
  20. import java.io.Reader;
  21. import java.math.BigDecimal;
  22. import java.math.MathContext;
  23. import java.net.URL;
  24. import java.sql.Array;
  25. import java.sql.Blob;
  26. import java.sql.Clob;
  27. import java.sql.Date;
  28. import java.sql.NClob;
  29. import java.sql.Ref;
  30. import java.sql.ResultSet;
  31. import java.sql.ResultSetMetaData;
  32. import java.sql.RowId;
  33. import java.sql.SQLException;
  34. import java.sql.SQLWarning;
  35. import java.sql.SQLXML;
  36. import java.sql.Statement;
  37. import java.sql.Time;
  38. import java.sql.Timestamp;
  39. import java.util.Calendar;
  40. import java.util.List;
  41. import java.util.Map;
  42. import org.apache.hadoop.hive.common.type.HiveDecimal;
  43. /**
  44. * Data independed base class which implements the common part of
  45. * all hive resultsets.
  46. */
  47. public abstract class HiveBaseResultSet implements ResultSet{
  48. protected SQLWarning warningChain = null;
  49. protected boolean wasNull = false;
  50. protected List<Object> row;
  51. protected List<String> columnNames;
  52. protected List<String> columnTypes;
  53. public boolean absolute(int row) throws SQLException {
  54. throw new SQLException("Method not supported");
  55. }
  56. public void afterLast() throws SQLException {
  57. throw new SQLException("Method not supported");
  58. }
  59. public void beforeFirst() throws SQLException {
  60. throw new SQLException("Method not supported");
  61. }
  62. public void cancelRowUpdates() throws SQLException {
  63. throw new SQLException("Method not supported");
  64. }
  65. public void deleteRow() throws SQLException {
  66. throw new SQLException("Method not supported");
  67. }
  68. public int findColumn(String columnName) throws SQLException {
  69. int columnIndex = columnNames.indexOf(columnName);
  70. if (columnIndex==-1) {
  71. throw new SQLException();
  72. } else {
  73. return ++columnIndex;
  74. }
  75. }
  76. public boolean first() throws SQLException {
  77. throw new SQLException("Method not supported");
  78. }
  79. public Array getArray(int i) throws SQLException {
  80. throw new SQLException("Method not supported");
  81. }
  82. public Array getArray(String colName) throws SQLException {
  83. throw new SQLException("Method not supported");
  84. }
  85. public InputStream getAsciiStream(int columnIndex) throws SQLException {
  86. throw new SQLException("Method not supported");
  87. }
  88. public InputStream getAsciiStream(String columnName) throws SQLException {
  89. throw new SQLException("Method not supported");
  90. }
  91. public BigDecimal getBigDecimal(int columnIndex) throws SQLException {
  92. Object obj = getObject(columnIndex);
  93. if (obj == null) {
  94. return null;
  95. }
  96. if (obj instanceof BigDecimal) {
  97. return ((BigDecimal) obj);
  98. }
  99. if (obj instanceof HiveDecimal) {
  100. return ((HiveDecimal) obj).bigDecimalValue();
  101. }
  102. throw new SQLException("Cannot convert column " + columnIndex
  103. + " to BigDecimal. Found data of type: "
  104. + obj.getClass()+", value: " + obj.toString());
  105. }
  106. public BigDecimal getBigDecimal(String columnName) throws SQLException {
  107. return getBigDecimal(findColumn(columnName));
  108. }
  109. public BigDecimal getBigDecimal(int columnIndex, int scale) throws SQLException {
  110. MathContext mc = new MathContext(scale);
  111. return getBigDecimal(columnIndex).round(mc);
  112. }
  113. public BigDecimal getBigDecimal(String columnName, int scale) throws SQLException {
  114. return getBigDecimal(findColumn(columnName), scale);
  115. }
  116. public InputStream getBinaryStream(int columnIndex) throws SQLException {
  117. throw new SQLException("Method not supported");
  118. }
  119. public InputStream getBinaryStream(String columnName) throws SQLException {
  120. throw new SQLException("Method not supported");
  121. }
  122. public Blob getBlob(int i) throws SQLException {
  123. throw new SQLException("Method not supported");
  124. }
  125. public Blob getBlob(String colName) throws SQLException {
  126. throw new SQLException("Method not supported");
  127. }
  128. public boolean getBoolean(int columnIndex) throws SQLException {
  129. Object obj = getObject(columnIndex);
  130. if (Boolean.class.isInstance(obj)) {
  131. return (Boolean) obj;
  132. } else if (obj == null) {
  133. return false;
  134. } else if (Number.class.isInstance(obj)) {
  135. return ((Number) obj).intValue() != 0;
  136. } else if (String.class.isInstance(obj)) {
  137. return !((String) obj).equals("0");
  138. }
  139. throw new SQLException("Cannot convert column " + columnIndex + " to boolean");
  140. }
  141. public boolean getBoolean(String columnName) throws SQLException {
  142. return getBoolean(findColumn(columnName));
  143. }
  144. public byte getByte(int columnIndex) throws SQLException {
  145. Object obj = getObject(columnIndex);
  146. if (Number.class.isInstance(obj)) {
  147. return ((Number) obj).byteValue();
  148. } else if (obj == null) {
  149. return 0;
  150. }
  151. throw new SQLException("Cannot convert column " + columnIndex + " to byte");
  152. }
  153. public byte getByte(String columnName) throws SQLException {
  154. return getByte(findColumn(columnName));
  155. }
  156. public byte[] getBytes(int columnIndex) throws SQLException {
  157. throw new SQLException("Method not supported");
  158. }
  159. public byte[] getBytes(String columnName) throws SQLException {
  160. throw new SQLException("Method not supported");
  161. }
  162. public Reader getCharacterStream(int columnIndex) throws SQLException {
  163. throw new SQLException("Method not supported");
  164. }
  165. public Reader getCharacterStream(String columnName) throws SQLException {
  166. throw new SQLException("Method not supported");
  167. }
  168. public Clob getClob(int i) throws SQLException {
  169. throw new SQLException("Method not supported");
  170. }
  171. public Clob getClob(String colName) throws SQLException {
  172. throw new SQLException("Method not supported");
  173. }
  174. public int getConcurrency() throws SQLException {
  175. return ResultSet.CONCUR_READ_ONLY;
  176. }
  177. public String getCursorName() throws SQLException {
  178. throw new SQLException("Method not supported");
  179. }
  180. public Date getDate(int columnIndex) throws SQLException {
  181. Object obj = getObject(columnIndex);
  182. if (obj == null) {
  183. return null;
  184. }
  185. if (obj instanceof Date) {
  186. return (Date) obj;
  187. }
  188. try {
  189. if (obj instanceof String) {
  190. return Date.valueOf((String)obj);
  191. }
  192. } catch (Exception e) {
  193. throw new SQLException("Cannot convert column " + columnIndex
  194. + " to date: " + e.toString());
  195. }
  196. throw new SQLException("Illegal conversion");
  197. }
  198. public Date getDate(String columnName) throws SQLException {
  199. return getDate(findColumn(columnName));
  200. }
  201. public Date getDate(int columnIndex, Calendar cal) throws SQLException {
  202. throw new SQLException("Method not supported");
  203. }
  204. public Date getDate(String columnName, Calendar cal) throws SQLException {
  205. throw new SQLException("Method not supported");
  206. }
  207. public double getDouble(int columnIndex) throws SQLException {
  208. try {
  209. Object obj = getObject(columnIndex);
  210. if (Number.class.isInstance(obj)) {
  211. return ((Number) obj).doubleValue();
  212. } else if (obj == null) {
  213. return 0;
  214. } else if (String.class.isInstance(obj)) {
  215. return Double.valueOf((String)obj);
  216. }
  217. throw new Exception("Illegal conversion");
  218. } catch (Exception e) {
  219. throw new SQLException("Cannot convert column " + columnIndex
  220. + " to double: " + e.toString());
  221. }
  222. }
  223. public double getDouble(String columnName) throws SQLException {
  224. return getDouble(findColumn(columnName));
  225. }
  226. public int getFetchDirection() throws SQLException {
  227. return ResultSet.FETCH_FORWARD;
  228. }
  229. public int getFetchSize() throws SQLException {
  230. throw new SQLException("Method not supported");
  231. }
  232. public float getFloat(int columnIndex) throws SQLException {
  233. try {
  234. Object obj = getObject(columnIndex);
  235. if (Number.class.isInstance(obj)) {
  236. return ((Number) obj).floatValue();
  237. } else if (obj == null) {
  238. return 0;
  239. } else if (String.class.isInstance(obj)) {
  240. return Float.valueOf((String)obj);
  241. }
  242. throw new Exception("Illegal conversion");
  243. } catch (Exception e) {
  244. throw new SQLException("Cannot convert column " + columnIndex
  245. + " to float: " + e.toString());
  246. }
  247. }
  248. public float getFloat(String columnName) throws SQLException {
  249. return getFloat(findColumn(columnName));
  250. }
  251. public int getHoldability() throws SQLException {
  252. throw new SQLException("Method not supported");
  253. }
  254. public int getInt(int columnIndex) throws SQLException {
  255. try {
  256. Object obj = getObject(columnIndex);
  257. if (Number.class.isInstance(obj)) {
  258. return ((Number) obj).intValue();
  259. } else if (obj == null) {
  260. return 0;
  261. } else if (String.class.isInstance(obj)) {
  262. return Integer.valueOf((String)obj);
  263. }
  264. throw new Exception("Illegal conversion");
  265. } catch (Exception e) {
  266. throw new SQLException("Cannot convert column " + columnIndex + " to integer" + e.toString());
  267. }
  268. }
  269. public int getInt(String columnName) throws SQLException {
  270. return getInt(findColumn(columnName));
  271. }
  272. public long getLong(int columnIndex) throws SQLException {
  273. try {
  274. Object obj = getObject(columnIndex);
  275. if (Number.class.isInstance(obj)) {
  276. return ((Number) obj).longValue();
  277. } else if (obj == null) {
  278. return 0;
  279. } else if (String.class.isInstance(obj)) {
  280. return Long.valueOf((String)obj);
  281. }
  282. throw new Exception("Illegal conversion");
  283. } catch (Exception e) {
  284. throw new SQLException("Cannot convert column " + columnIndex + " to long: " + e.toString());
  285. }
  286. }
  287. public long getLong(String columnName) throws SQLException {
  288. return getLong(findColumn(columnName));
  289. }
  290. public ResultSetMetaData getMetaData() throws SQLException {
  291. return new HiveResultSetMetaData(columnNames, columnTypes);
  292. }
  293. public Reader getNCharacterStream(int arg0) throws SQLException {
  294. throw new SQLException("Method not supported");
  295. }
  296. public Reader getNCharacterStream(String arg0) throws SQLException {
  297. throw new SQLException("Method not supported");
  298. }
  299. public NClob getNClob(int arg0) throws SQLException {
  300. throw new SQLException("Method not supported");
  301. }
  302. public NClob getNClob(String columnLabel) throws SQLException {
  303. throw new SQLException("Method not supported");
  304. }
  305. public String getNString(int columnIndex) throws SQLException {
  306. throw new SQLException("Method not supported");
  307. }
  308. public String getNString(String columnLabel) throws SQLException {
  309. throw new SQLException("Method not supported");
  310. }
  311. public Object getObject(int columnIndex) throws SQLException {
  312. if (row == null) {
  313. throw new SQLException("No row found.");
  314. }
  315. if (columnIndex > row.size()) {
  316. throw new SQLException("Invalid columnIndex: " + columnIndex);
  317. }
  318. try {
  319. wasNull = false;
  320. if (row.get(columnIndex - 1) == null) {
  321. wasNull = true;
  322. }
  323. return row.get(columnIndex - 1);
  324. } catch (Exception e) {
  325. throw new SQLException(e.toString());
  326. }
  327. }
  328. public Object getObject(String columnName) throws SQLException {
  329. return getObject(findColumn(columnName));
  330. }
  331. public <T> T getObject(int columnIndex, Class<T> type) throws SQLException {
  332. // TODO method required by JDK 1.7
  333. throw new SQLException("Method not supported");
  334. }
  335. public <T> T getObject(String columnLabel, Class<T> type) throws SQLException {
  336. // TODO method required by JDK 1.7
  337. throw new SQLException("Method not supported");
  338. }
  339. public Object getObject(int i, Map<String, Class<?>> map) throws SQLException {
  340. throw new SQLException("Method not supported");
  341. }
  342. public Object getObject(String colName, Map<String, Class<?>> map) throws SQLException {
  343. throw new SQLException("Method not supported");
  344. }
  345. public Ref getRef(int i) throws SQLException {
  346. throw new SQLException("Method not supported");
  347. }
  348. public Ref getRef(String colName) throws SQLException {
  349. throw new SQLException("Method not supported");
  350. }
  351. public int getRow() throws SQLException {
  352. throw new SQLException("Method not supported");
  353. }
  354. public RowId getRowId(int columnIndex) throws SQLException {
  355. throw new SQLException("Method not supported");
  356. }
  357. public RowId getRowId(String columnLabel) throws SQLException {
  358. throw new SQLException("Method not supported");
  359. }
  360. public SQLXML getSQLXML(int columnIndex) throws SQLException {
  361. throw new SQLException("Method not supported");
  362. }
  363. public SQLXML getSQLXML(String columnLabel) throws SQLException {
  364. throw new SQLException("Method not supported");
  365. }
  366. public short getShort(int columnIndex) throws SQLException {
  367. try {
  368. Object obj = getObject(columnIndex);
  369. if (Number.class.isInstance(obj)) {
  370. return ((Number) obj).shortValue();
  371. } else if (obj == null) {
  372. return 0;
  373. } else if (String.class.isInstance(obj)) {
  374. return Short.valueOf((String)obj);
  375. }
  376. throw new Exception("Illegal conversion");
  377. } catch (Exception e) {
  378. throw new SQLException("Cannot convert column " + columnIndex
  379. + " to short: " + e.toString());
  380. }
  381. }
  382. public short getShort(String columnName) throws SQLException {
  383. return getShort(findColumn(columnName));
  384. }
  385. public Statement getStatement() throws SQLException {
  386. throw new SQLException("Method not supported");
  387. }
  388. /**
  389. * @param columnIndex - the first column is 1, the second is 2, ...
  390. * @see java.sql.ResultSet#getString(int)
  391. */
  392. public String getString(int columnIndex) throws SQLException {
  393. // Column index starts from 1, not 0.
  394. Object obj = getObject(columnIndex);
  395. if (obj == null) {
  396. return null;
  397. }
  398. return obj.toString();
  399. }
  400. public String getString(String columnName) throws SQLException {
  401. return getString(findColumn(columnName));
  402. }
  403. public Time getTime(int columnIndex) throws SQLException {
  404. throw new SQLException("Method not supported");
  405. }
  406. public Time getTime(String columnName) throws SQLException {
  407. throw new SQLException("Method not supported");
  408. }
  409. public Time getTime(int columnIndex, Calendar cal) throws SQLException {
  410. throw new SQLException("Method not supported");
  411. }
  412. public Time getTime(String columnName, Calendar cal) throws SQLException {
  413. throw new SQLException("Method not supported");
  414. }
  415. public Timestamp getTimestamp(int columnIndex) throws SQLException {
  416. Object obj = getObject(columnIndex);
  417. if (obj == null) {
  418. return null;
  419. }
  420. if (obj instanceof Timestamp) {
  421. return (Timestamp) obj;
  422. }
  423. if (obj instanceof String) {
  424. return Timestamp.valueOf((String)obj);
  425. }
  426. throw new SQLException("Illegal conversion");
  427. }
  428. public Timestamp getTimestamp(String columnName) throws SQLException {
  429. return getTimestamp(findColumn(columnName));
  430. }
  431. public Timestamp getTimestamp(int columnIndex, Calendar cal) throws SQLException {
  432. throw new SQLException("Method not supported");
  433. }
  434. public Timestamp getTimestamp(String columnName, Calendar cal) throws SQLException {
  435. throw new SQLException("Method not supported");
  436. }
  437. public int getType() throws SQLException {
  438. return ResultSet.TYPE_FORWARD_ONLY;
  439. }
  440. public URL getURL(int columnIndex) throws SQLException {
  441. throw new SQLException("Method not supported");
  442. }
  443. public URL getURL(String columnName) throws SQLException {
  444. throw new SQLException("Method not supported");
  445. }
  446. public InputStream getUnicodeStream(int columnIndex) throws SQLException {
  447. throw new SQLException("Method not supported");
  448. }
  449. public InputStream getUnicodeStream(String columnName) throws SQLException {
  450. throw new SQLException("Method not supported");
  451. }
  452. public void insertRow() throws SQLException {
  453. throw new SQLException("Method not supported");
  454. }
  455. public boolean isAfterLast() throws SQLException {
  456. throw new SQLException("Method not supported");
  457. }
  458. public boolean isBeforeFirst() throws SQLException {
  459. throw new SQLException("Method not supported");
  460. }
  461. public boolean isClosed() throws SQLException {
  462. throw new SQLException("Method not supported");
  463. }
  464. public boolean isFirst() throws SQLException {
  465. throw new SQLException("Method not supported");
  466. }
  467. public boolean isLast() throws SQLException {
  468. throw new SQLException("Method not supported");
  469. }
  470. public boolean last() throws SQLException {
  471. throw new SQLException("Method not supported");
  472. }
  473. public void moveToCurrentRow() throws SQLException {
  474. throw new SQLException("Method not supported");
  475. }
  476. public void moveToInsertRow() throws SQLException {
  477. throw new SQLException("Method not supported");
  478. }
  479. public boolean previous() throws SQLException {
  480. throw new SQLException("Method not supported");
  481. }
  482. public void refreshRow() throws SQLException {
  483. throw new SQLException("Method not supported");
  484. }
  485. public boolean relative(int rows) throws SQLException {
  486. throw new SQLException("Method not supported");
  487. }
  488. public boolean rowDeleted() throws SQLException {
  489. throw new SQLException("Method not supported");
  490. }
  491. public boolean rowInserted() throws SQLException {
  492. throw new SQLException("Method not supported");
  493. }
  494. public boolean rowUpdated() throws SQLException {
  495. throw new SQLException("Method not supported");
  496. }
  497. public void setFetchDirection(int direction) throws SQLException {
  498. throw new SQLException("Method not supported");
  499. }
  500. public void setFetchSize(int rows) throws SQLException {
  501. throw new SQLException("Method not supported");
  502. }
  503. public void updateArray(int columnIndex, Array x) throws SQLException {
  504. throw new SQLException("Method not supported");
  505. }
  506. public void updateArray(String columnName, Array x) throws SQLException {
  507. throw new SQLException("Method not supported");
  508. }
  509. public void updateAsciiStream(int columnIndex, InputStream x) throws SQLException {
  510. throw new SQLException("Method not supported");
  511. }
  512. public void updateAsciiStream(String columnLabel, InputStream x) throws SQLException {
  513. throw new SQLException("Method not supported");
  514. }
  515. public void updateAsciiStream(int columnIndex, InputStream x, int length)
  516. throws SQLException {
  517. throw new SQLException("Method not supported");
  518. }
  519. public void updateAsciiStream(String columnName, InputStream x, int length)
  520. throws SQLException {
  521. throw new SQLException("Method not supported");
  522. }
  523. public void updateAsciiStream(int columnIndex, InputStream x, long length)
  524. throws SQLException {
  525. throw new SQLException("Method not supported");
  526. }
  527. public void updateAsciiStream(String columnLabel, InputStream x, long length)
  528. throws SQLException {
  529. throw new SQLException("Method not supported");
  530. }
  531. public void updateBigDecimal(int columnIndex, BigDecimal x) throws SQLException {
  532. throw new SQLException("Method not supported");
  533. }
  534. public void updateBigDecimal(String columnName, BigDecimal x) throws SQLException {
  535. throw new SQLException("Method not supported");
  536. }
  537. public void updateBinaryStream(int columnIndex, InputStream x) throws SQLException {
  538. throw new SQLException("Method not supported");
  539. }
  540. public void updateBinaryStream(String columnLabel, InputStream x) throws SQLException {
  541. throw new SQLException("Method not supported");
  542. }
  543. public void updateBinaryStream(int columnIndex, InputStream x, int length)
  544. throws SQLException {
  545. throw new SQLException("Method not supported");
  546. }
  547. public void updateBinaryStream(String columnName, InputStream x, int length)
  548. throws SQLException {
  549. throw new SQLException("Method not supported");
  550. }
  551. public void updateBinaryStream(int columnIndex, InputStream x, long length)
  552. throws SQLException {
  553. throw new SQLException("Method not supported");
  554. }
  555. public void updateBinaryStream(String columnLabel, InputStream x, long length)
  556. throws SQLException {
  557. throw new SQLException("Method not supported");
  558. }
  559. public void updateBlob(int columnIndex, Blob x) throws SQLException {
  560. throw new SQLException("Method not supported");
  561. }
  562. public void updateBlob(String columnName, Blob x) throws SQLException {
  563. throw new SQLException("Method not supported");
  564. }
  565. public void updateBlob(int columnIndex, InputStream inputStream) throws SQLException {
  566. throw new SQLException("Method not supported");
  567. }
  568. public void updateBlob(String columnLabel, InputStream inputStream) throws SQLException {
  569. throw new SQLException("Method not supported");
  570. }
  571. public void updateBlob(int columnIndex, InputStream inputStream, long length)
  572. throws SQLException {
  573. throw new SQLException("Method not supported");
  574. }
  575. public void updateBlob(String columnLabel, InputStream inputStream,
  576. long length) throws SQLException {
  577. throw new SQLException("Method not supported");
  578. }
  579. public void updateBoolean(int columnIndex, boolean x) throws SQLException {
  580. throw new SQLException("Method not supported");
  581. }
  582. public void updateBoolean(String columnName, boolean x) throws SQLException {
  583. throw new SQLException("Method not supported");
  584. }
  585. public void updateByte(int columnIndex, byte x) throws SQLException {
  586. throw new SQLException("Method not supported");
  587. }
  588. public void updateByte(String columnName, byte x) throws SQLException {
  589. throw new SQLException("Method not supported");
  590. }
  591. public void updateBytes(int columnIndex, byte[] x) throws SQLException {
  592. throw new SQLException("Method not supported");
  593. }
  594. public void updateBytes(String columnName, byte[] x) throws SQLException {
  595. throw new SQLException("Method not supported");
  596. }
  597. public void updateCharacterStream(int columnIndex, Reader x) throws SQLException {
  598. throw new SQLException("Method not supported");
  599. }
  600. public void updateCharacterStream(String columnLabel, Reader reader) throws SQLException {
  601. throw new SQLException("Method not supported");
  602. }
  603. public void updateCharacterStream(int columnIndex, Reader x, int length)
  604. throws SQLException {
  605. throw new SQLException("Method not supported");
  606. }
  607. public void updateCharacterStream(String columnName, Reader reader, int length)
  608. throws SQLException {
  609. throw new SQLException("Method not supported");
  610. }
  611. public void updateCharacterStream(int columnIndex, Reader x, long length)
  612. throws SQLException {
  613. throw new SQLException("Method not supported");
  614. }
  615. public void updateCharacterStream(String columnLabel, Reader reader,
  616. long length) throws SQLException {
  617. throw new SQLException("Method not supported");
  618. }
  619. public void updateClob(int columnIndex, Clob x) throws SQLException {
  620. throw new SQLException("Method not supported");
  621. }
  622. public void updateClob(String columnName, Clob x) throws SQLException {
  623. throw new SQLException("Method not supported");
  624. }
  625. public void updateClob(int columnIndex, Reader reader) throws SQLException {
  626. throw new SQLException("Method not supported");
  627. }
  628. public void updateClob(String columnLabel, Reader reader) throws SQLException {
  629. throw new SQLException("Method not supported");
  630. }
  631. public void updateClob(int columnIndex, Reader reader, long length) throws SQLException {
  632. throw new SQLException("Method not supported");
  633. }
  634. public void updateClob(String columnLabel, Reader reader, long length) throws SQLException {
  635. throw new SQLException("Method not supported");
  636. }
  637. public void updateDate(int columnIndex, Date x) throws SQLException {
  638. throw new SQLException("Method not supported");
  639. }
  640. public void updateDate(String columnName, Date x) throws SQLException {
  641. throw new SQLException("Method not supported");
  642. }
  643. public void updateDouble(int columnIndex, double x) throws SQLException {
  644. throw new SQLException("Method not supported");
  645. }
  646. public void updateDouble(String columnName, double x) throws SQLException {
  647. throw new SQLException("Method not supported");
  648. }
  649. public void updateFloat(int columnIndex, float x) throws SQLException {
  650. throw new SQLException("Method not supported");
  651. }
  652. public void updateFloat(String columnName, float x) throws SQLException {
  653. throw new SQLException("Method not supported");
  654. }
  655. public void updateInt(int columnIndex, int x) throws SQLException {
  656. throw new SQLException("Method not supported");
  657. }
  658. public void updateInt(String columnName, int x) throws SQLException {
  659. throw new SQLException("Method not supported");
  660. }
  661. public void updateLong(int columnIndex, long x) throws SQLException {
  662. throw new SQLException("Method not supported");
  663. }
  664. public void updateLong(String columnName, long x) throws SQLException {
  665. throw new SQLException("Method not supported");
  666. }
  667. public void updateNCharacterStream(int columnIndex, Reader x) throws SQLException {
  668. throw new SQLException("Method not supported");
  669. }
  670. public void updateNCharacterStream(String columnLabel, Reader reader) throws SQLException {
  671. throw new SQLException("Method not supported");
  672. }
  673. public void updateNCharacterStream(int columnIndex, Reader x, long length) throws SQLException {
  674. throw new SQLException("Method not supported");
  675. }
  676. public void updateNCharacterStream(String columnLabel, Reader reader,
  677. long length) throws SQLException {
  678. throw new SQLException("Method not supported");
  679. }
  680. public void updateNClob(int columnIndex, NClob clob) throws SQLException {
  681. throw new SQLException("Method not supported");
  682. }
  683. public void updateNClob(String columnLabel, NClob clob) throws SQLException {
  684. throw new SQLException("Method not supported");
  685. }
  686. public void updateNClob(int columnIndex, Reader reader) throws SQLException {
  687. throw new SQLException("Method not supported");
  688. }
  689. public void updateNClob(String columnLabel, Reader reader) throws SQLException {
  690. throw new SQLException("Method not supported");
  691. }
  692. public void updateNClob(int columnIndex, Reader reader, long length) throws SQLException {
  693. throw new SQLException("Method not supported");
  694. }
  695. public void updateNClob(String columnLabel, Reader reader, long length) throws SQLException {
  696. throw new SQLException("Method not supported");
  697. }
  698. public void updateNString(int columnIndex, String string) throws SQLException {
  699. throw new SQLException("Method not supported");
  700. }
  701. public void updateNString(String columnLabel, String string) throws SQLException {
  702. throw new SQLException("Method not supported");
  703. }
  704. public void updateNull(int columnIndex) throws SQLException {
  705. throw new SQLException("Method not supported");
  706. }
  707. public void updateNull(String columnName) throws SQLException {
  708. throw new SQLException("Method not supported");
  709. }
  710. public void updateObject(int columnIndex, Object x) throws SQLException {
  711. throw new SQLException("Method not supported");
  712. }
  713. public void updateObject(String columnName, Object x) throws SQLException {
  714. throw new SQLException("Method not supported");
  715. }
  716. public void updateObject(int columnIndex, Object x, int scale) throws SQLException {
  717. throw new SQLException("Method not supported");
  718. }
  719. public void updateObject(String columnName, Object x, int scale) throws SQLException {
  720. throw new SQLException("Method not supported");
  721. }
  722. public void updateRef(int columnIndex, Ref x) throws SQLException {
  723. throw new SQLException("Method not supported");
  724. }
  725. public void updateRef(String columnName, Ref x) throws SQLException {
  726. throw new SQLException("Method not supported");
  727. }
  728. public void updateRow() throws SQLException {
  729. throw new SQLException("Method not supported");
  730. }
  731. public void updateRowId(int columnIndex, RowId x) throws SQLException {
  732. throw new SQLException("Method not supported");
  733. }
  734. public void updateRowId(String columnLabel, RowId x) throws SQLException {
  735. throw new SQLException("Method not supported");
  736. }
  737. public void updateSQLXML(int columnIndex, SQLXML xmlObject) throws SQLException {
  738. throw new SQLException("Method not supported");
  739. }
  740. public void updateSQLXML(String columnLabel, SQLXML xmlObject) throws SQLException {
  741. throw new SQLException("Method not supported");
  742. }
  743. public void updateShort(int columnIndex, short x) throws SQLException {
  744. throw new SQLException("Method not supported");
  745. }
  746. public void updateShort(String columnName, short x) throws SQLException {
  747. throw new SQLException("Method not supported");
  748. }
  749. public void updateString(int columnIndex, String x) throws SQLException {
  750. throw new SQLException("Method not supported");
  751. }
  752. public void updateString(String columnName, String x) throws SQLException {
  753. throw new SQLException("Method not supported");
  754. }
  755. public void updateTime(int columnIndex, Time x) throws SQLException {
  756. throw new SQLException("Method not supported");
  757. }
  758. public void updateTime(String columnName, Time x) throws SQLException {
  759. throw new SQLException("Method not supported");
  760. }
  761. public void updateTimestamp(int columnIndex, Timestamp x) throws SQLException {
  762. throw new SQLException("Method not supported");
  763. }
  764. public void updateTimestamp(String columnName, Timestamp x) throws SQLException {
  765. throw new SQLException("Method not supported");
  766. }
  767. public SQLWarning getWarnings() throws SQLException {
  768. return warningChain;
  769. }
  770. public void clearWarnings() throws SQLException {
  771. warningChain = null;
  772. }
  773. public void close() throws SQLException {
  774. throw new SQLException("Method not supported");
  775. }
  776. public boolean wasNull() throws SQLException {
  777. return wasNull;
  778. }
  779. public boolean isWrapperFor(Class<?> iface) throws SQLException {
  780. throw new SQLException("Method not supported");
  781. }
  782. public <T> T unwrap(Class<T> iface) throws SQLException {
  783. throw new SQLException("Method not supported");
  784. }
  785. }