You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@harmony.apache.org by nd...@apache.org on 2006/11/04 07:57:29 UTC

svn commit: r471131 - in /incubator/harmony/enhanced/classlib/trunk/modules/sql: META-INF/ src/main/java/javax/sql/rowset/ src/main/java/javax/sql/rowset/spi/

Author: ndbeyer
Date: Fri Nov  3 22:57:27 2006
New Revision: 471131

URL: http://svn.apache.org/viewvc?view=rev&rev=471131
Log:
Stub out javax.sql.rowset and javax.sql.rowset.spi

Added:
    incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/
    incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/CachedRowSet.java   (with props)
    incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/FilteredRowSet.java   (with props)
    incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/JdbcRowSet.java   (with props)
    incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/JoinRowSet.java   (with props)
    incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/Joinable.java   (with props)
    incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/Predicate.java   (with props)
    incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/RowSetWarning.java   (with props)
    incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/WebRowSet.java   (with props)
    incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/
    incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/SyncFactory.java   (with props)
    incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/SyncFactoryException.java   (with props)
    incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/SyncProvider.java   (with props)
    incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/SyncProviderException.java   (with props)
    incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/SyncResolver.java   (with props)
    incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/TransactionalWriter.java   (with props)
    incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/XmlReader.java   (with props)
    incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/XmlWriter.java   (with props)
Modified:
    incubator/harmony/enhanced/classlib/trunk/modules/sql/META-INF/MANIFEST.MF

Modified: incubator/harmony/enhanced/classlib/trunk/modules/sql/META-INF/MANIFEST.MF
URL: http://svn.apache.org/viewvc/incubator/harmony/enhanced/classlib/trunk/modules/sql/META-INF/MANIFEST.MF?view=diff&rev=471131&r1=471130&r2=471131
==============================================================================
--- incubator/harmony/enhanced/classlib/trunk/modules/sql/META-INF/MANIFEST.MF (original)
+++ incubator/harmony/enhanced/classlib/trunk/modules/sql/META-INF/MANIFEST.MF Fri Nov  3 22:57:27 2006
@@ -21,11 +21,15 @@
  java.text,
  java.util,
  java.util.jar;resolution:=optional,
+ java.util.logging,
  java.util.zip;resolution:=optional,
+ javax.naming,
  org.apache.harmony.kernel.vm,
  org.apache.harmony.luni.util,
  org.apache.harmony.testframework.serialization;hy_usage=test;resolution:=optional
 Export-Package: java.sql,
  javax.sql,
+ javax.sql.rowset,
+ javax.sql.rowset.spi,
  javax.transaction,
  javax.transaction.xa

Added: incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/CachedRowSet.java
URL: http://svn.apache.org/viewvc/incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/CachedRowSet.java?view=auto&rev=471131
==============================================================================
--- incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/CachedRowSet.java (added)
+++ incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/CachedRowSet.java Fri Nov  3 22:57:27 2006
@@ -0,0 +1,115 @@
+/*
+ *  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 javax.sql.rowset;
+
+import java.sql.Connection;
+import java.sql.ResultSet;
+import java.sql.SQLException;
+import java.sql.Savepoint;
+import java.util.Collection;
+import javax.sql.RowSet;
+import javax.sql.RowSetEvent;
+import javax.sql.RowSetMetaData;
+import javax.sql.rowset.spi.SyncProvider;
+import javax.sql.rowset.spi.SyncProviderException;
+
+public interface CachedRowSet extends Joinable, ResultSet, RowSet {
+    boolean COMMIT_ON_ACCEPT_CHANGES = true;
+
+    void populate(ResultSet data) throws SQLException;
+
+    void execute(Connection conn) throws SQLException;
+
+    void acceptChanges() throws SyncProviderException;
+
+    void acceptChanges(Connection con) throws SyncProviderException;
+
+    void restoreOriginal() throws SQLException;
+
+    void release() throws SQLException;
+
+    void undoDelete() throws SQLException;
+
+    void undoInsert() throws SQLException;
+
+    void undoUpdate() throws SQLException;
+
+    boolean columnUpdated(int idx) throws SQLException;
+
+    boolean columnUpdated(String columnName) throws SQLException;
+
+    Collection<?> toCollection() throws SQLException;
+
+    Collection<?> toCollection(int column) throws SQLException;
+
+    Collection<?> toCollection(String column) throws SQLException;
+
+    SyncProvider getSyncProvider() throws SQLException;
+
+    void setSyncProvider(String provider) throws SQLException;
+
+    int size();
+
+    void setMetaData(RowSetMetaData md) throws SQLException;
+
+    ResultSet getOriginal() throws SQLException;
+
+    ResultSet getOriginalRow() throws SQLException;
+
+    void setOriginalRow() throws SQLException;
+
+    String getTableName() throws SQLException;
+
+    void setTableName(String tabName) throws SQLException;
+
+    int[] getKeyColumns() throws SQLException;
+
+    void setKeyColumns(int[] keys) throws SQLException;
+
+    RowSet createShared() throws SQLException;
+
+    CachedRowSet createCopy() throws SQLException;
+
+    CachedRowSet createCopySchema() throws SQLException;
+
+    CachedRowSet createCopyNoConstraints() throws SQLException;
+
+    RowSetWarning getRowSetWarnings() throws SQLException;
+
+    boolean getShowDeleted() throws SQLException;
+
+    void setShowDeleted(boolean b) throws SQLException;
+
+    void commit() throws SQLException;
+
+    void rollback() throws SQLException;
+
+    void rollback(Savepoint s) throws SQLException;
+
+    void rowSetPopulated(RowSetEvent event, int numRows) throws SQLException;
+
+    void populate(ResultSet rs, int startRow) throws SQLException;
+
+    void setPageSize(int size) throws SQLException;
+
+    int getPageSize();
+
+    boolean nextPage() throws SQLException;
+
+    boolean previousPage() throws SQLException;
+}

Propchange: incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/CachedRowSet.java
------------------------------------------------------------------------------
    svn:eol-style = native

Added: incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/FilteredRowSet.java
URL: http://svn.apache.org/viewvc/incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/FilteredRowSet.java?view=auto&rev=471131
==============================================================================
--- incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/FilteredRowSet.java (added)
+++ incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/FilteredRowSet.java Fri Nov  3 22:57:27 2006
@@ -0,0 +1,26 @@
+/*
+ *  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 javax.sql.rowset;
+
+import java.sql.SQLException;
+
+public interface FilteredRowSet extends WebRowSet {
+    void setFilter(Predicate p) throws SQLException;
+
+    Predicate getFilter();
+}

Propchange: incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/FilteredRowSet.java
------------------------------------------------------------------------------
    svn:eol-style = native

Added: incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/JdbcRowSet.java
URL: http://svn.apache.org/viewvc/incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/JdbcRowSet.java?view=auto&rev=471131
==============================================================================
--- incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/JdbcRowSet.java (added)
+++ incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/JdbcRowSet.java Fri Nov  3 22:57:27 2006
@@ -0,0 +1,41 @@
+/*
+ *  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 javax.sql.rowset;
+
+import java.sql.ResultSet;
+import java.sql.SQLException;
+import java.sql.Savepoint;
+import javax.sql.RowSet;
+
+public interface JdbcRowSet extends Joinable, ResultSet, RowSet {
+    boolean getShowDeleted() throws SQLException;
+
+    void setShowDeleted(boolean b) throws SQLException;
+
+    RowSetWarning getRowSetWarnings() throws SQLException;
+
+    void commit() throws SQLException;
+
+    boolean getAutoCommit() throws SQLException;
+
+    void setAutoCommit(boolean autoCommit) throws SQLException;
+
+    void rollback() throws SQLException;
+
+    void rollback(Savepoint s) throws SQLException;
+}

Propchange: incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/JdbcRowSet.java
------------------------------------------------------------------------------
    svn:eol-style = native

Added: incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/JoinRowSet.java
URL: http://svn.apache.org/viewvc/incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/JoinRowSet.java?view=auto&rev=471131
==============================================================================
--- incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/JoinRowSet.java (added)
+++ incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/JoinRowSet.java Fri Nov  3 22:57:27 2006
@@ -0,0 +1,66 @@
+/*
+ *  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 javax.sql.rowset;
+
+import java.sql.SQLException;
+import java.util.Collection;
+import javax.sql.RowSet;
+
+public interface JoinRowSet extends WebRowSet {
+    int CROSS_JOIN = 0;
+
+    int INNER_JOIN = 1;
+
+    int LEFT_OUTER_JOIN = 2;
+
+    int RIGHT_OUTER_JOIN = 3;
+
+    int FULL_JOIN = 4;
+
+    void addRowSet(Joinable rowset) throws SQLException;
+
+    void addRowSet(RowSet rowset, int columnIdx) throws SQLException;
+
+    void addRowSet(RowSet rowset, String columnName) throws SQLException;
+
+    void addRowSet(RowSet[] rowset, int[] columnIdx) throws SQLException;
+
+    void addRowSet(RowSet[] rowset, String[] columnName) throws SQLException;
+
+    Collection<?> getRowSets() throws SQLException;
+
+    String[] getRowSetNames() throws SQLException;
+
+    CachedRowSet toCachedRowSet() throws SQLException;
+
+    boolean supportsCrossJoin();
+
+    boolean supportsInnerJoin();
+
+    boolean supportsLeftOuterJoin();
+
+    boolean supportsRightOuterJoin();
+
+    boolean supportsFullJoin();
+
+    void setJoinType(int joinType) throws SQLException;
+
+    String getWhereClause() throws SQLException;
+
+    int getJoinType() throws SQLException;
+}

Propchange: incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/JoinRowSet.java
------------------------------------------------------------------------------
    svn:eol-style = native

Added: incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/Joinable.java
URL: http://svn.apache.org/viewvc/incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/Joinable.java?view=auto&rev=471131
==============================================================================
--- incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/Joinable.java (added)
+++ incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/Joinable.java Fri Nov  3 22:57:27 2006
@@ -0,0 +1,42 @@
+/*
+ *  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 javax.sql.rowset;
+
+import java.sql.SQLException;
+
+public interface Joinable {
+    int[] getMatchColumnIndexes() throws SQLException;
+
+    String[] getMatchColumnNames() throws SQLException;
+
+    void setMatchColumn(int columnIdx) throws SQLException;
+
+    void setMatchColumn(int[] columnIdxes) throws SQLException;
+
+    void setMatchColumn(String columnName) throws SQLException;
+
+    void setMatchColumn(String[] columnNames) throws SQLException;
+
+    void unsetMatchColumn(int columnIdx) throws SQLException;
+
+    void unsetMatchColumn(int[] columnIdxes) throws SQLException;
+
+    void unsetMatchColumn(String columnName) throws SQLException;
+
+    void unsetMatchColumn(String[] columnName) throws SQLException;
+}

Propchange: incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/Joinable.java
------------------------------------------------------------------------------
    svn:eol-style = native

Added: incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/Predicate.java
URL: http://svn.apache.org/viewvc/incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/Predicate.java?view=auto&rev=471131
==============================================================================
--- incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/Predicate.java (added)
+++ incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/Predicate.java Fri Nov  3 22:57:27 2006
@@ -0,0 +1,29 @@
+/*
+ *  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 javax.sql.rowset;
+
+import java.sql.SQLException;
+import javax.sql.RowSet;
+
+public interface Predicate {
+    boolean evaluate(RowSet rs);
+
+    boolean evaluate(Object value, int column) throws SQLException;
+
+    boolean evaluate(Object value, String columnName) throws SQLException;
+}

Propchange: incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/Predicate.java
------------------------------------------------------------------------------
    svn:eol-style = native

Added: incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/RowSetWarning.java
URL: http://svn.apache.org/viewvc/incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/RowSetWarning.java?view=auto&rev=471131
==============================================================================
--- incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/RowSetWarning.java (added)
+++ incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/RowSetWarning.java Fri Nov  3 22:57:27 2006
@@ -0,0 +1,50 @@
+/*
+ *  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 javax.sql.rowset;
+
+import java.sql.SQLException;
+
+public class RowSetWarning extends SQLException {
+    private static final long serialVersionUID = 6678332766434564774L;
+
+    private RowSetWarning rwarning;
+
+    public RowSetWarning() {
+        super();
+    }
+
+    public RowSetWarning(String reason) {
+        super(reason);
+    }
+
+    public RowSetWarning(String reason, String sqlState) {
+        super(reason, sqlState);
+    }
+
+    public RowSetWarning(String reason, String sqlState, int vendorCode) {
+        super(reason, sqlState, vendorCode);
+    }
+
+    public RowSetWarning getNextWarning() {
+        return rwarning;
+    }
+
+    public void setNextWarning(RowSetWarning nextWarning) {
+        this.rwarning = nextWarning;
+    }
+}

Propchange: incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/RowSetWarning.java
------------------------------------------------------------------------------
    svn:eol-style = native

Added: incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/WebRowSet.java
URL: http://svn.apache.org/viewvc/incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/WebRowSet.java?view=auto&rev=471131
==============================================================================
--- incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/WebRowSet.java (added)
+++ incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/WebRowSet.java Fri Nov  3 22:57:27 2006
@@ -0,0 +1,45 @@
+/*
+ *  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 javax.sql.rowset;
+
+import java.io.IOException;
+import java.io.InputStream;
+import java.io.OutputStream;
+import java.io.Reader;
+import java.io.Writer;
+import java.sql.ResultSet;
+import java.sql.SQLException;
+import javax.sql.RowSet;
+
+public interface WebRowSet extends CachedRowSet, Joinable, ResultSet, RowSet {
+    String PUBLIC_XML_SCHEMA = "--//Sun Microsystems, Inc.//XSD Schema//EN";
+
+    String SCHEMA_SYSTEM_ID = "http://java.sun.com/xml/ns/jdbc/webrowset.xsd";
+
+    void readXml(Reader reader) throws SQLException;
+
+    void readXml(InputStream iStream) throws SQLException, IOException;
+
+    void writeXml(ResultSet rs, Writer writer) throws SQLException;
+
+    void writeXml(ResultSet rs, OutputStream oStream) throws SQLException, IOException;
+
+    void writeXml(Writer writer) throws SQLException;
+
+    void writeXml(OutputStream oStream) throws SQLException, IOException;
+}

Propchange: incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/WebRowSet.java
------------------------------------------------------------------------------
    svn:eol-style = native

Added: incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/SyncFactory.java
URL: http://svn.apache.org/viewvc/incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/SyncFactory.java?view=auto&rev=471131
==============================================================================
--- incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/SyncFactory.java (added)
+++ incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/SyncFactory.java Fri Nov  3 22:57:27 2006
@@ -0,0 +1,68 @@
+/*
+ *  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 javax.sql.rowset.spi;
+
+import java.util.Enumeration;
+import java.util.logging.Level;
+import java.util.logging.Logger;
+import javax.naming.Context;
+
+public class SyncFactory {
+    public static String ROWSET_SYNC_PROVIDER = "rowset.provider.classname";
+
+    public static String ROWSET_SYNC_VENDOR = "rowset.provider.vendor";
+
+    public static String ROWSET_SYNC_PROVIDER_VERSION = "rowset.provider.version";
+
+    public static void registerProvider(String providerID) throws SyncFactoryException {
+        throw new UnsupportedOperationException();
+    }
+
+    public static SyncFactory getSyncFactory() {
+        throw new UnsupportedOperationException();
+    }
+
+    public static void unregisterProvider(String providerID) throws SyncFactoryException {
+        throw new UnsupportedOperationException();
+    }
+
+    public static SyncProvider getInstance(String providerID) throws SyncFactoryException {
+        throw new UnsupportedOperationException();
+    }
+
+    public static Enumeration<SyncProvider> getRegisteredProviders()
+            throws SyncFactoryException {
+        throw new UnsupportedOperationException();
+    }
+
+    public static void setLogger(Logger logger) {
+        throw new UnsupportedOperationException();
+    }
+
+    public static void setLogger(Logger logger, Level level) {
+        throw new UnsupportedOperationException();
+    }
+
+    public static Logger getLogger() throws SyncFactoryException {
+        throw new UnsupportedOperationException();
+    }
+
+    public static void setJNDIContext(Context ctx) throws SyncFactoryException {
+        throw new UnsupportedOperationException();
+    }
+}

Propchange: incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/SyncFactory.java
------------------------------------------------------------------------------
    svn:eol-style = native

Added: incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/SyncFactoryException.java
URL: http://svn.apache.org/viewvc/incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/SyncFactoryException.java?view=auto&rev=471131
==============================================================================
--- incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/SyncFactoryException.java (added)
+++ incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/SyncFactoryException.java Fri Nov  3 22:57:27 2006
@@ -0,0 +1,32 @@
+/*
+ *  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 javax.sql.rowset.spi;
+
+import java.sql.SQLException;
+
+public class SyncFactoryException extends SQLException {
+    private static final long serialVersionUID = -4354595476433200352L;
+
+    public SyncFactoryException() {
+        super();
+    }
+
+    public SyncFactoryException(String msg) {
+        super(msg);
+    }
+}

Propchange: incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/SyncFactoryException.java
------------------------------------------------------------------------------
    svn:eol-style = native

Added: incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/SyncProvider.java
URL: http://svn.apache.org/viewvc/incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/SyncProvider.java?view=auto&rev=471131
==============================================================================
--- incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/SyncProvider.java (added)
+++ incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/SyncProvider.java Fri Nov  3 22:57:27 2006
@@ -0,0 +1,67 @@
+/*
+ *  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 javax.sql.rowset.spi;
+
+import javax.sql.RowSetReader;
+import javax.sql.RowSetWriter;
+
+public abstract class SyncProvider {
+    public static int GRADE_NONE = 1;
+
+    public static int GRADE_CHECK_MODIFIED_AT_COMMIT = 2;
+
+    public static int GRADE_CHECK_ALL_AT_COMMIT = 3;
+
+    public static int GRADE_LOCK_WHEN_MODIFIED = 4;
+
+    public static int GRADE_LOCK_WHEN_LOADED = 5;
+
+    public static int DATASOURCE_NO_LOCK = 1;
+
+    public static int DATASOURCE_ROW_LOCK = 2;
+
+    public static int DATASOURCE_TABLE_LOCK = 3;
+
+    public static int DATASOURCE_DB_LOCK = 4;
+
+    public static int UPDATABLE_VIEW_SYNC = 5;
+
+    public static int NONUPDATABLE_VIEW_SYNC = 6;
+
+    public SyncProvider() {
+        super();
+    }
+
+    public abstract String getProviderID();
+
+    public abstract RowSetReader getRowSetReader();
+
+    public abstract RowSetWriter getRowSetWriter();
+
+    public abstract int getProviderGrade();
+
+    public abstract void setDataSourceLock(int dataSourceLock) throws SyncProviderException;
+
+    public abstract int getDataSourceLock() throws SyncProviderException;
+
+    public abstract int supportsUpdatableView();
+
+    public abstract String getVersion();
+
+    public abstract String getVendor();
+}

Propchange: incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/SyncProvider.java
------------------------------------------------------------------------------
    svn:eol-style = native

Added: incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/SyncProviderException.java
URL: http://svn.apache.org/viewvc/incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/SyncProviderException.java?view=auto&rev=471131
==============================================================================
--- incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/SyncProviderException.java (added)
+++ incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/SyncProviderException.java Fri Nov  3 22:57:27 2006
@@ -0,0 +1,53 @@
+/*
+ *  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 javax.sql.rowset.spi;
+
+import java.sql.SQLException;
+
+public class SyncProviderException extends SQLException {
+    private static final long serialVersionUID = -939908523620640692L;
+
+    private SyncResolver syncResolver;
+
+    public SyncProviderException() {
+        super();
+    }
+
+    public SyncProviderException(String msg) {
+        super(msg);
+    }
+
+    public SyncProviderException(SyncResolver syncResolver) {
+        super();
+        if (syncResolver == null) {
+            throw new IllegalArgumentException();
+        }
+        this.syncResolver = syncResolver;
+    }
+
+    public SyncResolver getSyncResolver() {
+        return syncResolver;
+    }
+
+    public void setSyncResolver(SyncResolver syncResolver) {
+        if (syncResolver == null) {
+            throw new IllegalArgumentException();
+        }
+        this.syncResolver = syncResolver;
+    }
+}

Propchange: incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/SyncProviderException.java
------------------------------------------------------------------------------
    svn:eol-style = native

Added: incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/SyncResolver.java
URL: http://svn.apache.org/viewvc/incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/SyncResolver.java?view=auto&rev=471131
==============================================================================
--- incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/SyncResolver.java (added)
+++ incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/SyncResolver.java Fri Nov  3 22:57:27 2006
@@ -0,0 +1,45 @@
+/*
+ *  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 javax.sql.rowset.spi;
+
+import java.sql.SQLException;
+import javax.sql.RowSet;
+
+public interface SyncResolver extends RowSet {
+    int UPDATE_ROW_CONFLICT = 0;
+
+    int DELETE_ROW_CONFLICT = 1;
+
+    int INSERT_ROW_CONFLICT = 2;
+
+    int NO_ROW_CONFLICT = 3;
+
+    int getStatus();
+
+    Object getConflictValue(int index) throws SQLException;
+
+    Object getConflictValue(String columnName) throws SQLException;
+
+    void setResolvedValue(int index, Object obj) throws SQLException;
+
+    void setResolvedValue(String columnName, Object obj) throws SQLException;
+
+    boolean nextConflict() throws SQLException;
+
+    boolean previousConflict() throws SQLException;
+}

Propchange: incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/SyncResolver.java
------------------------------------------------------------------------------
    svn:eol-style = native

Added: incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/TransactionalWriter.java
URL: http://svn.apache.org/viewvc/incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/TransactionalWriter.java?view=auto&rev=471131
==============================================================================
--- incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/TransactionalWriter.java (added)
+++ incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/TransactionalWriter.java Fri Nov  3 22:57:27 2006
@@ -0,0 +1,30 @@
+/*
+ *  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 javax.sql.rowset.spi;
+
+import java.sql.SQLException;
+import java.sql.Savepoint;
+import javax.sql.RowSetWriter;
+
+public interface TransactionalWriter extends RowSetWriter {
+    void commit() throws SQLException;
+
+    void rollback() throws SQLException;
+
+    void rollback(Savepoint s) throws SQLException;
+}

Propchange: incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/TransactionalWriter.java
------------------------------------------------------------------------------
    svn:eol-style = native

Added: incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/XmlReader.java
URL: http://svn.apache.org/viewvc/incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/XmlReader.java?view=auto&rev=471131
==============================================================================
--- incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/XmlReader.java (added)
+++ incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/XmlReader.java Fri Nov  3 22:57:27 2006
@@ -0,0 +1,27 @@
+/*
+ *  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 javax.sql.rowset.spi;
+
+import java.io.Reader;
+import java.sql.SQLException;
+import javax.sql.RowSetReader;
+import javax.sql.rowset.WebRowSet;
+
+public interface XmlReader extends RowSetReader {
+    void readXML(WebRowSet caller, Reader reader) throws SQLException;
+}

Propchange: incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/XmlReader.java
------------------------------------------------------------------------------
    svn:eol-style = native

Added: incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/XmlWriter.java
URL: http://svn.apache.org/viewvc/incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/XmlWriter.java?view=auto&rev=471131
==============================================================================
--- incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/XmlWriter.java (added)
+++ incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/XmlWriter.java Fri Nov  3 22:57:27 2006
@@ -0,0 +1,27 @@
+/*
+ *  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 javax.sql.rowset.spi;
+
+import java.io.Writer;
+import java.sql.SQLException;
+import javax.sql.RowSetWriter;
+import javax.sql.rowset.WebRowSet;
+
+public interface XmlWriter extends RowSetWriter {
+    void writeXML(WebRowSet caller, Writer writer) throws SQLException;
+}

Propchange: incubator/harmony/enhanced/classlib/trunk/modules/sql/src/main/java/javax/sql/rowset/spi/XmlWriter.java
------------------------------------------------------------------------------
    svn:eol-style = native