You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@sqoop.apache.org by an...@apache.org on 2018/01/18 14:04:15 UTC

[29/32] sqoop git commit: SQOOP-3273: Removing com.cloudera.sqoop packages

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/mapreduce/db/DBConfiguration.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/mapreduce/db/DBConfiguration.java b/src/java/com/cloudera/sqoop/mapreduce/db/DBConfiguration.java
deleted file mode 100644
index 89f2b4f..0000000
--- a/src/java/com/cloudera/sqoop/mapreduce/db/DBConfiguration.java
+++ /dev/null
@@ -1,165 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.mapreduce.db;
-
-import org.apache.hadoop.conf.Configuration;
-
-/**
- * A container for configuration property names for jobs with DB input/output.
- *
- * The job can be configured using the static methods in this class,
- * {@link DBInputFormat}, and {@link DBOutputFormat}.
- * Alternatively, the properties can be set in the configuration with proper
- * values.
- *
- * @see DBConfiguration#configureDB(Configuration, String, String, String,
- * String)
- * @see DBInputFormat#setInput(Job, Class, String, String)
- * @see DBInputFormat#setInput(Job, Class, String, String, String, String...)
- * @see DBOutputFormat#setOutput(Job, String, String...)
- *
- * @deprecated use org.apache.sqoop.mapreduce.db.DBConfiguration instead.
- * @see org.apache.sqoop.mapreduce.db.DBConfiguration
- */
-public class DBConfiguration
-  extends org.apache.sqoop.mapreduce.db.DBConfiguration {
-
-  /** The JDBC Driver class name. */
-  public static final String DRIVER_CLASS_PROPERTY =
-      org.apache.sqoop.mapreduce.db.DBConfiguration.DRIVER_CLASS_PROPERTY;
-
-  /** JDBC Database access URL. */
-  public static final String URL_PROPERTY =
-      org.apache.sqoop.mapreduce.db.DBConfiguration.URL_PROPERTY;
-
-  /** User name to access the database. */
-  public static final String USERNAME_PROPERTY =
-      org.apache.sqoop.mapreduce.db.DBConfiguration.USERNAME_PROPERTY;
-
-  /** Password to access the database. */
-  public static final String PASSWORD_PROPERTY =
-      org.apache.sqoop.mapreduce.db.DBConfiguration.PASSWORD_PROPERTY;
-
-  /** Fetch size. */
-  public static final String FETCH_SIZE =
-      org.apache.sqoop.mapreduce.db.DBConfiguration.FETCH_SIZE;
-
-  /** Input table name. */
-  public static final String INPUT_TABLE_NAME_PROPERTY =
-      org.apache.sqoop.mapreduce.db.DBConfiguration.INPUT_TABLE_NAME_PROPERTY;
-
-  /** Field names in the Input table. */
-  public static final String INPUT_FIELD_NAMES_PROPERTY =
-      org.apache.sqoop.mapreduce.db.DBConfiguration.INPUT_FIELD_NAMES_PROPERTY;
-
-  /** WHERE clause in the input SELECT statement. */
-  public static final String INPUT_CONDITIONS_PROPERTY =
-      org.apache.sqoop.mapreduce.db.DBConfiguration.INPUT_CONDITIONS_PROPERTY;
-
-  /** ORDER BY clause in the input SELECT statement. */
-  public static final String INPUT_ORDER_BY_PROPERTY =
-      org.apache.sqoop.mapreduce.db.DBConfiguration.INPUT_ORDER_BY_PROPERTY;
-
-  /** Whole input query, exluding LIMIT...OFFSET. */
-  public static final String INPUT_QUERY =
-      org.apache.sqoop.mapreduce.db.DBConfiguration.INPUT_QUERY;
-
-  /** Input query to get the count of records. */
-  public static final String INPUT_COUNT_QUERY =
-      org.apache.sqoop.mapreduce.db.DBConfiguration.INPUT_COUNT_QUERY;
-
-  /** Input query to get the max and min values of the jdbc.input.query. */
-  public static final String INPUT_BOUNDING_QUERY =
-      org.apache.sqoop.mapreduce.db.DBConfiguration.INPUT_BOUNDING_QUERY;
-
-  /** Class name implementing DBWritable which will hold input tuples. */
-  public static final String INPUT_CLASS_PROPERTY =
-      org.apache.sqoop.mapreduce.db.DBConfiguration.INPUT_CLASS_PROPERTY;
-
-  /** Output table name. */
-  public static final String OUTPUT_TABLE_NAME_PROPERTY =
-      org.apache.sqoop.mapreduce.db.DBConfiguration.OUTPUT_TABLE_NAME_PROPERTY;
-
-  /** Field names in the Output table. */
-  public static final String OUTPUT_FIELD_NAMES_PROPERTY =
-      org.apache.sqoop.mapreduce.db.DBConfiguration.OUTPUT_FIELD_NAMES_PROPERTY;
-
-  /** Number of fields in the Output table. */
-  public static final String OUTPUT_FIELD_COUNT_PROPERTY =
-      org.apache.sqoop.mapreduce.db.DBConfiguration.OUTPUT_FIELD_COUNT_PROPERTY;
-
-  /**
-   * Sets the DB access related fields in the {@link Configuration}.
-   * @param conf the configuration
-   * @param driverClass JDBC Driver class name
-   * @param dbUrl JDBC DB access URL
-   * @param userName DB access username
-   * @param passwd DB access passwd
-   * @param fetchSize DB fetch size
-   */
-  public static void configureDB(Configuration conf, String driverClass,
-      String dbUrl, String userName, String passwd, Integer fetchSize) {
-
-    org.apache.sqoop.mapreduce.db.DBConfiguration.configureDB(
-        conf, driverClass, dbUrl, userName, passwd, fetchSize);
-  }
-
-  /**
-   * Sets the DB access related fields in the JobConf.
-   * @param job the job
-   * @param driverClass JDBC Driver class name
-   * @param dbUrl JDBC DB access URL
-   * @param fetchSize DB fetch size
-   */
-  public static void configureDB(Configuration job, String driverClass,
-      String dbUrl, Integer fetchSize) {
-    org.apache.sqoop.mapreduce.db.DBConfiguration.configureDB(job, driverClass,
-        dbUrl, fetchSize);
-  }
-
-  /**
-   * Sets the DB access related fields in the {@link Configuration}.
-   * @param conf the configuration
-   * @param driverClass JDBC Driver class name
-   * @param dbUrl JDBC DB access URL
-   * @param userName DB access username
-   * @param passwd DB access passwd
-   */
-  public static void configureDB(Configuration conf, String driverClass,
-      String dbUrl, String userName, String passwd) {
-    org.apache.sqoop.mapreduce.db.DBConfiguration.configureDB(conf, driverClass,
-        dbUrl, userName, passwd);
-  }
-
-  /**
-   * Sets the DB access related fields in the JobConf.
-   * @param job the job
-   * @param driverClass JDBC Driver class name
-   * @param dbUrl JDBC DB access URL.
-   */
-  public static void configureDB(Configuration job, String driverClass,
-      String dbUrl) {
-    org.apache.sqoop.mapreduce.db.DBConfiguration.configureDB(job, driverClass,
-        dbUrl);
-  }
-
-  public DBConfiguration(Configuration job) {
-    super(job);
-  }
-}
-

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/mapreduce/db/DBInputFormat.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/mapreduce/db/DBInputFormat.java b/src/java/com/cloudera/sqoop/mapreduce/db/DBInputFormat.java
deleted file mode 100644
index 90c1b24..0000000
--- a/src/java/com/cloudera/sqoop/mapreduce/db/DBInputFormat.java
+++ /dev/null
@@ -1,73 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.mapreduce.db;
-
-import org.apache.sqoop.mapreduce.DBWritable;
-
-/**
- * A InputFormat that reads input data from an SQL table.
- * <p>
- * DBInputFormat emits LongWritables containing the record number as
- * key and DBWritables as value.
- *
- * The SQL query, and input class can be using one of the two
- * setInput methods.
- *
- * @deprecated use org.apache.sqoop.mapreduce.db.DBInputFormat instead.
- * @see org.apache.sqoop.mapreduce.db.DBInputFormat
- */
-public class DBInputFormat<T extends DBWritable>
-    extends org.apache.sqoop.mapreduce.db.DBInputFormat<T> {
-
-  /**
-   * A Class that does nothing, implementing DBWritable.
-   * @deprecated use org.apache.sqoop.mapreduce.db.DBInputFormat.NullDBWritable
-   *   instead.
-   * @see org.apache.sqoop.mapreduce.db.DBInputFormat.NullDBWritable
-   */
-  public static class NullDBWritable
-    extends org.apache.sqoop.mapreduce.db.DBInputFormat.NullDBWritable {
-  }
-
-  /**
-   * A InputSplit that spans a set of rows.
-   *
-   * @deprecated use org.apache.sqoop.mapreduce.db.DBInputFormat.DBInputSplit
-   *   instead.
-   * @see org.apache.sqoop.mapreduce.db.DBInputFormat.DBInputSplit
-   */
-  public static class DBInputSplit extends
-    org.apache.sqoop.mapreduce.db.DBInputFormat.DBInputSplit {
-
-    /**
-     * Default Constructor.
-     */
-    public DBInputSplit() {
-      super();
-    }
-
-    /**
-     * Convenience Constructor.
-     * @param start the index of the first row to select
-     * @param end the index of the last row to select
-     */
-    public DBInputSplit(long start, long end) {
-      super(start, end);
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/mapreduce/db/DBOutputFormat.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/mapreduce/db/DBOutputFormat.java b/src/java/com/cloudera/sqoop/mapreduce/db/DBOutputFormat.java
deleted file mode 100644
index e68adb9..0000000
--- a/src/java/com/cloudera/sqoop/mapreduce/db/DBOutputFormat.java
+++ /dev/null
@@ -1,58 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.mapreduce.db;
-
-import java.sql.Connection;
-import java.sql.PreparedStatement;
-import java.sql.SQLException;
-
-import org.apache.sqoop.mapreduce.DBWritable;
-
-/**
- * A OutputFormat that sends the reduce output to a SQL table.
- * <p>
- * {@link DBOutputFormat} accepts &lt;key,value&gt; pairs, where
- * key has a type extending DBWritable. Returned {@link RecordWriter}
- * writes <b>only the key</b> to the database with a batch SQL query.
- *
- * @deprecated use org.apache.sqoop.mapreduce.db.DBoutputFormat instead.
- * @see org.apache.sqoop.mapreduce.db.DBOutputFormat
- */
-public class DBOutputFormat<K extends DBWritable, V>
-    extends org.apache.sqoop.mapreduce.db.DBOutputFormat<K, V> {
-
-  /**
-   * A RecordWriter that writes the reduce output to a SQL table.
-   *
-   * @deprecated use
-   *   org.apache.sqoop.mapreduce.db.DBOutputFormat.DBRecordWriter instead.
-   * @see org.apache.sqoop.mapreduce.db.DBOutputFormat.DBRecordWriter
-   */
-  public static class DBRecordWriter<K extends DBWritable, V> extends
-    org.apache.sqoop.mapreduce.db.DBOutputFormat.DBRecordWriter<K, V> {
-
-    public DBRecordWriter() throws SQLException {
-      super();
-    }
-
-    public DBRecordWriter(Connection connection,
-        PreparedStatement statement) throws SQLException {
-      super(connection, statement);
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/mapreduce/db/DBRecordReader.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/mapreduce/db/DBRecordReader.java b/src/java/com/cloudera/sqoop/mapreduce/db/DBRecordReader.java
deleted file mode 100644
index 2f6a897..0000000
--- a/src/java/com/cloudera/sqoop/mapreduce/db/DBRecordReader.java
+++ /dev/null
@@ -1,50 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.mapreduce.db;
-
-import java.sql.Connection;
-import java.sql.SQLException;
-
-import org.apache.hadoop.conf.Configuration;
-import org.apache.sqoop.mapreduce.DBWritable;
-
-/**
- * A RecordReader that reads records from a SQL table.
- * Emits LongWritables containing the record number as
- * key and DBWritables as value.
- *
- * @deprecated use org.apache.sqoop.mapreduce.db.DBRecordReader instead.
- * @see org.apache.sqoop.mapreduce.db.DBRecordReader
- */
-public class DBRecordReader<T extends DBWritable> extends
-    org.apache.sqoop.mapreduce.db.DBRecordReader<T> {
-
-  /**
-   * @param split The InputSplit to read data for
-   * @throws SQLException
-   */
-  // CHECKSTYLE:OFF
-  // TODO (aaron): Refactor constructor to take fewer arguments
-  public DBRecordReader(DBInputFormat.DBInputSplit split,
-      Class<T> inputClass, Configuration conf, Connection conn,
-      DBConfiguration dbConfig, String cond, String [] fields, String table)
-      throws SQLException {
-    super(split, inputClass, conf, conn, dbConfig, cond, fields, table);
-  }
-  // CHECKSTYLE:ON
-}

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/mapreduce/db/DBSplitter.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/mapreduce/db/DBSplitter.java b/src/java/com/cloudera/sqoop/mapreduce/db/DBSplitter.java
deleted file mode 100644
index 6abeeba..0000000
--- a/src/java/com/cloudera/sqoop/mapreduce/db/DBSplitter.java
+++ /dev/null
@@ -1,34 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.mapreduce.db;
-
-
-/**
- * DBSplitter will generate DBInputSplits to use with DataDrivenDBInputFormat.
- * DataDrivenDBInputFormat needs to interpolate between two values that
- * represent the lowest and highest valued records to import. Depending
- * on the data-type of the column, this requires different behavior.
- * DBSplitter implementations should perform this for a data type or family
- * of data types.
- *
- * @deprecated use org.apache.sqoop.mapreduce.db.DBSplitter instead.
- * @see org.apache.sqoop.mapreduce.db.DBSplitter
- */
-public interface DBSplitter extends org.apache.sqoop.mapreduce.db.DBSplitter {
-
-}

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/mapreduce/db/DataDrivenDBInputFormat.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/mapreduce/db/DataDrivenDBInputFormat.java b/src/java/com/cloudera/sqoop/mapreduce/db/DataDrivenDBInputFormat.java
deleted file mode 100644
index 4cdb218..0000000
--- a/src/java/com/cloudera/sqoop/mapreduce/db/DataDrivenDBInputFormat.java
+++ /dev/null
@@ -1,113 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.mapreduce.db;
-
-import org.apache.hadoop.conf.Configuration;
-import org.apache.hadoop.mapreduce.Job;
-import org.apache.sqoop.mapreduce.DBWritable;
-
-/**
- * A InputFormat that reads input data from an SQL table.
- * Operates like DBInputFormat, but instead of using LIMIT and OFFSET to
- * demarcate splits, it tries to generate WHERE clauses which separate the
- * data into roughly equivalent shards.
- *
- * @deprecated use org.apache.sqoop.mapreduce.db.DataDrivenDBInputFormat instead
- * @see org.apache.sqoop.mapreduce.db.DataDrivenDBInputFormat
- */
-public class DataDrivenDBInputFormat<T extends DBWritable>
-    extends org.apache.sqoop.mapreduce.db.DataDrivenDBInputFormat<T> {
-
-  /**
-   * If users are providing their own query, the following string is expected
-   * to appear in the WHERE clause, which will be substituted with a pair of
-   * conditions on the input to allow input splits to parallelise the import.
-   */
-  public static final String SUBSTITUTE_TOKEN =
-      org.apache.sqoop.mapreduce.db.DataDrivenDBInputFormat.SUBSTITUTE_TOKEN;
-
-  /**
-   * A InputSplit that spans a set of rows.
-   *
-   * @deprecated use org.apache.sqoop.mapreduce.db.DataDrivenDBInputFormat.
-   *   DataDrivenDBInputSplit instead.
-   * @see org.apache.sqoop.mapreduce.db.DataDrivenDBInputFormat.
-   *      DataDrivenDBInputSplit
-   */
-  public static class DataDrivenDBInputSplit extends
-  org.apache.sqoop.mapreduce.db.DataDrivenDBInputFormat.DataDrivenDBInputSplit {
-
-    /**
-     * Default Constructor.
-     */
-    public DataDrivenDBInputSplit() {
-      super();
-    }
-
-    /**
-     * Convenience Constructor.
-     * @param lower the string to be put in the WHERE clause to guard
-     * on the 'lower' end.
-     * @param upper the string to be put in the WHERE clause to guard
-     * on the 'upper' end.
-     */
-    public DataDrivenDBInputSplit(final String lower, final String upper) {
-      super(lower, upper);
-    }
-  }
-
-
-  /** Set the user-defined bounding query to use with a user-defined query.
-      This *must* include the substring "$CONDITIONS"
-      (DataDrivenDBInputFormat.SUBSTITUTE_TOKEN) inside the WHERE clause,
-      so that DataDrivenDBInputFormat knows where to insert split clauses.
-      e.g., "SELECT foo FROM mytable WHERE $CONDITIONS"
-      This will be expanded to something like:
-        SELECT foo FROM mytable WHERE (id &gt; 100) AND (id &lt; 250)
-      inside each split.
-    */
-  public static void setBoundingQuery(Configuration conf, String query) {
-    org.apache.sqoop.mapreduce.db.DataDrivenDBInputFormat.setBoundingQuery(
-        conf, query);
-  }
-
-  // Configuration methods override superclass to ensure that the proper
-  // DataDrivenDBInputFormat gets used.
-
-  /** Note that the "orderBy" column is called the "splitBy" in this version.
-    * We reuse the same field, but it's not strictly ordering it
-    * -- just partitioning the results.
-    */
-  public static void setInput(Job job,
-      Class<? extends DBWritable> inputClass,
-      String tableName, String conditions,
-      String splitBy, String... fieldNames) {
-    org.apache.sqoop.mapreduce.db.DataDrivenDBInputFormat.setInput(
-        job, inputClass, tableName, conditions, splitBy, fieldNames);
-  }
-
-  /** setInput() takes a custom query and a separate "bounding query" to use
-      instead of the custom "count query" used by DBInputFormat.
-    */
-  public static void setInput(Job job,
-      Class<? extends DBWritable> inputClass,
-      String inputQuery, String inputBoundingQuery) {
-    org.apache.sqoop.mapreduce.db.DataDrivenDBInputFormat.setInput(
-        job, inputClass, inputQuery, inputBoundingQuery);
-  }
-}

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/mapreduce/db/DataDrivenDBRecordReader.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/mapreduce/db/DataDrivenDBRecordReader.java b/src/java/com/cloudera/sqoop/mapreduce/db/DataDrivenDBRecordReader.java
deleted file mode 100644
index 9563444..0000000
--- a/src/java/com/cloudera/sqoop/mapreduce/db/DataDrivenDBRecordReader.java
+++ /dev/null
@@ -1,53 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.mapreduce.db;
-
-import java.sql.Connection;
-import java.sql.SQLException;
-
-import org.apache.hadoop.conf.Configuration;
-import org.apache.sqoop.mapreduce.DBWritable;
-
-/**
- * A RecordReader that reads records from a SQL table,
- * using data-driven WHERE clause splits.
- * Emits LongWritables containing the record number as
- * key and DBWritables as value.
- *
- * @deprecated use org.apache.sqoop.mapreduce.db.DataDrivenDBRecordReader
- *   instead.
- * @see org.apache.sqoop.mapreduce.db.DataDrivenDBRecordReader
- */
-public class DataDrivenDBRecordReader<T extends DBWritable>
-    extends org.apache.sqoop.mapreduce.db.DataDrivenDBRecordReader<T> {
-
-  // CHECKSTYLE:OFF
-  // TODO(aaron): Refactor constructor to use fewer arguments.
-  /**
-   * @param split The InputSplit to read data for
-   * @throws SQLException
-   */
-  public DataDrivenDBRecordReader(DBInputFormat.DBInputSplit split,
-      Class<T> inputClass, Configuration conf, Connection conn,
-      DBConfiguration dbConfig, String cond, String [] fields, String table,
-      String dbProduct) throws SQLException {
-    super(split, inputClass, conf, conn, dbConfig,
-        cond, fields, table, dbProduct);
-  }
-  // CHECKSTYLE:ON
-}

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/mapreduce/db/DateSplitter.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/mapreduce/db/DateSplitter.java b/src/java/com/cloudera/sqoop/mapreduce/db/DateSplitter.java
deleted file mode 100644
index 2e4a2ba..0000000
--- a/src/java/com/cloudera/sqoop/mapreduce/db/DateSplitter.java
+++ /dev/null
@@ -1,31 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.mapreduce.db;
-
-
-/**
- * Implement DBSplitter over date/time values.
- * Make use of logic from IntegerSplitter, since date/time are just longs
- * in Java.
- *
- * @deprecated use org.apache.sqoop.mapreduce.db.DateSplitter instead.
- * @see org.apache.sqoop.mapreduce.db.DateSplitter
- */
-public class DateSplitter extends org.apache.sqoop.mapreduce.db.DateSplitter {
-
-}

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/mapreduce/db/FloatSplitter.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/mapreduce/db/FloatSplitter.java b/src/java/com/cloudera/sqoop/mapreduce/db/FloatSplitter.java
deleted file mode 100644
index 0c7bc8c..0000000
--- a/src/java/com/cloudera/sqoop/mapreduce/db/FloatSplitter.java
+++ /dev/null
@@ -1,30 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.mapreduce.db;
-
-
-/**
- * Implement DBSplitter over floating-point values.
- *
- * @deprecated use org.apache.sqoop.mapreduce.db.FloatSplitter instead.
- * @see org.apache.sqoop.mapreduce.db.FloatSplitter
- */
-public class FloatSplitter
-  extends org.apache.sqoop.mapreduce.db.FloatSplitter {
-
-}

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/mapreduce/db/IntegerSplitter.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/mapreduce/db/IntegerSplitter.java b/src/java/com/cloudera/sqoop/mapreduce/db/IntegerSplitter.java
deleted file mode 100644
index f042833..0000000
--- a/src/java/com/cloudera/sqoop/mapreduce/db/IntegerSplitter.java
+++ /dev/null
@@ -1,32 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.mapreduce.db;
-
-import org.apache.commons.logging.Log;
-
-/**
- * Implement DBSplitter over integer values.
- *
- * @deprecated use org.apache.sqoop.mapreduce.db.IntegerSplitter instead.
- * @see org.apache.sqoop.mapreduce.db.IntegerSplitter
- */
-public class IntegerSplitter
-  extends org.apache.sqoop.mapreduce.db.IntegerSplitter {
-  public static final Log LOG =
-      org.apache.sqoop.mapreduce.db.IntegerSplitter.LOG;
-}

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/mapreduce/db/OracleDBRecordReader.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/mapreduce/db/OracleDBRecordReader.java b/src/java/com/cloudera/sqoop/mapreduce/db/OracleDBRecordReader.java
deleted file mode 100644
index 53f30d5..0000000
--- a/src/java/com/cloudera/sqoop/mapreduce/db/OracleDBRecordReader.java
+++ /dev/null
@@ -1,58 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.mapreduce.db;
-
-import java.sql.Connection;
-import java.sql.SQLException;
-
-import org.apache.hadoop.conf.Configuration;
-import org.apache.sqoop.mapreduce.DBWritable;
-
-/**
- * A RecordReader that reads records from an Oracle SQL table.
- * @deprecated use org.apache.sqoop.mapreduce.db.OracleDBRecordReader instead.
- * @see org.apache.sqoop.mapreduce.db.OracleDBRecordReader
- */
-public class OracleDBRecordReader<T extends DBWritable> extends
-  org.apache.sqoop.mapreduce.db.OracleDBRecordReader<T> {
-
-  /** Configuration key to set to a timezone string. */
-  public static final String SESSION_TIMEZONE_KEY =
-      org.apache.sqoop.mapreduce.db.OracleDBRecordReader.SESSION_TIMEZONE_KEY;
-
-  // CHECKSTYLE:OFF
-  public OracleDBRecordReader(DBInputFormat.DBInputSplit split,
-      Class<T> inputClass, Configuration conf, Connection conn,
-      DBConfiguration dbConfig, String cond, String [] fields,
-      String table) throws SQLException {
-    super(split, inputClass, conf, conn, dbConfig, cond, fields, table);
-  }
-  // CHECKSTYLE:ON
-
-  /**
-   * Set session time zone.
-   * @param conf The current configuration.
-   * We read the 'oracle.sessionTimeZone' property from here.
-   * @param conn The connection to alter the timezone properties of.
-   */
-  public static void setSessionTimeZone(Configuration conf,
-      Connection conn) throws SQLException {
-    org.apache.sqoop.mapreduce.db.OracleDBRecordReader.setSessionTimeZone(
-        conf, conn);
-  }
-}

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/mapreduce/db/OracleDataDrivenDBInputFormat.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/mapreduce/db/OracleDataDrivenDBInputFormat.java b/src/java/com/cloudera/sqoop/mapreduce/db/OracleDataDrivenDBInputFormat.java
deleted file mode 100644
index b8cb8f7..0000000
--- a/src/java/com/cloudera/sqoop/mapreduce/db/OracleDataDrivenDBInputFormat.java
+++ /dev/null
@@ -1,31 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.mapreduce.db;
-
-import org.apache.sqoop.mapreduce.DBWritable;
-
-/**
- * A InputFormat that reads input data from an SQL table in an Oracle db.
- *
- * @deprecated use org.apache.sqoop.mapreduce.db.OracleDataDrivenDBInputFormat
- *   instead.
- * @see org.apache.sqoop.mapreduce.db.OracleDataDrivenDBInputFormat
- */
-public class OracleDataDrivenDBInputFormat<T extends DBWritable>
-    extends org.apache.sqoop.mapreduce.db.OracleDataDrivenDBInputFormat<T> {
-}

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/mapreduce/db/OracleDataDrivenDBRecordReader.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/mapreduce/db/OracleDataDrivenDBRecordReader.java b/src/java/com/cloudera/sqoop/mapreduce/db/OracleDataDrivenDBRecordReader.java
deleted file mode 100644
index 228d627..0000000
--- a/src/java/com/cloudera/sqoop/mapreduce/db/OracleDataDrivenDBRecordReader.java
+++ /dev/null
@@ -1,47 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.mapreduce.db;
-
-import java.sql.Connection;
-import java.sql.SQLException;
-
-import org.apache.hadoop.conf.Configuration;
-import org.apache.sqoop.mapreduce.DBWritable;
-
-/**
- * A RecordReader that reads records from a Oracle table
- * via DataDrivenDBRecordReader.
- *
- * @deprecated use org.apache.sqoop.mapreduce.db.OracleDataDrivenDBRecordReader
- *   instead.
- * @see org.apache.sqoop.mapreduce.db.OracleDataDrivenDBRecordReader
- */
-public class OracleDataDrivenDBRecordReader<T extends DBWritable>
-    extends org.apache.sqoop.mapreduce.db.OracleDataDrivenDBRecordReader<T> {
-
-  // CHECKSTYLE:OFF
-  // TODO(aaron): Enable checkstyle after refactoring DBRecordReader c'tor.
-  public OracleDataDrivenDBRecordReader(DBInputFormat.DBInputSplit split,
-      Class<T> inputClass, Configuration conf, Connection conn,
-      DBConfiguration dbConfig, String cond, String [] fields,
-      String table) throws SQLException {
-
-    super(split, inputClass, conf, conn, dbConfig, cond, fields, table);
-  }
-  // CHECKSTYLE:ON
-}

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/mapreduce/db/OracleDateSplitter.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/mapreduce/db/OracleDateSplitter.java b/src/java/com/cloudera/sqoop/mapreduce/db/OracleDateSplitter.java
deleted file mode 100644
index 3e1af33..0000000
--- a/src/java/com/cloudera/sqoop/mapreduce/db/OracleDateSplitter.java
+++ /dev/null
@@ -1,32 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.mapreduce.db;
-
-/**
- * Implement DBSplitter over date/time values returned by an Oracle db.
- * Make use of logic from DateSplitter, since this just needs to use
- * some Oracle-specific functions on the formatting end when generating
- * InputSplits.
- *
- * @deprecated use org.apache.sqoop.mapreduce.db.OracleDateSplitter instead.
- * @see org.apache.sqoop.mapreduce.db.OracleDateSplitter
- */
-public class OracleDateSplitter
-    extends org.apache.sqoop.mapreduce.db.OracleDateSplitter {
-
-}

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/mapreduce/db/TextSplitter.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/mapreduce/db/TextSplitter.java b/src/java/com/cloudera/sqoop/mapreduce/db/TextSplitter.java
deleted file mode 100644
index f1bd9d1..0000000
--- a/src/java/com/cloudera/sqoop/mapreduce/db/TextSplitter.java
+++ /dev/null
@@ -1,29 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.mapreduce.db;
-
-
-/**
- * Implement DBSplitter over text strings.
- *
- * @deprecated use org.apache.sqoop.mapreduce.db.TextSplitter instead.
- * @see org.apache.sqoop.mapreduce.db.TextSplitter
- */
-public class TextSplitter extends org.apache.sqoop.mapreduce.db.TextSplitter {
-
-}

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/metastore/GenericJobStorage.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/metastore/GenericJobStorage.java b/src/java/com/cloudera/sqoop/metastore/GenericJobStorage.java
deleted file mode 100644
index d42e5a3..0000000
--- a/src/java/com/cloudera/sqoop/metastore/GenericJobStorage.java
+++ /dev/null
@@ -1,36 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.metastore;
-
-/**
- * @deprecated Moving to use org.apache.sqoop namespace.
- */
-public class GenericJobStorage
-    extends org.apache.sqoop.metastore.GenericJobStorage {
-
-  public static final String META_CONNECT_KEY =
-      org.apache.sqoop.metastore.GenericJobStorage.META_CONNECT_KEY;
-  public static final String META_USERNAME_KEY =
-      org.apache.sqoop.metastore.GenericJobStorage.META_USERNAME_KEY;
-  public static final String META_PASSWORD_KEY =
-      org.apache.sqoop.metastore.GenericJobStorage.META_PASSWORD_KEY;
-  public static final String ROOT_TABLE_NAME_KEY =
-      org.apache.sqoop.metastore.GenericJobStorage.ROOT_TABLE_NAME_KEY;
-
-}
-

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/metastore/JobData.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/metastore/JobData.java b/src/java/com/cloudera/sqoop/metastore/JobData.java
deleted file mode 100644
index 94194d7..0000000
--- a/src/java/com/cloudera/sqoop/metastore/JobData.java
+++ /dev/null
@@ -1,39 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.metastore;
-
-import com.cloudera.sqoop.SqoopOptions;
-import com.cloudera.sqoop.tool.SqoopTool;
-
-/**
- * @deprecated Moving to use org.apache.sqoop namespace.
- */
-public class JobData
-    extends org.apache.sqoop.metastore.JobData {
-
-  public JobData() {
-    super();
-  }
-
-  public JobData(SqoopOptions options, SqoopTool sqoopTool) {
-    super(options, sqoopTool);
-  }
-
-}
-

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/metastore/JobStorage.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/metastore/JobStorage.java b/src/java/com/cloudera/sqoop/metastore/JobStorage.java
deleted file mode 100644
index bbc6aea..0000000
--- a/src/java/com/cloudera/sqoop/metastore/JobStorage.java
+++ /dev/null
@@ -1,27 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.metastore;
-
-/**
- * @deprecated Moving to use org.apache.sqoop namespace.
- */
-public abstract class JobStorage
-    extends org.apache.sqoop.metastore.JobStorage {
-}
-

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/metastore/JobStorageFactory.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/metastore/JobStorageFactory.java b/src/java/com/cloudera/sqoop/metastore/JobStorageFactory.java
deleted file mode 100644
index 3809e6b..0000000
--- a/src/java/com/cloudera/sqoop/metastore/JobStorageFactory.java
+++ /dev/null
@@ -1,37 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.metastore;
-
-import org.apache.hadoop.conf.Configuration;
-
-/**
- * @deprecated Moving to use org.apache.sqoop namespace.
- */
-public class JobStorageFactory
-    extends org.apache.sqoop.metastore.JobStorageFactory {
-
-  public static final String AVAILABLE_STORAGES_KEY =
-          org.apache.sqoop.metastore.JobStorageFactory.AVAILABLE_STORAGES_KEY;
-
-  public JobStorageFactory(Configuration config) {
-    super(config);
-  }
-
-}
-

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/metastore/hsqldb/HsqldbMetaStore.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/metastore/hsqldb/HsqldbMetaStore.java b/src/java/com/cloudera/sqoop/metastore/hsqldb/HsqldbMetaStore.java
deleted file mode 100644
index 945c11a..0000000
--- a/src/java/com/cloudera/sqoop/metastore/hsqldb/HsqldbMetaStore.java
+++ /dev/null
@@ -1,42 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.metastore.hsqldb;
-
-import org.apache.hadoop.conf.Configuration;
-
-/**
- * @deprecated Moving to use org.apache.sqoop namespace.
- */
-public class HsqldbMetaStore
-    extends org.apache.sqoop.metastore.hsqldb.HsqldbMetaStore {
-
-  public static final String META_STORAGE_LOCATION_KEY =
-    org.apache.sqoop.metastore.hsqldb.HsqldbMetaStore.META_STORAGE_LOCATION_KEY;
-  public static final String META_SERVER_PORT_KEY =
-    org.apache.sqoop.metastore.hsqldb.HsqldbMetaStore.META_SERVER_PORT_KEY;
-  public static final int DEFAULT_PORT =
-    org.apache.sqoop.metastore.hsqldb.HsqldbMetaStore.DEFAULT_PORT;
-
-  public HsqldbMetaStore(Configuration config) {
-    super(config);
-  }
-
-}
-

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/orm/AvroSchemaGenerator.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/orm/AvroSchemaGenerator.java b/src/java/com/cloudera/sqoop/orm/AvroSchemaGenerator.java
deleted file mode 100644
index 8ecee80..0000000
--- a/src/java/com/cloudera/sqoop/orm/AvroSchemaGenerator.java
+++ /dev/null
@@ -1,34 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.orm;
-
-import com.cloudera.sqoop.SqoopOptions;
-import com.cloudera.sqoop.manager.ConnManager;
-
-/**
- * @deprecated Moving to use org.apache.sqoop namespace.
- */
-public class AvroSchemaGenerator
-    extends org.apache.sqoop.orm.AvroSchemaGenerator {
-
-  public AvroSchemaGenerator(final SqoopOptions opts, final ConnManager connMgr,
-      final String table) {
-    super(opts, connMgr, table);
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/orm/ClassWriter.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/orm/ClassWriter.java b/src/java/com/cloudera/sqoop/orm/ClassWriter.java
deleted file mode 100644
index 80141bf..0000000
--- a/src/java/com/cloudera/sqoop/orm/ClassWriter.java
+++ /dev/null
@@ -1,111 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.orm;
-
-import java.util.HashSet;
-
-import com.cloudera.sqoop.SqoopOptions;
-import com.cloudera.sqoop.manager.ConnManager;
-
-/**
- * @deprecated Moving to use org.apache.sqoop namespace.
- */
-public class ClassWriter
-    extends org.apache.sqoop.orm.ClassWriter {
-
-  public static final HashSet<String> JAVA_RESERVED_WORDS;
-
-  static {
-    JAVA_RESERVED_WORDS = new HashSet<String>();
-
-    JAVA_RESERVED_WORDS.add("abstract");
-    JAVA_RESERVED_WORDS.add("assert");
-    JAVA_RESERVED_WORDS.add("boolean");
-    JAVA_RESERVED_WORDS.add("break");
-    JAVA_RESERVED_WORDS.add("byte");
-    JAVA_RESERVED_WORDS.add("case");
-    JAVA_RESERVED_WORDS.add("catch");
-    JAVA_RESERVED_WORDS.add("char");
-    JAVA_RESERVED_WORDS.add("class");
-    JAVA_RESERVED_WORDS.add("const");
-    JAVA_RESERVED_WORDS.add("continue");
-    JAVA_RESERVED_WORDS.add("default");
-    JAVA_RESERVED_WORDS.add("do");
-    JAVA_RESERVED_WORDS.add("double");
-    JAVA_RESERVED_WORDS.add("else");
-    JAVA_RESERVED_WORDS.add("enum");
-    JAVA_RESERVED_WORDS.add("extends");
-    JAVA_RESERVED_WORDS.add("false");
-    JAVA_RESERVED_WORDS.add("final");
-    JAVA_RESERVED_WORDS.add("finally");
-    JAVA_RESERVED_WORDS.add("float");
-    JAVA_RESERVED_WORDS.add("for");
-    JAVA_RESERVED_WORDS.add("goto");
-    JAVA_RESERVED_WORDS.add("if");
-    JAVA_RESERVED_WORDS.add("implements");
-    JAVA_RESERVED_WORDS.add("import");
-    JAVA_RESERVED_WORDS.add("instanceof");
-    JAVA_RESERVED_WORDS.add("int");
-    JAVA_RESERVED_WORDS.add("interface");
-    JAVA_RESERVED_WORDS.add("long");
-    JAVA_RESERVED_WORDS.add("native");
-    JAVA_RESERVED_WORDS.add("new");
-    JAVA_RESERVED_WORDS.add("null");
-    JAVA_RESERVED_WORDS.add("package");
-    JAVA_RESERVED_WORDS.add("private");
-    JAVA_RESERVED_WORDS.add("protected");
-    JAVA_RESERVED_WORDS.add("public");
-    JAVA_RESERVED_WORDS.add("return");
-    JAVA_RESERVED_WORDS.add("short");
-    JAVA_RESERVED_WORDS.add("static");
-    JAVA_RESERVED_WORDS.add("strictfp");
-    JAVA_RESERVED_WORDS.add("super");
-    JAVA_RESERVED_WORDS.add("switch");
-    JAVA_RESERVED_WORDS.add("synchronized");
-    JAVA_RESERVED_WORDS.add("this");
-    JAVA_RESERVED_WORDS.add("throw");
-    JAVA_RESERVED_WORDS.add("throws");
-    JAVA_RESERVED_WORDS.add("transient");
-    JAVA_RESERVED_WORDS.add("true");
-    JAVA_RESERVED_WORDS.add("try");
-    JAVA_RESERVED_WORDS.add("void");
-    JAVA_RESERVED_WORDS.add("volatile");
-    JAVA_RESERVED_WORDS.add("while");
-  }
-
-  public static final int CLASS_WRITER_VERSION =
-    org.apache.sqoop.orm.ClassWriter.CLASS_WRITER_VERSION;
-
-  public static String toIdentifier(String candidate) {
-    return org.apache.sqoop.orm.ClassWriter.toIdentifier(candidate);
-  }
-
-  public static String toJavaIdentifier(String candidate) {
-    return org.apache.sqoop.orm.ClassWriter.toJavaIdentifier(candidate);
-  }
-
-  public static String getIdentifierStrForChar(char c) {
-    return org.apache.sqoop.orm.ClassWriter.getIdentifierStrForChar(c);
-  }
-
-  public ClassWriter(final SqoopOptions opts, final ConnManager connMgr,
-      final String table, final CompilationManager compMgr) {
-    super(opts, connMgr, table, compMgr);
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/orm/CompilationManager.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/orm/CompilationManager.java b/src/java/com/cloudera/sqoop/orm/CompilationManager.java
deleted file mode 100644
index 152d8a4..0000000
--- a/src/java/com/cloudera/sqoop/orm/CompilationManager.java
+++ /dev/null
@@ -1,35 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.orm;
-
-import com.cloudera.sqoop.SqoopOptions;
-
-/**
- * @deprecated Moving to use org.apache.sqoop namespace.
- */
-public class CompilationManager
-    extends org.apache.sqoop.orm.CompilationManager {
-
-  public static final String DEFAULT_CODEGEN_JAR_NAME =
-    org.apache.sqoop.orm.CompilationManager.DEFAULT_CODEGEN_JAR_NAME;
-
-  public CompilationManager(final SqoopOptions opts) {
-    super(opts);
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/orm/TableClassName.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/orm/TableClassName.java b/src/java/com/cloudera/sqoop/orm/TableClassName.java
deleted file mode 100644
index 20c82af..0000000
--- a/src/java/com/cloudera/sqoop/orm/TableClassName.java
+++ /dev/null
@@ -1,32 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.orm;
-
-import com.cloudera.sqoop.SqoopOptions;
-
-/**
- * @deprecated Moving to use org.apache.sqoop namespace.
- */
-public class TableClassName
-    extends org.apache.sqoop.orm.TableClassName {
-
-  public TableClassName(final SqoopOptions opts) {
-    super(opts);
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/tool/BaseSqoopTool.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/tool/BaseSqoopTool.java b/src/java/com/cloudera/sqoop/tool/BaseSqoopTool.java
deleted file mode 100644
index 891ed4d..0000000
--- a/src/java/com/cloudera/sqoop/tool/BaseSqoopTool.java
+++ /dev/null
@@ -1,218 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.tool;
-
-import com.cloudera.sqoop.SqoopOptions;
-import org.apache.sqoop.manager.SupportedManagers;
-
-/**
- * @deprecated Moving to use org.apache.sqoop namespace.
- */
-public abstract class BaseSqoopTool
-    extends org.apache.sqoop.tool.BaseSqoopTool {
-
-  public static final String HELP_STR =
-          org.apache.sqoop.tool.BaseSqoopTool.HELP_STR;
-  public static final String CONNECT_STRING_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.CONNECT_STRING_ARG;
-  public static final String CONN_MANAGER_CLASS_NAME =
-          org.apache.sqoop.tool.BaseSqoopTool.CONN_MANAGER_CLASS_NAME;
-  public static final String CONNECT_PARAM_FILE =
-          org.apache.sqoop.tool.BaseSqoopTool.CONNECT_PARAM_FILE;
-  public static final String DRIVER_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.DRIVER_ARG;
-  public static final String USERNAME_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.USERNAME_ARG;
-  public static final String PASSWORD_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.PASSWORD_ARG;
-  public static final String PASSWORD_PROMPT_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.PASSWORD_PROMPT_ARG;
-  public static final String DIRECT_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.DIRECT_ARG;
-  public static final String BATCH_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.BATCH_ARG;
-  public static final String TABLE_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.TABLE_ARG;
-  public static final String STAGING_TABLE_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.STAGING_TABLE_ARG;
-  public static final String CLEAR_STAGING_TABLE_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.CLEAR_STAGING_TABLE_ARG;
-  public static final String COLUMNS_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.COLUMNS_ARG;
-  public static final String SPLIT_BY_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.SPLIT_BY_ARG;
-  public static final String WHERE_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.WHERE_ARG;
-  public static final String HADOOP_HOME_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.HADOOP_HOME_ARG;
-  public static final String HIVE_HOME_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.HIVE_HOME_ARG;
-  public static final String WAREHOUSE_DIR_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.WAREHOUSE_DIR_ARG;
-  public static final String TARGET_DIR_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.TARGET_DIR_ARG;
-  public static final String APPEND_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.APPEND_ARG;
-  public static final String NULL_STRING =
-          org.apache.sqoop.tool.BaseSqoopTool.NULL_STRING;
-  public static final String INPUT_NULL_STRING =
-          org.apache.sqoop.tool.BaseSqoopTool.INPUT_NULL_STRING;
-  public static final String NULL_NON_STRING =
-          org.apache.sqoop.tool.BaseSqoopTool.NULL_NON_STRING;
-  public static final String INPUT_NULL_NON_STRING =
-          org.apache.sqoop.tool.BaseSqoopTool.INPUT_NULL_NON_STRING;
-  public static final String MAP_COLUMN_JAVA =
-          org.apache.sqoop.tool.BaseSqoopTool.MAP_COLUMN_JAVA;
-  public static final String MAP_COLUMN_HIVE =
-          org.apache.sqoop.tool.BaseSqoopTool.MAP_COLUMN_HIVE;
-  public static final String FMT_SEQUENCEFILE_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.FMT_SEQUENCEFILE_ARG;
-  public static final String FMT_TEXTFILE_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.FMT_TEXTFILE_ARG;
-  public static final String FMT_AVRODATAFILE_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.FMT_AVRODATAFILE_ARG;
-  public static final String HIVE_IMPORT_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.HIVE_IMPORT_ARG;
-  public static final String HIVE_TABLE_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.HIVE_TABLE_ARG;
-  public static final String HIVE_OVERWRITE_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.HIVE_OVERWRITE_ARG;
-  public static final String HIVE_DROP_DELIMS_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.HIVE_DROP_DELIMS_ARG;
-  public static final String HIVE_DELIMS_REPLACEMENT_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.HIVE_DELIMS_REPLACEMENT_ARG;
-  public static final String HIVE_PARTITION_KEY_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.HIVE_PARTITION_KEY_ARG;
-  public static final String HIVE_PARTITION_VALUE_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.HIVE_PARTITION_VALUE_ARG;
-  public static final String CREATE_HIVE_TABLE_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.CREATE_HIVE_TABLE_ARG;
-  public static final String NUM_MAPPERS_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.NUM_MAPPERS_ARG;
-  public static final String NUM_MAPPERS_SHORT_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.NUM_MAPPERS_SHORT_ARG;
-  public static final String COMPRESS_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.COMPRESS_ARG;
-  public static final String COMPRESSION_CODEC_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.COMPRESSION_CODEC_ARG;
-  public static final String COMPRESS_SHORT_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.COMPRESS_SHORT_ARG;
-  public static final String DIRECT_SPLIT_SIZE_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.DIRECT_SPLIT_SIZE_ARG;
-  public static final String INLINE_LOB_LIMIT_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.INLINE_LOB_LIMIT_ARG;
-  public static final String FETCH_SIZE_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.FETCH_SIZE_ARG;
-  public static final String EXPORT_PATH_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.EXPORT_PATH_ARG;
-  public static final String FIELDS_TERMINATED_BY_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.FIELDS_TERMINATED_BY_ARG;
-  public static final String LINES_TERMINATED_BY_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.LINES_TERMINATED_BY_ARG;
-  public static final String OPTIONALLY_ENCLOSED_BY_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.OPTIONALLY_ENCLOSED_BY_ARG;
-  public static final String ENCLOSED_BY_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.ENCLOSED_BY_ARG;
-  public static final String ESCAPED_BY_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.ESCAPED_BY_ARG;
-  public static final String MYSQL_DELIMITERS_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.MYSQL_DELIMITERS_ARG;
-  public static final String INPUT_FIELDS_TERMINATED_BY_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.INPUT_FIELDS_TERMINATED_BY_ARG;
-  public static final String INPUT_LINES_TERMINATED_BY_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.INPUT_LINES_TERMINATED_BY_ARG;
-  public static final String INPUT_OPTIONALLY_ENCLOSED_BY_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.INPUT_OPTIONALLY_ENCLOSED_BY_ARG;
-  public static final String INPUT_ENCLOSED_BY_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.INPUT_ENCLOSED_BY_ARG;
-  public static final String INPUT_ESCAPED_BY_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.INPUT_ESCAPED_BY_ARG;
-  public static final String CODE_OUT_DIR_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.CODE_OUT_DIR_ARG;
-  public static final String BIN_OUT_DIR_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.BIN_OUT_DIR_ARG;
-  public static final String PACKAGE_NAME_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.PACKAGE_NAME_ARG;
-  public static final String CLASS_NAME_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.CLASS_NAME_ARG;
-  public static final String JAR_FILE_NAME_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.JAR_FILE_NAME_ARG;
-  public static final String SQL_QUERY_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.SQL_QUERY_ARG;
-  public static final String SQL_QUERY_BOUNDARY =
-          org.apache.sqoop.tool.BaseSqoopTool.SQL_QUERY_BOUNDARY;
-  public static final String SQL_QUERY_SHORT_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.SQL_QUERY_SHORT_ARG;
-  public static final String VERBOSE_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.VERBOSE_ARG;
-  public static final String HELP_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.HELP_ARG;
-  public static final String UPDATE_KEY_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.UPDATE_KEY_ARG;
-  public static final String UPDATE_MODE_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.UPDATE_MODE_ARG;
-  public static final String INCREMENT_TYPE_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.INCREMENT_TYPE_ARG;
-  public static final String INCREMENT_COL_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.INCREMENT_COL_ARG;
-  public static final String INCREMENT_LAST_VAL_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.INCREMENT_LAST_VAL_ARG;
-  public static final String HBASE_TABLE_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.HBASE_TABLE_ARG;
-  public static final String HBASE_COL_FAM_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.HBASE_COL_FAM_ARG;
-  public static final String HBASE_ROW_KEY_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.HBASE_ROW_KEY_ARG;
-  public static final String HBASE_CREATE_TABLE_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.HBASE_CREATE_TABLE_ARG;
-  public static final String STORAGE_METASTORE_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.STORAGE_METASTORE_ARG;
-  public static final String JOB_CMD_CREATE_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.JOB_CMD_CREATE_ARG;
-  public static final String JOB_CMD_DELETE_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.JOB_CMD_DELETE_ARG;
-  public static final String JOB_CMD_EXEC_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.JOB_CMD_EXEC_ARG;
-  public static final String JOB_CMD_LIST_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.JOB_CMD_LIST_ARG;
-  public static final String JOB_CMD_SHOW_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.JOB_CMD_SHOW_ARG;
-  public static final String METASTORE_SHUTDOWN_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.METASTORE_SHUTDOWN_ARG;
-  public static final String NEW_DATASET_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.NEW_DATASET_ARG;
-  public static final String OLD_DATASET_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.OLD_DATASET_ARG;
-  public static final String MERGE_KEY_ARG =
-          org.apache.sqoop.tool.BaseSqoopTool.MERGE_KEY_ARG;
-
-  public BaseSqoopTool() {
-  }
-
-  public BaseSqoopTool(String toolName) {
-    super(toolName);
-  }
-
-  protected void validateHasDirectConnectorOption(SqoopOptions options) throws SqoopOptions.InvalidOptionsException {
-    SupportedManagers m = SupportedManagers.createFrom(options);
-    if (m != null && options.isDirect() && !m.hasDirectConnector()) {
-      throw new SqoopOptions.InvalidOptionsException(
-          "Was called with the --direct option, but no direct connector available.");
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/tool/CodeGenTool.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/tool/CodeGenTool.java b/src/java/com/cloudera/sqoop/tool/CodeGenTool.java
deleted file mode 100644
index caab39f..0000000
--- a/src/java/com/cloudera/sqoop/tool/CodeGenTool.java
+++ /dev/null
@@ -1,25 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.tool;
-
-/**
- * @deprecated Moving to use org.apache.sqoop namespace.
- */
-public class CodeGenTool
-    extends org.apache.sqoop.tool.CodeGenTool {
-}

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/tool/CreateHiveTableTool.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/tool/CreateHiveTableTool.java b/src/java/com/cloudera/sqoop/tool/CreateHiveTableTool.java
deleted file mode 100644
index 103b66e..0000000
--- a/src/java/com/cloudera/sqoop/tool/CreateHiveTableTool.java
+++ /dev/null
@@ -1,25 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.tool;
-
-/**
- * @deprecated Moving to use org.apache.sqoop namespace.
- */
-public class CreateHiveTableTool
-    extends org.apache.sqoop.tool.CreateHiveTableTool {
-}

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/tool/EvalSqlTool.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/tool/EvalSqlTool.java b/src/java/com/cloudera/sqoop/tool/EvalSqlTool.java
deleted file mode 100644
index fcba535..0000000
--- a/src/java/com/cloudera/sqoop/tool/EvalSqlTool.java
+++ /dev/null
@@ -1,25 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.tool;
-
-/**
- * @deprecated Moving to use org.apache.sqoop namespace.
- */
-public class EvalSqlTool
-    extends org.apache.sqoop.tool.EvalSqlTool {
-}

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/tool/ExportTool.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/tool/ExportTool.java b/src/java/com/cloudera/sqoop/tool/ExportTool.java
deleted file mode 100644
index 597f0fb..0000000
--- a/src/java/com/cloudera/sqoop/tool/ExportTool.java
+++ /dev/null
@@ -1,25 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.tool;
-
-/**
- * @deprecated Moving to use org.apache.sqoop namespace.
- */
-public class ExportTool
-    extends org.apache.sqoop.tool.ExportTool {
-}

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/tool/HelpTool.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/tool/HelpTool.java b/src/java/com/cloudera/sqoop/tool/HelpTool.java
deleted file mode 100644
index dc2933a..0000000
--- a/src/java/com/cloudera/sqoop/tool/HelpTool.java
+++ /dev/null
@@ -1,25 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.tool;
-
-/**
- * @deprecated Moving to use org.apache.sqoop namespace.
- */
-public class HelpTool
-    extends org.apache.sqoop.tool.HelpTool {
-}

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/tool/ImportAllTablesTool.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/tool/ImportAllTablesTool.java b/src/java/com/cloudera/sqoop/tool/ImportAllTablesTool.java
deleted file mode 100644
index 0c7724b..0000000
--- a/src/java/com/cloudera/sqoop/tool/ImportAllTablesTool.java
+++ /dev/null
@@ -1,25 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.tool;
-
-/**
- * @deprecated Moving to use org.apache.sqoop namespace.
- */
-public class ImportAllTablesTool
-    extends org.apache.sqoop.tool.ImportAllTablesTool {
-}

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/tool/ImportTool.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/tool/ImportTool.java b/src/java/com/cloudera/sqoop/tool/ImportTool.java
deleted file mode 100644
index 8f00741..0000000
--- a/src/java/com/cloudera/sqoop/tool/ImportTool.java
+++ /dev/null
@@ -1,34 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.tool;
-
-/**
- * @deprecated Moving to use org.apache.sqoop namespace.
- */
-public class ImportTool
-    extends org.apache.sqoop.tool.ImportTool {
-
-  public ImportTool() {
-    super();
-  }
-
-  public ImportTool(String toolName, boolean allTables) {
-    super(toolName, allTables);
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/tool/JobTool.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/tool/JobTool.java b/src/java/com/cloudera/sqoop/tool/JobTool.java
deleted file mode 100644
index f1554d0..0000000
--- a/src/java/com/cloudera/sqoop/tool/JobTool.java
+++ /dev/null
@@ -1,25 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.tool;
-
-/**
- * @deprecated Moving to use org.apache.sqoop namespace.
- */
-public class JobTool
-    extends org.apache.sqoop.tool.JobTool {
-}

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/tool/ListDatabasesTool.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/tool/ListDatabasesTool.java b/src/java/com/cloudera/sqoop/tool/ListDatabasesTool.java
deleted file mode 100644
index 29d8923..0000000
--- a/src/java/com/cloudera/sqoop/tool/ListDatabasesTool.java
+++ /dev/null
@@ -1,25 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.tool;
-
-/**
- * @deprecated Moving to use org.apache.sqoop namespace.
- */
-public class ListDatabasesTool
-    extends org.apache.sqoop.tool.ListDatabasesTool {
-}

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/tool/ListTablesTool.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/tool/ListTablesTool.java b/src/java/com/cloudera/sqoop/tool/ListTablesTool.java
deleted file mode 100644
index 08392ef..0000000
--- a/src/java/com/cloudera/sqoop/tool/ListTablesTool.java
+++ /dev/null
@@ -1,25 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.tool;
-
-/**
- * @deprecated Moving to use org.apache.sqoop namespace.
- */
-public class ListTablesTool
-    extends org.apache.sqoop.tool.ListTablesTool {
-}

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/tool/MergeTool.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/tool/MergeTool.java b/src/java/com/cloudera/sqoop/tool/MergeTool.java
deleted file mode 100644
index 1ae2a4c..0000000
--- a/src/java/com/cloudera/sqoop/tool/MergeTool.java
+++ /dev/null
@@ -1,25 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.tool;
-
-/**
- * @deprecated Moving to use org.apache.sqoop namespace.
- */
-public class MergeTool
-    extends org.apache.sqoop.tool.MergeTool {
-}

http://git-wip-us.apache.org/repos/asf/sqoop/blob/6984a36c/src/java/com/cloudera/sqoop/tool/MetastoreTool.java
----------------------------------------------------------------------
diff --git a/src/java/com/cloudera/sqoop/tool/MetastoreTool.java b/src/java/com/cloudera/sqoop/tool/MetastoreTool.java
deleted file mode 100644
index 210f9cc..0000000
--- a/src/java/com/cloudera/sqoop/tool/MetastoreTool.java
+++ /dev/null
@@ -1,25 +0,0 @@
-/**
- * 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 com.cloudera.sqoop.tool;
-
-/**
- * @deprecated Moving to use org.apache.sqoop namespace.
- */
-public class MetastoreTool
-    extends org.apache.sqoop.tool.MetastoreTool {
-}