/** * Autogenerated by Thrift Compiler (0.9.3) * * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING * @generated */ package org.apache.hadoop.hbase.thrift.generated; import org.apache.thrift.scheme.IScheme; import org.apache.thrift.scheme.SchemeFactory; import org.apache.thrift.scheme.StandardScheme; import org.apache.thrift.scheme.TupleScheme; import org.apache.thrift.protocol.TTupleProtocol; import org.apache.thrift.protocol.TProtocolException; import org.apache.thrift.EncodingUtils; import org.apache.thrift.TException; import org.apache.thrift.async.AsyncMethodCallback; import org.apache.thrift.server.AbstractNonblockingServer.*; import java.util.List; import java.util.ArrayList; import java.util.Map; import java.util.HashMap; import java.util.EnumMap; import java.util.Set; import java.util.HashSet; import java.util.EnumSet; import java.util.Collections; import java.util.BitSet; import java.nio.ByteBuffer; import java.util.Arrays; import javax.annotation.Generated; import org.slf4j.Logger; import org.slf4j.LoggerFactory; @SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"}) @Generated(value = "Autogenerated by Thrift Compiler (0.9.3)", date = "2016-05-25") public class Hbase { public interface Iface { /** * Brings a table on-line (enables it) * * @param tableName name of the table */ public void enableTable(ByteBuffer tableName) throws IOError, org.apache.thrift.TException; /** * Disables a table (takes it off-line) If it is being served, the master * will tell the servers to stop serving it. * * @param tableName name of the table */ public void disableTable(ByteBuffer tableName) throws IOError, org.apache.thrift.TException; /** * @return true if table is on-line * * @param tableName name of the table to check */ public boolean isTableEnabled(ByteBuffer tableName) throws IOError, org.apache.thrift.TException; public void compact(ByteBuffer tableNameOrRegionName) throws IOError, org.apache.thrift.TException; public void majorCompact(ByteBuffer tableNameOrRegionName) throws IOError, org.apache.thrift.TException; /** * List all the userspace tables. * * @return returns a list of names */ public List<ByteBuffer> getTableNames() throws IOError, org.apache.thrift.TException; /** * List all the column families assoicated with a table. * * @return list of column family descriptors * * @param tableName table name */ public Map<ByteBuffer,ColumnDescriptor> getColumnDescriptors(ByteBuffer tableName) throws IOError, org.apache.thrift.TException; /** * List the regions associated with a table. * * @return list of region descriptors * * @param tableName table name */ public List<TRegionInfo> getTableRegions(ByteBuffer tableName) throws IOError, org.apache.thrift.TException; /** * Create a table with the specified column families. The name * field for each ColumnDescriptor must be set and must end in a * colon (:). All other fields are optional and will get default * values if not explicitly specified. * * @throws IllegalArgument if an input parameter is invalid * * @throws AlreadyExists if the table name already exists * * @param tableName name of table to create * * @param columnFamilies list of column family descriptors */ public void createTable(ByteBuffer tableName, List<ColumnDescriptor> columnFamilies) throws IOError, IllegalArgument, AlreadyExists, org.apache.thrift.TException; /** * Deletes a table * * @throws IOError if table doesn't exist on server or there was some other * problem * * @param tableName name of table to delete */ public void deleteTable(ByteBuffer tableName) throws IOError, org.apache.thrift.TException; /** * Get a single TCell for the specified table, row, and column at the * latest timestamp. Returns an empty list if no such value exists. * * @return value for specified row/column * * @param tableName name of table * * @param row row key * * @param column column name * * @param attributes Get attributes */ public List<TCell> get(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException; /** * Get the specified number of versions for the specified table, * row, and column. * * @return list of cells for specified row/column * * @param tableName name of table * * @param row row key * * @param column column name * * @param numVersions number of versions to retrieve * * @param attributes Get attributes */ public List<TCell> getVer(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, int numVersions, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException; /** * Get the specified number of versions for the specified table, * row, and column. Only versions less than or equal to the specified * timestamp will be returned. * * @return list of cells for specified row/column * * @param tableName name of table * * @param row row key * * @param column column name * * @param timestamp timestamp * * @param numVersions number of versions to retrieve * * @param attributes Get attributes */ public List<TCell> getVerTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, int numVersions, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException; /** * Get all the data for the specified table and row at the latest * timestamp. Returns an empty list if the row does not exist. * * @return TRowResult containing the row and map of columns to TCells * * @param tableName name of table * * @param row row key * * @param attributes Get attributes */ public List<TRowResult> getRow(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException; /** * Get the specified columns for the specified table and row at the latest * timestamp. Returns an empty list if the row does not exist. * * @return TRowResult containing the row and map of columns to TCells * * @param tableName name of table * * @param row row key * * @param columns List of columns to return, null for all columns * * @param attributes Get attributes */ public List<TRowResult> getRowWithColumns(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException; /** * Get all the data for the specified table and row at the specified * timestamp. Returns an empty list if the row does not exist. * * @return TRowResult containing the row and map of columns to TCells * * @param tableName name of the table * * @param row row key * * @param timestamp timestamp * * @param attributes Get attributes */ public List<TRowResult> getRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException; /** * Get the specified columns for the specified table and row at the specified * timestamp. Returns an empty list if the row does not exist. * * @return TRowResult containing the row and map of columns to TCells * * @param tableName name of table * * @param row row key * * @param columns List of columns to return, null for all columns * * @param timestamp * @param attributes Get attributes */ public List<TRowResult> getRowWithColumnsTs(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException; /** * Get all the data for the specified table and rows at the latest * timestamp. Returns an empty list if no rows exist. * * @return TRowResult containing the rows and map of columns to TCells * * @param tableName name of table * * @param rows row keys * * @param attributes Get attributes */ public List<TRowResult> getRows(ByteBuffer tableName, List<ByteBuffer> rows, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException; /** * Get the specified columns for the specified table and rows at the latest * timestamp. Returns an empty list if no rows exist. * * @return TRowResult containing the rows and map of columns to TCells * * @param tableName name of table * * @param rows row keys * * @param columns List of columns to return, null for all columns * * @param attributes Get attributes */ public List<TRowResult> getRowsWithColumns(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException; /** * Get all the data for the specified table and rows at the specified * timestamp. Returns an empty list if no rows exist. * * @return TRowResult containing the rows and map of columns to TCells * * @param tableName name of the table * * @param rows row keys * * @param timestamp timestamp * * @param attributes Get attributes */ public List<TRowResult> getRowsTs(ByteBuffer tableName, List<ByteBuffer> rows, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException; /** * Get the specified columns for the specified table and rows at the specified * timestamp. Returns an empty list if no rows exist. * * @return TRowResult containing the rows and map of columns to TCells * * @param tableName name of table * * @param rows row keys * * @param columns List of columns to return, null for all columns * * @param timestamp * @param attributes Get attributes */ public List<TRowResult> getRowsWithColumnsTs(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException; /** * Apply a series of mutations (updates/deletes) to a row in a * single transaction. If an exception is thrown, then the * transaction is aborted. Default current timestamp is used, and * all entries will have an identical timestamp. * * @param tableName name of table * * @param row row key * * @param mutations list of mutation commands * * @param attributes Mutation attributes */ public void mutateRow(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, IllegalArgument, org.apache.thrift.TException; /** * Apply a series of mutations (updates/deletes) to a row in a * single transaction. If an exception is thrown, then the * transaction is aborted. The specified timestamp is used, and * all entries will have an identical timestamp. * * @param tableName name of table * * @param row row key * * @param mutations list of mutation commands * * @param timestamp timestamp * * @param attributes Mutation attributes */ public void mutateRowTs(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, IllegalArgument, org.apache.thrift.TException; /** * Apply a series of batches (each a series of mutations on a single row) * in a single transaction. If an exception is thrown, then the * transaction is aborted. Default current timestamp is used, and * all entries will have an identical timestamp. * * @param tableName name of table * * @param rowBatches list of row batches * * @param attributes Mutation attributes */ public void mutateRows(ByteBuffer tableName, List<BatchMutation> rowBatches, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, IllegalArgument, org.apache.thrift.TException; /** * Apply a series of batches (each a series of mutations on a single row) * in a single transaction. If an exception is thrown, then the * transaction is aborted. The specified timestamp is used, and * all entries will have an identical timestamp. * * @param tableName name of table * * @param rowBatches list of row batches * * @param timestamp timestamp * * @param attributes Mutation attributes */ public void mutateRowsTs(ByteBuffer tableName, List<BatchMutation> rowBatches, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, IllegalArgument, org.apache.thrift.TException; /** * Atomically increment the column value specified. Returns the next value post increment. * * @param tableName name of table * * @param row row to increment * * @param column name of column * * @param value amount to increment by */ public long atomicIncrement(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long value) throws IOError, IllegalArgument, org.apache.thrift.TException; /** * Delete all cells that match the passed row and column. * * @param tableName name of table * * @param row Row to update * * @param column name of column whose value is to be deleted * * @param attributes Delete attributes */ public void deleteAll(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException; /** * Delete all cells that match the passed row and column and whose * timestamp is equal-to or older than the passed timestamp. * * @param tableName name of table * * @param row Row to update * * @param column name of column whose value is to be deleted * * @param timestamp timestamp * * @param attributes Delete attributes */ public void deleteAllTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException; /** * Completely delete the row's cells. * * @param tableName name of table * * @param row key of the row to be completely deleted. * * @param attributes Delete attributes */ public void deleteAllRow(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException; /** * Increment a cell by the ammount. * Increments can be applied async if hbase.regionserver.thrift.coalesceIncrement is set to true. * False is the default. Turn to true if you need the extra performance and can accept some * data loss if a thrift server dies with increments still in the queue. * * @param increment The single increment to apply */ public void increment(TIncrement increment) throws IOError, org.apache.thrift.TException; public void incrementRows(List<TIncrement> increments) throws IOError, org.apache.thrift.TException; /** * Completely delete the row's cells marked with a timestamp * equal-to or older than the passed timestamp. * * @param tableName name of table * * @param row key of the row to be completely deleted. * * @param timestamp timestamp * * @param attributes Delete attributes */ public void deleteAllRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException; /** * Get a scanner on the current table, using the Scan instance * for the scan parameters. * * @param tableName name of table * * @param scan Scan instance * * @param attributes Scan attributes */ public int scannerOpenWithScan(ByteBuffer tableName, TScan scan, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException; /** * Get a scanner on the current table starting at the specified row and * ending at the last row in the table. Return the specified columns. * * @return scanner id to be used with other scanner procedures * * @param tableName name of table * * @param startRow Starting row in table to scan. * Send "" (empty string) to start at the first row. * * @param columns columns to scan. If column name is a column family, all * columns of the specified column family are returned. It's also possible * to pass a regex in the column qualifier. * * @param attributes Scan attributes */ public int scannerOpen(ByteBuffer tableName, ByteBuffer startRow, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException; /** * Get a scanner on the current table starting and stopping at the * specified rows. ending at the last row in the table. Return the * specified columns. * * @return scanner id to be used with other scanner procedures * * @param tableName name of table * * @param startRow Starting row in table to scan. * Send "" (empty string) to start at the first row. * * @param stopRow row to stop scanning on. This row is *not* included in the * scanner's results * * @param columns columns to scan. If column name is a column family, all * columns of the specified column family are returned. It's also possible * to pass a regex in the column qualifier. * * @param attributes Scan attributes */ public int scannerOpenWithStop(ByteBuffer tableName, ByteBuffer startRow, ByteBuffer stopRow, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException; /** * Open a scanner for a given prefix. That is all rows will have the specified * prefix. No other rows will be returned. * * @return scanner id to use with other scanner calls * * @param tableName name of table * * @param startAndPrefix the prefix (and thus start row) of the keys you want * * @param columns the columns you want returned * * @param attributes Scan attributes */ public int scannerOpenWithPrefix(ByteBuffer tableName, ByteBuffer startAndPrefix, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException; /** * Get a scanner on the current table starting at the specified row and * ending at the last row in the table. Return the specified columns. * Only values with the specified timestamp are returned. * * @return scanner id to be used with other scanner procedures * * @param tableName name of table * * @param startRow Starting row in table to scan. * Send "" (empty string) to start at the first row. * * @param columns columns to scan. If column name is a column family, all * columns of the specified column family are returned. It's also possible * to pass a regex in the column qualifier. * * @param timestamp timestamp * * @param attributes Scan attributes */ public int scannerOpenTs(ByteBuffer tableName, ByteBuffer startRow, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException; /** * Get a scanner on the current table starting and stopping at the * specified rows. ending at the last row in the table. Return the * specified columns. Only values with the specified timestamp are * returned. * * @return scanner id to be used with other scanner procedures * * @param tableName name of table * * @param startRow Starting row in table to scan. * Send "" (empty string) to start at the first row. * * @param stopRow row to stop scanning on. This row is *not* included in the * scanner's results * * @param columns columns to scan. If column name is a column family, all * columns of the specified column family are returned. It's also possible * to pass a regex in the column qualifier. * * @param timestamp timestamp * * @param attributes Scan attributes */ public int scannerOpenWithStopTs(ByteBuffer tableName, ByteBuffer startRow, ByteBuffer stopRow, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException; /** * Returns the scanner's current row value and advances to the next * row in the table. When there are no more rows in the table, or a key * greater-than-or-equal-to the scanner's specified stopRow is reached, * an empty list is returned. * * @return a TRowResult containing the current row and a map of the columns to TCells. * * @throws IllegalArgument if ScannerID is invalid * * @throws NotFound when the scanner reaches the end * * @param id id of a scanner returned by scannerOpen */ public List<TRowResult> scannerGet(int id) throws IOError, IllegalArgument, org.apache.thrift.TException; /** * Returns, starting at the scanner's current row value nbRows worth of * rows and advances to the next row in the table. When there are no more * rows in the table, or a key greater-than-or-equal-to the scanner's * specified stopRow is reached, an empty list is returned. * * @return a TRowResult containing the current row and a map of the columns to TCells. * * @throws IllegalArgument if ScannerID is invalid * * @throws NotFound when the scanner reaches the end * * @param id id of a scanner returned by scannerOpen * * @param nbRows number of results to return */ public List<TRowResult> scannerGetList(int id, int nbRows) throws IOError, IllegalArgument, org.apache.thrift.TException; /** * Closes the server-state associated with an open scanner. * * @throws IllegalArgument if ScannerID is invalid * * @param id id of a scanner returned by scannerOpen */ public void scannerClose(int id) throws IOError, IllegalArgument, org.apache.thrift.TException; /** * Get the regininfo for the specified row. It scans * the metatable to find region's start and end keys. * * @return value for specified row/column * * @param row row key */ public TRegionInfo getRegionInfo(ByteBuffer row) throws IOError, org.apache.thrift.TException; /** * Appends values to one or more columns within a single row. * * @return values of columns after the append operation. * * @param append The single append operation to apply */ public List<TCell> append(TAppend append) throws IOError, org.apache.thrift.TException; /** * Atomically checks if a row/family/qualifier value matches the expected * value. If it does, it adds the corresponding mutation operation for put. * * @return true if the new put was executed, false otherwise * * @param tableName name of table * * @param row row key * * @param column column name * * @param value the expected value for the column parameter, if not * provided the check is for the non-existence of the * column in question * * @param mput mutation for the put * * @param attributes Mutation attributes */ public boolean checkAndPut(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, ByteBuffer value, Mutation mput, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, IllegalArgument, org.apache.thrift.TException; } public interface AsyncIface { public void enableTable(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void disableTable(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void isTableEnabled(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void compact(ByteBuffer tableNameOrRegionName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void majorCompact(ByteBuffer tableNameOrRegionName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void getTableNames(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void getColumnDescriptors(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void getTableRegions(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void createTable(ByteBuffer tableName, List<ColumnDescriptor> columnFamilies, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void deleteTable(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void get(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void getVer(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, int numVersions, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void getVerTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, int numVersions, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void getRow(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void getRowWithColumns(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void getRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void getRowWithColumnsTs(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void getRows(ByteBuffer tableName, List<ByteBuffer> rows, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void getRowsWithColumns(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void getRowsTs(ByteBuffer tableName, List<ByteBuffer> rows, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void getRowsWithColumnsTs(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void mutateRow(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void mutateRowTs(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void mutateRows(ByteBuffer tableName, List<BatchMutation> rowBatches, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void mutateRowsTs(ByteBuffer tableName, List<BatchMutation> rowBatches, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void atomicIncrement(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long value, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void deleteAll(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void deleteAllTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void deleteAllRow(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void increment(TIncrement increment, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void incrementRows(List<TIncrement> increments, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void deleteAllRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void scannerOpenWithScan(ByteBuffer tableName, TScan scan, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void scannerOpen(ByteBuffer tableName, ByteBuffer startRow, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void scannerOpenWithStop(ByteBuffer tableName, ByteBuffer startRow, ByteBuffer stopRow, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void scannerOpenWithPrefix(ByteBuffer tableName, ByteBuffer startAndPrefix, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void scannerOpenTs(ByteBuffer tableName, ByteBuffer startRow, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void scannerOpenWithStopTs(ByteBuffer tableName, ByteBuffer startRow, ByteBuffer stopRow, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void scannerGet(int id, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void scannerGetList(int id, int nbRows, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void scannerClose(int id, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void getRegionInfo(ByteBuffer row, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void append(TAppend append, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; public void checkAndPut(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, ByteBuffer value, Mutation mput, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; } public static class Client extends org.apache.thrift.TServiceClient implements Iface { public static class Factory implements org.apache.thrift.TServiceClientFactory<Client> { public Factory() {} public Client getClient(org.apache.thrift.protocol.TProtocol prot) { return new Client(prot); } public Client getClient(org.apache.thrift.protocol.TProtocol iprot, org.apache.thrift.protocol.TProtocol oprot) { return new Client(iprot, oprot); } } public Client(org.apache.thrift.protocol.TProtocol prot) { super(prot, prot); } public Client(org.apache.thrift.protocol.TProtocol iprot, org.apache.thrift.protocol.TProtocol oprot) { super(iprot, oprot); } public void enableTable(ByteBuffer tableName) throws IOError, org.apache.thrift.TException { send_enableTable(tableName); recv_enableTable(); } public void send_enableTable(ByteBuffer tableName) throws org.apache.thrift.TException { enableTable_args args = new enableTable_args(); args.setTableName(tableName); sendBase("enableTable", args); } public void recv_enableTable() throws IOError, org.apache.thrift.TException { enableTable_result result = new enableTable_result(); receiveBase(result, "enableTable"); if (result.io != null) { throw result.io; } return; } public void disableTable(ByteBuffer tableName) throws IOError, org.apache.thrift.TException { send_disableTable(tableName); recv_disableTable(); } public void send_disableTable(ByteBuffer tableName) throws org.apache.thrift.TException { disableTable_args args = new disableTable_args(); args.setTableName(tableName); sendBase("disableTable", args); } public void recv_disableTable() throws IOError, org.apache.thrift.TException { disableTable_result result = new disableTable_result(); receiveBase(result, "disableTable"); if (result.io != null) { throw result.io; } return; } public boolean isTableEnabled(ByteBuffer tableName) throws IOError, org.apache.thrift.TException { send_isTableEnabled(tableName); return recv_isTableEnabled(); } public void send_isTableEnabled(ByteBuffer tableName) throws org.apache.thrift.TException { isTableEnabled_args args = new isTableEnabled_args(); args.setTableName(tableName); sendBase("isTableEnabled", args); } public boolean recv_isTableEnabled() throws IOError, org.apache.thrift.TException { isTableEnabled_result result = new isTableEnabled_result(); receiveBase(result, "isTableEnabled"); if (result.isSetSuccess()) { return result.success; } if (result.io != null) { throw result.io; } throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "isTableEnabled failed: unknown result"); } public void compact(ByteBuffer tableNameOrRegionName) throws IOError, org.apache.thrift.TException { send_compact(tableNameOrRegionName); recv_compact(); } public void send_compact(ByteBuffer tableNameOrRegionName) throws org.apache.thrift.TException { compact_args args = new compact_args(); args.setTableNameOrRegionName(tableNameOrRegionName); sendBase("compact", args); } public void recv_compact() throws IOError, org.apache.thrift.TException { compact_result result = new compact_result(); receiveBase(result, "compact"); if (result.io != null) { throw result.io; } return; } public void majorCompact(ByteBuffer tableNameOrRegionName) throws IOError, org.apache.thrift.TException { send_majorCompact(tableNameOrRegionName); recv_majorCompact(); } public void send_majorCompact(ByteBuffer tableNameOrRegionName) throws org.apache.thrift.TException { majorCompact_args args = new majorCompact_args(); args.setTableNameOrRegionName(tableNameOrRegionName); sendBase("majorCompact", args); } public void recv_majorCompact() throws IOError, org.apache.thrift.TException { majorCompact_result result = new majorCompact_result(); receiveBase(result, "majorCompact"); if (result.io != null) { throw result.io; } return; } public List<ByteBuffer> getTableNames() throws IOError, org.apache.thrift.TException { send_getTableNames(); return recv_getTableNames(); } public void send_getTableNames() throws org.apache.thrift.TException { getTableNames_args args = new getTableNames_args(); sendBase("getTableNames", args); } public List<ByteBuffer> recv_getTableNames() throws IOError, org.apache.thrift.TException { getTableNames_result result = new getTableNames_result(); receiveBase(result, "getTableNames"); if (result.isSetSuccess()) { return result.success; } if (result.io != null) { throw result.io; } throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "getTableNames failed: unknown result"); } public Map<ByteBuffer,ColumnDescriptor> getColumnDescriptors(ByteBuffer tableName) throws IOError, org.apache.thrift.TException { send_getColumnDescriptors(tableName); return recv_getColumnDescriptors(); } public void send_getColumnDescriptors(ByteBuffer tableName) throws org.apache.thrift.TException { getColumnDescriptors_args args = new getColumnDescriptors_args(); args.setTableName(tableName); sendBase("getColumnDescriptors", args); } public Map<ByteBuffer,ColumnDescriptor> recv_getColumnDescriptors() throws IOError, org.apache.thrift.TException { getColumnDescriptors_result result = new getColumnDescriptors_result(); receiveBase(result, "getColumnDescriptors"); if (result.isSetSuccess()) { return result.success; } if (result.io != null) { throw result.io; } throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "getColumnDescriptors failed: unknown result"); } public List<TRegionInfo> getTableRegions(ByteBuffer tableName) throws IOError, org.apache.thrift.TException { send_getTableRegions(tableName); return recv_getTableRegions(); } public void send_getTableRegions(ByteBuffer tableName) throws org.apache.thrift.TException { getTableRegions_args args = new getTableRegions_args(); args.setTableName(tableName); sendBase("getTableRegions", args); } public List<TRegionInfo> recv_getTableRegions() throws IOError, org.apache.thrift.TException { getTableRegions_result result = new getTableRegions_result(); receiveBase(result, "getTableRegions"); if (result.isSetSuccess()) { return result.success; } if (result.io != null) { throw result.io; } throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "getTableRegions failed: unknown result"); } public void createTable(ByteBuffer tableName, List<ColumnDescriptor> columnFamilies) throws IOError, IllegalArgument, AlreadyExists, org.apache.thrift.TException { send_createTable(tableName, columnFamilies); recv_createTable(); } public void send_createTable(ByteBuffer tableName, List<ColumnDescriptor> columnFamilies) throws org.apache.thrift.TException { createTable_args args = new createTable_args(); args.setTableName(tableName); args.setColumnFamilies(columnFamilies); sendBase("createTable", args); } public void recv_createTable() throws IOError, IllegalArgument, AlreadyExists, org.apache.thrift.TException { createTable_result result = new createTable_result(); receiveBase(result, "createTable"); if (result.io != null) { throw result.io; } if (result.ia != null) { throw result.ia; } if (result.exist != null) { throw result.exist; } return; } public void deleteTable(ByteBuffer tableName) throws IOError, org.apache.thrift.TException { send_deleteTable(tableName); recv_deleteTable(); } public void send_deleteTable(ByteBuffer tableName) throws org.apache.thrift.TException { deleteTable_args args = new deleteTable_args(); args.setTableName(tableName); sendBase("deleteTable", args); } public void recv_deleteTable() throws IOError, org.apache.thrift.TException { deleteTable_result result = new deleteTable_result(); receiveBase(result, "deleteTable"); if (result.io != null) { throw result.io; } return; } public List<TCell> get(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException { send_get(tableName, row, column, attributes); return recv_get(); } public void send_get(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException { get_args args = new get_args(); args.setTableName(tableName); args.setRow(row); args.setColumn(column); args.setAttributes(attributes); sendBase("get", args); } public List<TCell> recv_get() throws IOError, org.apache.thrift.TException { get_result result = new get_result(); receiveBase(result, "get"); if (result.isSetSuccess()) { return result.success; } if (result.io != null) { throw result.io; } throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "get failed: unknown result"); } public List<TCell> getVer(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, int numVersions, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException { send_getVer(tableName, row, column, numVersions, attributes); return recv_getVer(); } public void send_getVer(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, int numVersions, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException { getVer_args args = new getVer_args(); args.setTableName(tableName); args.setRow(row); args.setColumn(column); args.setNumVersions(numVersions); args.setAttributes(attributes); sendBase("getVer", args); } public List<TCell> recv_getVer() throws IOError, org.apache.thrift.TException { getVer_result result = new getVer_result(); receiveBase(result, "getVer"); if (result.isSetSuccess()) { return result.success; } if (result.io != null) { throw result.io; } throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "getVer failed: unknown result"); } public List<TCell> getVerTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, int numVersions, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException { send_getVerTs(tableName, row, column, timestamp, numVersions, attributes); return recv_getVerTs(); } public void send_getVerTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, int numVersions, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException { getVerTs_args args = new getVerTs_args(); args.setTableName(tableName); args.setRow(row); args.setColumn(column); args.setTimestamp(timestamp); args.setNumVersions(numVersions); args.setAttributes(attributes); sendBase("getVerTs", args); } public List<TCell> recv_getVerTs() throws IOError, org.apache.thrift.TException { getVerTs_result result = new getVerTs_result(); receiveBase(result, "getVerTs"); if (result.isSetSuccess()) { return result.success; } if (result.io != null) { throw result.io; } throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "getVerTs failed: unknown result"); } public List<TRowResult> getRow(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException { send_getRow(tableName, row, attributes); return recv_getRow(); } public void send_getRow(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException { getRow_args args = new getRow_args(); args.setTableName(tableName); args.setRow(row); args.setAttributes(attributes); sendBase("getRow", args); } public List<TRowResult> recv_getRow() throws IOError, org.apache.thrift.TException { getRow_result result = new getRow_result(); receiveBase(result, "getRow"); if (result.isSetSuccess()) { return result.success; } if (result.io != null) { throw result.io; } throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "getRow failed: unknown result"); } public List<TRowResult> getRowWithColumns(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException { send_getRowWithColumns(tableName, row, columns, attributes); return recv_getRowWithColumns(); } public void send_getRowWithColumns(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException { getRowWithColumns_args args = new getRowWithColumns_args(); args.setTableName(tableName); args.setRow(row); args.setColumns(columns); args.setAttributes(attributes); sendBase("getRowWithColumns", args); } public List<TRowResult> recv_getRowWithColumns() throws IOError, org.apache.thrift.TException { getRowWithColumns_result result = new getRowWithColumns_result(); receiveBase(result, "getRowWithColumns"); if (result.isSetSuccess()) { return result.success; } if (result.io != null) { throw result.io; } throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "getRowWithColumns failed: unknown result"); } public List<TRowResult> getRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException { send_getRowTs(tableName, row, timestamp, attributes); return recv_getRowTs(); } public void send_getRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException { getRowTs_args args = new getRowTs_args(); args.setTableName(tableName); args.setRow(row); args.setTimestamp(timestamp); args.setAttributes(attributes); sendBase("getRowTs", args); } public List<TRowResult> recv_getRowTs() throws IOError, org.apache.thrift.TException { getRowTs_result result = new getRowTs_result(); receiveBase(result, "getRowTs"); if (result.isSetSuccess()) { return result.success; } if (result.io != null) { throw result.io; } throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "getRowTs failed: unknown result"); } public List<TRowResult> getRowWithColumnsTs(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException { send_getRowWithColumnsTs(tableName, row, columns, timestamp, attributes); return recv_getRowWithColumnsTs(); } public void send_getRowWithColumnsTs(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException { getRowWithColumnsTs_args args = new getRowWithColumnsTs_args(); args.setTableName(tableName); args.setRow(row); args.setColumns(columns); args.setTimestamp(timestamp); args.setAttributes(attributes); sendBase("getRowWithColumnsTs", args); } public List<TRowResult> recv_getRowWithColumnsTs() throws IOError, org.apache.thrift.TException { getRowWithColumnsTs_result result = new getRowWithColumnsTs_result(); receiveBase(result, "getRowWithColumnsTs"); if (result.isSetSuccess()) { return result.success; } if (result.io != null) { throw result.io; } throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "getRowWithColumnsTs failed: unknown result"); } public List<TRowResult> getRows(ByteBuffer tableName, List<ByteBuffer> rows, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException { send_getRows(tableName, rows, attributes); return recv_getRows(); } public void send_getRows(ByteBuffer tableName, List<ByteBuffer> rows, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException { getRows_args args = new getRows_args(); args.setTableName(tableName); args.setRows(rows); args.setAttributes(attributes); sendBase("getRows", args); } public List<TRowResult> recv_getRows() throws IOError, org.apache.thrift.TException { getRows_result result = new getRows_result(); receiveBase(result, "getRows"); if (result.isSetSuccess()) { return result.success; } if (result.io != null) { throw result.io; } throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "getRows failed: unknown result"); } public List<TRowResult> getRowsWithColumns(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException { send_getRowsWithColumns(tableName, rows, columns, attributes); return recv_getRowsWithColumns(); } public void send_getRowsWithColumns(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException { getRowsWithColumns_args args = new getRowsWithColumns_args(); args.setTableName(tableName); args.setRows(rows); args.setColumns(columns); args.setAttributes(attributes); sendBase("getRowsWithColumns", args); } public List<TRowResult> recv_getRowsWithColumns() throws IOError, org.apache.thrift.TException { getRowsWithColumns_result result = new getRowsWithColumns_result(); receiveBase(result, "getRowsWithColumns"); if (result.isSetSuccess()) { return result.success; } if (result.io != null) { throw result.io; } throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "getRowsWithColumns failed: unknown result"); } public List<TRowResult> getRowsTs(ByteBuffer tableName, List<ByteBuffer> rows, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException { send_getRowsTs(tableName, rows, timestamp, attributes); return recv_getRowsTs(); } public void send_getRowsTs(ByteBuffer tableName, List<ByteBuffer> rows, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException { getRowsTs_args args = new getRowsTs_args(); args.setTableName(tableName); args.setRows(rows); args.setTimestamp(timestamp); args.setAttributes(attributes); sendBase("getRowsTs", args); } public List<TRowResult> recv_getRowsTs() throws IOError, org.apache.thrift.TException { getRowsTs_result result = new getRowsTs_result(); receiveBase(result, "getRowsTs"); if (result.isSetSuccess()) { return result.success; } if (result.io != null) { throw result.io; } throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "getRowsTs failed: unknown result"); } public List<TRowResult> getRowsWithColumnsTs(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException { send_getRowsWithColumnsTs(tableName, rows, columns, timestamp, attributes); return recv_getRowsWithColumnsTs(); } public void send_getRowsWithColumnsTs(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException { getRowsWithColumnsTs_args args = new getRowsWithColumnsTs_args(); args.setTableName(tableName); args.setRows(rows); args.setColumns(columns); args.setTimestamp(timestamp); args.setAttributes(attributes); sendBase("getRowsWithColumnsTs", args); } public List<TRowResult> recv_getRowsWithColumnsTs() throws IOError, org.apache.thrift.TException { getRowsWithColumnsTs_result result = new getRowsWithColumnsTs_result(); receiveBase(result, "getRowsWithColumnsTs"); if (result.isSetSuccess()) { return result.success; } if (result.io != null) { throw result.io; } throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "getRowsWithColumnsTs failed: unknown result"); } public void mutateRow(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, IllegalArgument, org.apache.thrift.TException { send_mutateRow(tableName, row, mutations, attributes); recv_mutateRow(); } public void send_mutateRow(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException { mutateRow_args args = new mutateRow_args(); args.setTableName(tableName); args.setRow(row); args.setMutations(mutations); args.setAttributes(attributes); sendBase("mutateRow", args); } public void recv_mutateRow() throws IOError, IllegalArgument, org.apache.thrift.TException { mutateRow_result result = new mutateRow_result(); receiveBase(result, "mutateRow"); if (result.io != null) { throw result.io; } if (result.ia != null) { throw result.ia; } return; } public void mutateRowTs(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, IllegalArgument, org.apache.thrift.TException { send_mutateRowTs(tableName, row, mutations, timestamp, attributes); recv_mutateRowTs(); } public void send_mutateRowTs(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException { mutateRowTs_args args = new mutateRowTs_args(); args.setTableName(tableName); args.setRow(row); args.setMutations(mutations); args.setTimestamp(timestamp); args.setAttributes(attributes); sendBase("mutateRowTs", args); } public void recv_mutateRowTs() throws IOError, IllegalArgument, org.apache.thrift.TException { mutateRowTs_result result = new mutateRowTs_result(); receiveBase(result, "mutateRowTs"); if (result.io != null) { throw result.io; } if (result.ia != null) { throw result.ia; } return; } public void mutateRows(ByteBuffer tableName, List<BatchMutation> rowBatches, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, IllegalArgument, org.apache.thrift.TException { send_mutateRows(tableName, rowBatches, attributes); recv_mutateRows(); } public void send_mutateRows(ByteBuffer tableName, List<BatchMutation> rowBatches, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException { mutateRows_args args = new mutateRows_args(); args.setTableName(tableName); args.setRowBatches(rowBatches); args.setAttributes(attributes); sendBase("mutateRows", args); } public void recv_mutateRows() throws IOError, IllegalArgument, org.apache.thrift.TException { mutateRows_result result = new mutateRows_result(); receiveBase(result, "mutateRows"); if (result.io != null) { throw result.io; } if (result.ia != null) { throw result.ia; } return; } public void mutateRowsTs(ByteBuffer tableName, List<BatchMutation> rowBatches, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, IllegalArgument, org.apache.thrift.TException { send_mutateRowsTs(tableName, rowBatches, timestamp, attributes); recv_mutateRowsTs(); } public void send_mutateRowsTs(ByteBuffer tableName, List<BatchMutation> rowBatches, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException { mutateRowsTs_args args = new mutateRowsTs_args(); args.setTableName(tableName); args.setRowBatches(rowBatches); args.setTimestamp(timestamp); args.setAttributes(attributes); sendBase("mutateRowsTs", args); } public void recv_mutateRowsTs() throws IOError, IllegalArgument, org.apache.thrift.TException { mutateRowsTs_result result = new mutateRowsTs_result(); receiveBase(result, "mutateRowsTs"); if (result.io != null) { throw result.io; } if (result.ia != null) { throw result.ia; } return; } public long atomicIncrement(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long value) throws IOError, IllegalArgument, org.apache.thrift.TException { send_atomicIncrement(tableName, row, column, value); return recv_atomicIncrement(); } public void send_atomicIncrement(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long value) throws org.apache.thrift.TException { atomicIncrement_args args = new atomicIncrement_args(); args.setTableName(tableName); args.setRow(row); args.setColumn(column); args.setValue(value); sendBase("atomicIncrement", args); } public long recv_atomicIncrement() throws IOError, IllegalArgument, org.apache.thrift.TException { atomicIncrement_result result = new atomicIncrement_result(); receiveBase(result, "atomicIncrement"); if (result.isSetSuccess()) { return result.success; } if (result.io != null) { throw result.io; } if (result.ia != null) { throw result.ia; } throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "atomicIncrement failed: unknown result"); } public void deleteAll(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException { send_deleteAll(tableName, row, column, attributes); recv_deleteAll(); } public void send_deleteAll(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException { deleteAll_args args = new deleteAll_args(); args.setTableName(tableName); args.setRow(row); args.setColumn(column); args.setAttributes(attributes); sendBase("deleteAll", args); } public void recv_deleteAll() throws IOError, org.apache.thrift.TException { deleteAll_result result = new deleteAll_result(); receiveBase(result, "deleteAll"); if (result.io != null) { throw result.io; } return; } public void deleteAllTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException { send_deleteAllTs(tableName, row, column, timestamp, attributes); recv_deleteAllTs(); } public void send_deleteAllTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException { deleteAllTs_args args = new deleteAllTs_args(); args.setTableName(tableName); args.setRow(row); args.setColumn(column); args.setTimestamp(timestamp); args.setAttributes(attributes); sendBase("deleteAllTs", args); } public void recv_deleteAllTs() throws IOError, org.apache.thrift.TException { deleteAllTs_result result = new deleteAllTs_result(); receiveBase(result, "deleteAllTs"); if (result.io != null) { throw result.io; } return; } public void deleteAllRow(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException { send_deleteAllRow(tableName, row, attributes); recv_deleteAllRow(); } public void send_deleteAllRow(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException { deleteAllRow_args args = new deleteAllRow_args(); args.setTableName(tableName); args.setRow(row); args.setAttributes(attributes); sendBase("deleteAllRow", args); } public void recv_deleteAllRow() throws IOError, org.apache.thrift.TException { deleteAllRow_result result = new deleteAllRow_result(); receiveBase(result, "deleteAllRow"); if (result.io != null) { throw result.io; } return; } public void increment(TIncrement increment) throws IOError, org.apache.thrift.TException { send_increment(increment); recv_increment(); } public void send_increment(TIncrement increment) throws org.apache.thrift.TException { increment_args args = new increment_args(); args.setIncrement(increment); sendBase("increment", args); } public void recv_increment() throws IOError, org.apache.thrift.TException { increment_result result = new increment_result(); receiveBase(result, "increment"); if (result.io != null) { throw result.io; } return; } public void incrementRows(List<TIncrement> increments) throws IOError, org.apache.thrift.TException { send_incrementRows(increments); recv_incrementRows(); } public void send_incrementRows(List<TIncrement> increments) throws org.apache.thrift.TException { incrementRows_args args = new incrementRows_args(); args.setIncrements(increments); sendBase("incrementRows", args); } public void recv_incrementRows() throws IOError, org.apache.thrift.TException { incrementRows_result result = new incrementRows_result(); receiveBase(result, "incrementRows"); if (result.io != null) { throw result.io; } return; } public void deleteAllRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException { send_deleteAllRowTs(tableName, row, timestamp, attributes); recv_deleteAllRowTs(); } public void send_deleteAllRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException { deleteAllRowTs_args args = new deleteAllRowTs_args(); args.setTableName(tableName); args.setRow(row); args.setTimestamp(timestamp); args.setAttributes(attributes); sendBase("deleteAllRowTs", args); } public void recv_deleteAllRowTs() throws IOError, org.apache.thrift.TException { deleteAllRowTs_result result = new deleteAllRowTs_result(); receiveBase(result, "deleteAllRowTs"); if (result.io != null) { throw result.io; } return; } public int scannerOpenWithScan(ByteBuffer tableName, TScan scan, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException { send_scannerOpenWithScan(tableName, scan, attributes); return recv_scannerOpenWithScan(); } public void send_scannerOpenWithScan(ByteBuffer tableName, TScan scan, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException { scannerOpenWithScan_args args = new scannerOpenWithScan_args(); args.setTableName(tableName); args.setScan(scan); args.setAttributes(attributes); sendBase("scannerOpenWithScan", args); } public int recv_scannerOpenWithScan() throws IOError, org.apache.thrift.TException { scannerOpenWithScan_result result = new scannerOpenWithScan_result(); receiveBase(result, "scannerOpenWithScan"); if (result.isSetSuccess()) { return result.success; } if (result.io != null) { throw result.io; } throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "scannerOpenWithScan failed: unknown result"); } public int scannerOpen(ByteBuffer tableName, ByteBuffer startRow, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException { send_scannerOpen(tableName, startRow, columns, attributes); return recv_scannerOpen(); } public void send_scannerOpen(ByteBuffer tableName, ByteBuffer startRow, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException { scannerOpen_args args = new scannerOpen_args(); args.setTableName(tableName); args.setStartRow(startRow); args.setColumns(columns); args.setAttributes(attributes); sendBase("scannerOpen", args); } public int recv_scannerOpen() throws IOError, org.apache.thrift.TException { scannerOpen_result result = new scannerOpen_result(); receiveBase(result, "scannerOpen"); if (result.isSetSuccess()) { return result.success; } if (result.io != null) { throw result.io; } throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "scannerOpen failed: unknown result"); } public int scannerOpenWithStop(ByteBuffer tableName, ByteBuffer startRow, ByteBuffer stopRow, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException { send_scannerOpenWithStop(tableName, startRow, stopRow, columns, attributes); return recv_scannerOpenWithStop(); } public void send_scannerOpenWithStop(ByteBuffer tableName, ByteBuffer startRow, ByteBuffer stopRow, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException { scannerOpenWithStop_args args = new scannerOpenWithStop_args(); args.setTableName(tableName); args.setStartRow(startRow); args.setStopRow(stopRow); args.setColumns(columns); args.setAttributes(attributes); sendBase("scannerOpenWithStop", args); } public int recv_scannerOpenWithStop() throws IOError, org.apache.thrift.TException { scannerOpenWithStop_result result = new scannerOpenWithStop_result(); receiveBase(result, "scannerOpenWithStop"); if (result.isSetSuccess()) { return result.success; } if (result.io != null) { throw result.io; } throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "scannerOpenWithStop failed: unknown result"); } public int scannerOpenWithPrefix(ByteBuffer tableName, ByteBuffer startAndPrefix, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException { send_scannerOpenWithPrefix(tableName, startAndPrefix, columns, attributes); return recv_scannerOpenWithPrefix(); } public void send_scannerOpenWithPrefix(ByteBuffer tableName, ByteBuffer startAndPrefix, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException { scannerOpenWithPrefix_args args = new scannerOpenWithPrefix_args(); args.setTableName(tableName); args.setStartAndPrefix(startAndPrefix); args.setColumns(columns); args.setAttributes(attributes); sendBase("scannerOpenWithPrefix", args); } public int recv_scannerOpenWithPrefix() throws IOError, org.apache.thrift.TException { scannerOpenWithPrefix_result result = new scannerOpenWithPrefix_result(); receiveBase(result, "scannerOpenWithPrefix"); if (result.isSetSuccess()) { return result.success; } if (result.io != null) { throw result.io; } throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "scannerOpenWithPrefix failed: unknown result"); } public int scannerOpenTs(ByteBuffer tableName, ByteBuffer startRow, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException { send_scannerOpenTs(tableName, startRow, columns, timestamp, attributes); return recv_scannerOpenTs(); } public void send_scannerOpenTs(ByteBuffer tableName, ByteBuffer startRow, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException { scannerOpenTs_args args = new scannerOpenTs_args(); args.setTableName(tableName); args.setStartRow(startRow); args.setColumns(columns); args.setTimestamp(timestamp); args.setAttributes(attributes); sendBase("scannerOpenTs", args); } public int recv_scannerOpenTs() throws IOError, org.apache.thrift.TException { scannerOpenTs_result result = new scannerOpenTs_result(); receiveBase(result, "scannerOpenTs"); if (result.isSetSuccess()) { return result.success; } if (result.io != null) { throw result.io; } throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "scannerOpenTs failed: unknown result"); } public int scannerOpenWithStopTs(ByteBuffer tableName, ByteBuffer startRow, ByteBuffer stopRow, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, org.apache.thrift.TException { send_scannerOpenWithStopTs(tableName, startRow, stopRow, columns, timestamp, attributes); return recv_scannerOpenWithStopTs(); } public void send_scannerOpenWithStopTs(ByteBuffer tableName, ByteBuffer startRow, ByteBuffer stopRow, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException { scannerOpenWithStopTs_args args = new scannerOpenWithStopTs_args(); args.setTableName(tableName); args.setStartRow(startRow); args.setStopRow(stopRow); args.setColumns(columns); args.setTimestamp(timestamp); args.setAttributes(attributes); sendBase("scannerOpenWithStopTs", args); } public int recv_scannerOpenWithStopTs() throws IOError, org.apache.thrift.TException { scannerOpenWithStopTs_result result = new scannerOpenWithStopTs_result(); receiveBase(result, "scannerOpenWithStopTs"); if (result.isSetSuccess()) { return result.success; } if (result.io != null) { throw result.io; } throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "scannerOpenWithStopTs failed: unknown result"); } public List<TRowResult> scannerGet(int id) throws IOError, IllegalArgument, org.apache.thrift.TException { send_scannerGet(id); return recv_scannerGet(); } public void send_scannerGet(int id) throws org.apache.thrift.TException { scannerGet_args args = new scannerGet_args(); args.setId(id); sendBase("scannerGet", args); } public List<TRowResult> recv_scannerGet() throws IOError, IllegalArgument, org.apache.thrift.TException { scannerGet_result result = new scannerGet_result(); receiveBase(result, "scannerGet"); if (result.isSetSuccess()) { return result.success; } if (result.io != null) { throw result.io; } if (result.ia != null) { throw result.ia; } throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "scannerGet failed: unknown result"); } public List<TRowResult> scannerGetList(int id, int nbRows) throws IOError, IllegalArgument, org.apache.thrift.TException { send_scannerGetList(id, nbRows); return recv_scannerGetList(); } public void send_scannerGetList(int id, int nbRows) throws org.apache.thrift.TException { scannerGetList_args args = new scannerGetList_args(); args.setId(id); args.setNbRows(nbRows); sendBase("scannerGetList", args); } public List<TRowResult> recv_scannerGetList() throws IOError, IllegalArgument, org.apache.thrift.TException { scannerGetList_result result = new scannerGetList_result(); receiveBase(result, "scannerGetList"); if (result.isSetSuccess()) { return result.success; } if (result.io != null) { throw result.io; } if (result.ia != null) { throw result.ia; } throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "scannerGetList failed: unknown result"); } public void scannerClose(int id) throws IOError, IllegalArgument, org.apache.thrift.TException { send_scannerClose(id); recv_scannerClose(); } public void send_scannerClose(int id) throws org.apache.thrift.TException { scannerClose_args args = new scannerClose_args(); args.setId(id); sendBase("scannerClose", args); } public void recv_scannerClose() throws IOError, IllegalArgument, org.apache.thrift.TException { scannerClose_result result = new scannerClose_result(); receiveBase(result, "scannerClose"); if (result.io != null) { throw result.io; } if (result.ia != null) { throw result.ia; } return; } public TRegionInfo getRegionInfo(ByteBuffer row) throws IOError, org.apache.thrift.TException { send_getRegionInfo(row); return recv_getRegionInfo(); } public void send_getRegionInfo(ByteBuffer row) throws org.apache.thrift.TException { getRegionInfo_args args = new getRegionInfo_args(); args.setRow(row); sendBase("getRegionInfo", args); } public TRegionInfo recv_getRegionInfo() throws IOError, org.apache.thrift.TException { getRegionInfo_result result = new getRegionInfo_result(); receiveBase(result, "getRegionInfo"); if (result.isSetSuccess()) { return result.success; } if (result.io != null) { throw result.io; } throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "getRegionInfo failed: unknown result"); } public List<TCell> append(TAppend append) throws IOError, org.apache.thrift.TException { send_append(append); return recv_append(); } public void send_append(TAppend append) throws org.apache.thrift.TException { append_args args = new append_args(); args.setAppend(append); sendBase("append", args); } public List<TCell> recv_append() throws IOError, org.apache.thrift.TException { append_result result = new append_result(); receiveBase(result, "append"); if (result.isSetSuccess()) { return result.success; } if (result.io != null) { throw result.io; } throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "append failed: unknown result"); } public boolean checkAndPut(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, ByteBuffer value, Mutation mput, Map<ByteBuffer,ByteBuffer> attributes) throws IOError, IllegalArgument, org.apache.thrift.TException { send_checkAndPut(tableName, row, column, value, mput, attributes); return recv_checkAndPut(); } public void send_checkAndPut(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, ByteBuffer value, Mutation mput, Map<ByteBuffer,ByteBuffer> attributes) throws org.apache.thrift.TException { checkAndPut_args args = new checkAndPut_args(); args.setTableName(tableName); args.setRow(row); args.setColumn(column); args.setValue(value); args.setMput(mput); args.setAttributes(attributes); sendBase("checkAndPut", args); } public boolean recv_checkAndPut() throws IOError, IllegalArgument, org.apache.thrift.TException { checkAndPut_result result = new checkAndPut_result(); receiveBase(result, "checkAndPut"); if (result.isSetSuccess()) { return result.success; } if (result.io != null) { throw result.io; } if (result.ia != null) { throw result.ia; } throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "checkAndPut failed: unknown result"); } } public static class AsyncClient extends org.apache.thrift.async.TAsyncClient implements AsyncIface { public static class Factory implements org.apache.thrift.async.TAsyncClientFactory<AsyncClient> { private org.apache.thrift.async.TAsyncClientManager clientManager; private org.apache.thrift.protocol.TProtocolFactory protocolFactory; public Factory(org.apache.thrift.async.TAsyncClientManager clientManager, org.apache.thrift.protocol.TProtocolFactory protocolFactory) { this.clientManager = clientManager; this.protocolFactory = protocolFactory; } public AsyncClient getAsyncClient(org.apache.thrift.transport.TNonblockingTransport transport) { return new AsyncClient(protocolFactory, clientManager, transport); } } public AsyncClient(org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.async.TAsyncClientManager clientManager, org.apache.thrift.transport.TNonblockingTransport transport) { super(protocolFactory, clientManager, transport); } public void enableTable(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); enableTable_call method_call = new enableTable_call(tableName, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class enableTable_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; public enableTable_call(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("enableTable", org.apache.thrift.protocol.TMessageType.CALL, 0)); enableTable_args args = new enableTable_args(); args.setTableName(tableName); args.write(prot); prot.writeMessageEnd(); } public void getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); (new Client(prot)).recv_enableTable(); } } public void disableTable(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); disableTable_call method_call = new disableTable_call(tableName, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class disableTable_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; public disableTable_call(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("disableTable", org.apache.thrift.protocol.TMessageType.CALL, 0)); disableTable_args args = new disableTable_args(); args.setTableName(tableName); args.write(prot); prot.writeMessageEnd(); } public void getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); (new Client(prot)).recv_disableTable(); } } public void isTableEnabled(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); isTableEnabled_call method_call = new isTableEnabled_call(tableName, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class isTableEnabled_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; public isTableEnabled_call(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("isTableEnabled", org.apache.thrift.protocol.TMessageType.CALL, 0)); isTableEnabled_args args = new isTableEnabled_args(); args.setTableName(tableName); args.write(prot); prot.writeMessageEnd(); } public boolean getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); return (new Client(prot)).recv_isTableEnabled(); } } public void compact(ByteBuffer tableNameOrRegionName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); compact_call method_call = new compact_call(tableNameOrRegionName, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class compact_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableNameOrRegionName; public compact_call(ByteBuffer tableNameOrRegionName, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableNameOrRegionName = tableNameOrRegionName; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("compact", org.apache.thrift.protocol.TMessageType.CALL, 0)); compact_args args = new compact_args(); args.setTableNameOrRegionName(tableNameOrRegionName); args.write(prot); prot.writeMessageEnd(); } public void getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); (new Client(prot)).recv_compact(); } } public void majorCompact(ByteBuffer tableNameOrRegionName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); majorCompact_call method_call = new majorCompact_call(tableNameOrRegionName, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class majorCompact_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableNameOrRegionName; public majorCompact_call(ByteBuffer tableNameOrRegionName, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableNameOrRegionName = tableNameOrRegionName; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("majorCompact", org.apache.thrift.protocol.TMessageType.CALL, 0)); majorCompact_args args = new majorCompact_args(); args.setTableNameOrRegionName(tableNameOrRegionName); args.write(prot); prot.writeMessageEnd(); } public void getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); (new Client(prot)).recv_majorCompact(); } } public void getTableNames(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); getTableNames_call method_call = new getTableNames_call(resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class getTableNames_call extends org.apache.thrift.async.TAsyncMethodCall { public getTableNames_call(org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("getTableNames", org.apache.thrift.protocol.TMessageType.CALL, 0)); getTableNames_args args = new getTableNames_args(); args.write(prot); prot.writeMessageEnd(); } public List<ByteBuffer> getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); return (new Client(prot)).recv_getTableNames(); } } public void getColumnDescriptors(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); getColumnDescriptors_call method_call = new getColumnDescriptors_call(tableName, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class getColumnDescriptors_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; public getColumnDescriptors_call(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("getColumnDescriptors", org.apache.thrift.protocol.TMessageType.CALL, 0)); getColumnDescriptors_args args = new getColumnDescriptors_args(); args.setTableName(tableName); args.write(prot); prot.writeMessageEnd(); } public Map<ByteBuffer,ColumnDescriptor> getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); return (new Client(prot)).recv_getColumnDescriptors(); } } public void getTableRegions(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); getTableRegions_call method_call = new getTableRegions_call(tableName, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class getTableRegions_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; public getTableRegions_call(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("getTableRegions", org.apache.thrift.protocol.TMessageType.CALL, 0)); getTableRegions_args args = new getTableRegions_args(); args.setTableName(tableName); args.write(prot); prot.writeMessageEnd(); } public List<TRegionInfo> getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); return (new Client(prot)).recv_getTableRegions(); } } public void createTable(ByteBuffer tableName, List<ColumnDescriptor> columnFamilies, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); createTable_call method_call = new createTable_call(tableName, columnFamilies, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class createTable_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; private List<ColumnDescriptor> columnFamilies; public createTable_call(ByteBuffer tableName, List<ColumnDescriptor> columnFamilies, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; this.columnFamilies = columnFamilies; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("createTable", org.apache.thrift.protocol.TMessageType.CALL, 0)); createTable_args args = new createTable_args(); args.setTableName(tableName); args.setColumnFamilies(columnFamilies); args.write(prot); prot.writeMessageEnd(); } public void getResult() throws IOError, IllegalArgument, AlreadyExists, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); (new Client(prot)).recv_createTable(); } } public void deleteTable(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); deleteTable_call method_call = new deleteTable_call(tableName, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class deleteTable_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; public deleteTable_call(ByteBuffer tableName, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("deleteTable", org.apache.thrift.protocol.TMessageType.CALL, 0)); deleteTable_args args = new deleteTable_args(); args.setTableName(tableName); args.write(prot); prot.writeMessageEnd(); } public void getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); (new Client(prot)).recv_deleteTable(); } } public void get(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); get_call method_call = new get_call(tableName, row, column, attributes, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class get_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; private ByteBuffer row; private ByteBuffer column; private Map<ByteBuffer,ByteBuffer> attributes; public get_call(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; this.row = row; this.column = column; this.attributes = attributes; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("get", org.apache.thrift.protocol.TMessageType.CALL, 0)); get_args args = new get_args(); args.setTableName(tableName); args.setRow(row); args.setColumn(column); args.setAttributes(attributes); args.write(prot); prot.writeMessageEnd(); } public List<TCell> getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); return (new Client(prot)).recv_get(); } } public void getVer(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, int numVersions, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); getVer_call method_call = new getVer_call(tableName, row, column, numVersions, attributes, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class getVer_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; private ByteBuffer row; private ByteBuffer column; private int numVersions; private Map<ByteBuffer,ByteBuffer> attributes; public getVer_call(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, int numVersions, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; this.row = row; this.column = column; this.numVersions = numVersions; this.attributes = attributes; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("getVer", org.apache.thrift.protocol.TMessageType.CALL, 0)); getVer_args args = new getVer_args(); args.setTableName(tableName); args.setRow(row); args.setColumn(column); args.setNumVersions(numVersions); args.setAttributes(attributes); args.write(prot); prot.writeMessageEnd(); } public List<TCell> getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); return (new Client(prot)).recv_getVer(); } } public void getVerTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, int numVersions, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); getVerTs_call method_call = new getVerTs_call(tableName, row, column, timestamp, numVersions, attributes, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class getVerTs_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; private ByteBuffer row; private ByteBuffer column; private long timestamp; private int numVersions; private Map<ByteBuffer,ByteBuffer> attributes; public getVerTs_call(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, int numVersions, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; this.row = row; this.column = column; this.timestamp = timestamp; this.numVersions = numVersions; this.attributes = attributes; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("getVerTs", org.apache.thrift.protocol.TMessageType.CALL, 0)); getVerTs_args args = new getVerTs_args(); args.setTableName(tableName); args.setRow(row); args.setColumn(column); args.setTimestamp(timestamp); args.setNumVersions(numVersions); args.setAttributes(attributes); args.write(prot); prot.writeMessageEnd(); } public List<TCell> getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); return (new Client(prot)).recv_getVerTs(); } } public void getRow(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); getRow_call method_call = new getRow_call(tableName, row, attributes, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class getRow_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; private ByteBuffer row; private Map<ByteBuffer,ByteBuffer> attributes; public getRow_call(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; this.row = row; this.attributes = attributes; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("getRow", org.apache.thrift.protocol.TMessageType.CALL, 0)); getRow_args args = new getRow_args(); args.setTableName(tableName); args.setRow(row); args.setAttributes(attributes); args.write(prot); prot.writeMessageEnd(); } public List<TRowResult> getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); return (new Client(prot)).recv_getRow(); } } public void getRowWithColumns(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); getRowWithColumns_call method_call = new getRowWithColumns_call(tableName, row, columns, attributes, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class getRowWithColumns_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; private ByteBuffer row; private List<ByteBuffer> columns; private Map<ByteBuffer,ByteBuffer> attributes; public getRowWithColumns_call(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; this.row = row; this.columns = columns; this.attributes = attributes; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("getRowWithColumns", org.apache.thrift.protocol.TMessageType.CALL, 0)); getRowWithColumns_args args = new getRowWithColumns_args(); args.setTableName(tableName); args.setRow(row); args.setColumns(columns); args.setAttributes(attributes); args.write(prot); prot.writeMessageEnd(); } public List<TRowResult> getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); return (new Client(prot)).recv_getRowWithColumns(); } } public void getRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); getRowTs_call method_call = new getRowTs_call(tableName, row, timestamp, attributes, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class getRowTs_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; private ByteBuffer row; private long timestamp; private Map<ByteBuffer,ByteBuffer> attributes; public getRowTs_call(ByteBuffer tableName, ByteBuffer row, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; this.row = row; this.timestamp = timestamp; this.attributes = attributes; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("getRowTs", org.apache.thrift.protocol.TMessageType.CALL, 0)); getRowTs_args args = new getRowTs_args(); args.setTableName(tableName); args.setRow(row); args.setTimestamp(timestamp); args.setAttributes(attributes); args.write(prot); prot.writeMessageEnd(); } public List<TRowResult> getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); return (new Client(prot)).recv_getRowTs(); } } public void getRowWithColumnsTs(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); getRowWithColumnsTs_call method_call = new getRowWithColumnsTs_call(tableName, row, columns, timestamp, attributes, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class getRowWithColumnsTs_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; private ByteBuffer row; private List<ByteBuffer> columns; private long timestamp; private Map<ByteBuffer,ByteBuffer> attributes; public getRowWithColumnsTs_call(ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; this.row = row; this.columns = columns; this.timestamp = timestamp; this.attributes = attributes; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("getRowWithColumnsTs", org.apache.thrift.protocol.TMessageType.CALL, 0)); getRowWithColumnsTs_args args = new getRowWithColumnsTs_args(); args.setTableName(tableName); args.setRow(row); args.setColumns(columns); args.setTimestamp(timestamp); args.setAttributes(attributes); args.write(prot); prot.writeMessageEnd(); } public List<TRowResult> getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); return (new Client(prot)).recv_getRowWithColumnsTs(); } } public void getRows(ByteBuffer tableName, List<ByteBuffer> rows, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); getRows_call method_call = new getRows_call(tableName, rows, attributes, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class getRows_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; private List<ByteBuffer> rows; private Map<ByteBuffer,ByteBuffer> attributes; public getRows_call(ByteBuffer tableName, List<ByteBuffer> rows, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; this.rows = rows; this.attributes = attributes; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("getRows", org.apache.thrift.protocol.TMessageType.CALL, 0)); getRows_args args = new getRows_args(); args.setTableName(tableName); args.setRows(rows); args.setAttributes(attributes); args.write(prot); prot.writeMessageEnd(); } public List<TRowResult> getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); return (new Client(prot)).recv_getRows(); } } public void getRowsWithColumns(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); getRowsWithColumns_call method_call = new getRowsWithColumns_call(tableName, rows, columns, attributes, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class getRowsWithColumns_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; private List<ByteBuffer> rows; private List<ByteBuffer> columns; private Map<ByteBuffer,ByteBuffer> attributes; public getRowsWithColumns_call(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; this.rows = rows; this.columns = columns; this.attributes = attributes; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("getRowsWithColumns", org.apache.thrift.protocol.TMessageType.CALL, 0)); getRowsWithColumns_args args = new getRowsWithColumns_args(); args.setTableName(tableName); args.setRows(rows); args.setColumns(columns); args.setAttributes(attributes); args.write(prot); prot.writeMessageEnd(); } public List<TRowResult> getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); return (new Client(prot)).recv_getRowsWithColumns(); } } public void getRowsTs(ByteBuffer tableName, List<ByteBuffer> rows, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); getRowsTs_call method_call = new getRowsTs_call(tableName, rows, timestamp, attributes, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class getRowsTs_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; private List<ByteBuffer> rows; private long timestamp; private Map<ByteBuffer,ByteBuffer> attributes; public getRowsTs_call(ByteBuffer tableName, List<ByteBuffer> rows, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; this.rows = rows; this.timestamp = timestamp; this.attributes = attributes; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("getRowsTs", org.apache.thrift.protocol.TMessageType.CALL, 0)); getRowsTs_args args = new getRowsTs_args(); args.setTableName(tableName); args.setRows(rows); args.setTimestamp(timestamp); args.setAttributes(attributes); args.write(prot); prot.writeMessageEnd(); } public List<TRowResult> getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); return (new Client(prot)).recv_getRowsTs(); } } public void getRowsWithColumnsTs(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); getRowsWithColumnsTs_call method_call = new getRowsWithColumnsTs_call(tableName, rows, columns, timestamp, attributes, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class getRowsWithColumnsTs_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; private List<ByteBuffer> rows; private List<ByteBuffer> columns; private long timestamp; private Map<ByteBuffer,ByteBuffer> attributes; public getRowsWithColumnsTs_call(ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; this.rows = rows; this.columns = columns; this.timestamp = timestamp; this.attributes = attributes; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("getRowsWithColumnsTs", org.apache.thrift.protocol.TMessageType.CALL, 0)); getRowsWithColumnsTs_args args = new getRowsWithColumnsTs_args(); args.setTableName(tableName); args.setRows(rows); args.setColumns(columns); args.setTimestamp(timestamp); args.setAttributes(attributes); args.write(prot); prot.writeMessageEnd(); } public List<TRowResult> getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); return (new Client(prot)).recv_getRowsWithColumnsTs(); } } public void mutateRow(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); mutateRow_call method_call = new mutateRow_call(tableName, row, mutations, attributes, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class mutateRow_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; private ByteBuffer row; private List<Mutation> mutations; private Map<ByteBuffer,ByteBuffer> attributes; public mutateRow_call(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; this.row = row; this.mutations = mutations; this.attributes = attributes; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("mutateRow", org.apache.thrift.protocol.TMessageType.CALL, 0)); mutateRow_args args = new mutateRow_args(); args.setTableName(tableName); args.setRow(row); args.setMutations(mutations); args.setAttributes(attributes); args.write(prot); prot.writeMessageEnd(); } public void getResult() throws IOError, IllegalArgument, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); (new Client(prot)).recv_mutateRow(); } } public void mutateRowTs(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); mutateRowTs_call method_call = new mutateRowTs_call(tableName, row, mutations, timestamp, attributes, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class mutateRowTs_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; private ByteBuffer row; private List<Mutation> mutations; private long timestamp; private Map<ByteBuffer,ByteBuffer> attributes; public mutateRowTs_call(ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; this.row = row; this.mutations = mutations; this.timestamp = timestamp; this.attributes = attributes; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("mutateRowTs", org.apache.thrift.protocol.TMessageType.CALL, 0)); mutateRowTs_args args = new mutateRowTs_args(); args.setTableName(tableName); args.setRow(row); args.setMutations(mutations); args.setTimestamp(timestamp); args.setAttributes(attributes); args.write(prot); prot.writeMessageEnd(); } public void getResult() throws IOError, IllegalArgument, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); (new Client(prot)).recv_mutateRowTs(); } } public void mutateRows(ByteBuffer tableName, List<BatchMutation> rowBatches, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); mutateRows_call method_call = new mutateRows_call(tableName, rowBatches, attributes, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class mutateRows_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; private List<BatchMutation> rowBatches; private Map<ByteBuffer,ByteBuffer> attributes; public mutateRows_call(ByteBuffer tableName, List<BatchMutation> rowBatches, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; this.rowBatches = rowBatches; this.attributes = attributes; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("mutateRows", org.apache.thrift.protocol.TMessageType.CALL, 0)); mutateRows_args args = new mutateRows_args(); args.setTableName(tableName); args.setRowBatches(rowBatches); args.setAttributes(attributes); args.write(prot); prot.writeMessageEnd(); } public void getResult() throws IOError, IllegalArgument, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); (new Client(prot)).recv_mutateRows(); } } public void mutateRowsTs(ByteBuffer tableName, List<BatchMutation> rowBatches, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); mutateRowsTs_call method_call = new mutateRowsTs_call(tableName, rowBatches, timestamp, attributes, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class mutateRowsTs_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; private List<BatchMutation> rowBatches; private long timestamp; private Map<ByteBuffer,ByteBuffer> attributes; public mutateRowsTs_call(ByteBuffer tableName, List<BatchMutation> rowBatches, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; this.rowBatches = rowBatches; this.timestamp = timestamp; this.attributes = attributes; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("mutateRowsTs", org.apache.thrift.protocol.TMessageType.CALL, 0)); mutateRowsTs_args args = new mutateRowsTs_args(); args.setTableName(tableName); args.setRowBatches(rowBatches); args.setTimestamp(timestamp); args.setAttributes(attributes); args.write(prot); prot.writeMessageEnd(); } public void getResult() throws IOError, IllegalArgument, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); (new Client(prot)).recv_mutateRowsTs(); } } public void atomicIncrement(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long value, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); atomicIncrement_call method_call = new atomicIncrement_call(tableName, row, column, value, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class atomicIncrement_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; private ByteBuffer row; private ByteBuffer column; private long value; public atomicIncrement_call(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long value, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; this.row = row; this.column = column; this.value = value; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("atomicIncrement", org.apache.thrift.protocol.TMessageType.CALL, 0)); atomicIncrement_args args = new atomicIncrement_args(); args.setTableName(tableName); args.setRow(row); args.setColumn(column); args.setValue(value); args.write(prot); prot.writeMessageEnd(); } public long getResult() throws IOError, IllegalArgument, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); return (new Client(prot)).recv_atomicIncrement(); } } public void deleteAll(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); deleteAll_call method_call = new deleteAll_call(tableName, row, column, attributes, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class deleteAll_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; private ByteBuffer row; private ByteBuffer column; private Map<ByteBuffer,ByteBuffer> attributes; public deleteAll_call(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; this.row = row; this.column = column; this.attributes = attributes; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("deleteAll", org.apache.thrift.protocol.TMessageType.CALL, 0)); deleteAll_args args = new deleteAll_args(); args.setTableName(tableName); args.setRow(row); args.setColumn(column); args.setAttributes(attributes); args.write(prot); prot.writeMessageEnd(); } public void getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); (new Client(prot)).recv_deleteAll(); } } public void deleteAllTs(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); deleteAllTs_call method_call = new deleteAllTs_call(tableName, row, column, timestamp, attributes, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class deleteAllTs_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; private ByteBuffer row; private ByteBuffer column; private long timestamp; private Map<ByteBuffer,ByteBuffer> attributes; public deleteAllTs_call(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; this.row = row; this.column = column; this.timestamp = timestamp; this.attributes = attributes; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("deleteAllTs", org.apache.thrift.protocol.TMessageType.CALL, 0)); deleteAllTs_args args = new deleteAllTs_args(); args.setTableName(tableName); args.setRow(row); args.setColumn(column); args.setTimestamp(timestamp); args.setAttributes(attributes); args.write(prot); prot.writeMessageEnd(); } public void getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); (new Client(prot)).recv_deleteAllTs(); } } public void deleteAllRow(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); deleteAllRow_call method_call = new deleteAllRow_call(tableName, row, attributes, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class deleteAllRow_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; private ByteBuffer row; private Map<ByteBuffer,ByteBuffer> attributes; public deleteAllRow_call(ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; this.row = row; this.attributes = attributes; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("deleteAllRow", org.apache.thrift.protocol.TMessageType.CALL, 0)); deleteAllRow_args args = new deleteAllRow_args(); args.setTableName(tableName); args.setRow(row); args.setAttributes(attributes); args.write(prot); prot.writeMessageEnd(); } public void getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); (new Client(prot)).recv_deleteAllRow(); } } public void increment(TIncrement increment, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); increment_call method_call = new increment_call(increment, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class increment_call extends org.apache.thrift.async.TAsyncMethodCall { private TIncrement increment; public increment_call(TIncrement increment, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.increment = increment; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("increment", org.apache.thrift.protocol.TMessageType.CALL, 0)); increment_args args = new increment_args(); args.setIncrement(increment); args.write(prot); prot.writeMessageEnd(); } public void getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); (new Client(prot)).recv_increment(); } } public void incrementRows(List<TIncrement> increments, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); incrementRows_call method_call = new incrementRows_call(increments, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class incrementRows_call extends org.apache.thrift.async.TAsyncMethodCall { private List<TIncrement> increments; public incrementRows_call(List<TIncrement> increments, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.increments = increments; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("incrementRows", org.apache.thrift.protocol.TMessageType.CALL, 0)); incrementRows_args args = new incrementRows_args(); args.setIncrements(increments); args.write(prot); prot.writeMessageEnd(); } public void getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); (new Client(prot)).recv_incrementRows(); } } public void deleteAllRowTs(ByteBuffer tableName, ByteBuffer row, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); deleteAllRowTs_call method_call = new deleteAllRowTs_call(tableName, row, timestamp, attributes, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class deleteAllRowTs_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; private ByteBuffer row; private long timestamp; private Map<ByteBuffer,ByteBuffer> attributes; public deleteAllRowTs_call(ByteBuffer tableName, ByteBuffer row, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; this.row = row; this.timestamp = timestamp; this.attributes = attributes; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("deleteAllRowTs", org.apache.thrift.protocol.TMessageType.CALL, 0)); deleteAllRowTs_args args = new deleteAllRowTs_args(); args.setTableName(tableName); args.setRow(row); args.setTimestamp(timestamp); args.setAttributes(attributes); args.write(prot); prot.writeMessageEnd(); } public void getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); (new Client(prot)).recv_deleteAllRowTs(); } } public void scannerOpenWithScan(ByteBuffer tableName, TScan scan, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); scannerOpenWithScan_call method_call = new scannerOpenWithScan_call(tableName, scan, attributes, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class scannerOpenWithScan_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; private TScan scan; private Map<ByteBuffer,ByteBuffer> attributes; public scannerOpenWithScan_call(ByteBuffer tableName, TScan scan, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; this.scan = scan; this.attributes = attributes; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("scannerOpenWithScan", org.apache.thrift.protocol.TMessageType.CALL, 0)); scannerOpenWithScan_args args = new scannerOpenWithScan_args(); args.setTableName(tableName); args.setScan(scan); args.setAttributes(attributes); args.write(prot); prot.writeMessageEnd(); } public int getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); return (new Client(prot)).recv_scannerOpenWithScan(); } } public void scannerOpen(ByteBuffer tableName, ByteBuffer startRow, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); scannerOpen_call method_call = new scannerOpen_call(tableName, startRow, columns, attributes, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class scannerOpen_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; private ByteBuffer startRow; private List<ByteBuffer> columns; private Map<ByteBuffer,ByteBuffer> attributes; public scannerOpen_call(ByteBuffer tableName, ByteBuffer startRow, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; this.startRow = startRow; this.columns = columns; this.attributes = attributes; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("scannerOpen", org.apache.thrift.protocol.TMessageType.CALL, 0)); scannerOpen_args args = new scannerOpen_args(); args.setTableName(tableName); args.setStartRow(startRow); args.setColumns(columns); args.setAttributes(attributes); args.write(prot); prot.writeMessageEnd(); } public int getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); return (new Client(prot)).recv_scannerOpen(); } } public void scannerOpenWithStop(ByteBuffer tableName, ByteBuffer startRow, ByteBuffer stopRow, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); scannerOpenWithStop_call method_call = new scannerOpenWithStop_call(tableName, startRow, stopRow, columns, attributes, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class scannerOpenWithStop_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; private ByteBuffer startRow; private ByteBuffer stopRow; private List<ByteBuffer> columns; private Map<ByteBuffer,ByteBuffer> attributes; public scannerOpenWithStop_call(ByteBuffer tableName, ByteBuffer startRow, ByteBuffer stopRow, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; this.startRow = startRow; this.stopRow = stopRow; this.columns = columns; this.attributes = attributes; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("scannerOpenWithStop", org.apache.thrift.protocol.TMessageType.CALL, 0)); scannerOpenWithStop_args args = new scannerOpenWithStop_args(); args.setTableName(tableName); args.setStartRow(startRow); args.setStopRow(stopRow); args.setColumns(columns); args.setAttributes(attributes); args.write(prot); prot.writeMessageEnd(); } public int getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); return (new Client(prot)).recv_scannerOpenWithStop(); } } public void scannerOpenWithPrefix(ByteBuffer tableName, ByteBuffer startAndPrefix, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); scannerOpenWithPrefix_call method_call = new scannerOpenWithPrefix_call(tableName, startAndPrefix, columns, attributes, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class scannerOpenWithPrefix_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; private ByteBuffer startAndPrefix; private List<ByteBuffer> columns; private Map<ByteBuffer,ByteBuffer> attributes; public scannerOpenWithPrefix_call(ByteBuffer tableName, ByteBuffer startAndPrefix, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; this.startAndPrefix = startAndPrefix; this.columns = columns; this.attributes = attributes; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("scannerOpenWithPrefix", org.apache.thrift.protocol.TMessageType.CALL, 0)); scannerOpenWithPrefix_args args = new scannerOpenWithPrefix_args(); args.setTableName(tableName); args.setStartAndPrefix(startAndPrefix); args.setColumns(columns); args.setAttributes(attributes); args.write(prot); prot.writeMessageEnd(); } public int getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); return (new Client(prot)).recv_scannerOpenWithPrefix(); } } public void scannerOpenTs(ByteBuffer tableName, ByteBuffer startRow, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); scannerOpenTs_call method_call = new scannerOpenTs_call(tableName, startRow, columns, timestamp, attributes, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class scannerOpenTs_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; private ByteBuffer startRow; private List<ByteBuffer> columns; private long timestamp; private Map<ByteBuffer,ByteBuffer> attributes; public scannerOpenTs_call(ByteBuffer tableName, ByteBuffer startRow, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; this.startRow = startRow; this.columns = columns; this.timestamp = timestamp; this.attributes = attributes; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("scannerOpenTs", org.apache.thrift.protocol.TMessageType.CALL, 0)); scannerOpenTs_args args = new scannerOpenTs_args(); args.setTableName(tableName); args.setStartRow(startRow); args.setColumns(columns); args.setTimestamp(timestamp); args.setAttributes(attributes); args.write(prot); prot.writeMessageEnd(); } public int getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); return (new Client(prot)).recv_scannerOpenTs(); } } public void scannerOpenWithStopTs(ByteBuffer tableName, ByteBuffer startRow, ByteBuffer stopRow, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); scannerOpenWithStopTs_call method_call = new scannerOpenWithStopTs_call(tableName, startRow, stopRow, columns, timestamp, attributes, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class scannerOpenWithStopTs_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; private ByteBuffer startRow; private ByteBuffer stopRow; private List<ByteBuffer> columns; private long timestamp; private Map<ByteBuffer,ByteBuffer> attributes; public scannerOpenWithStopTs_call(ByteBuffer tableName, ByteBuffer startRow, ByteBuffer stopRow, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; this.startRow = startRow; this.stopRow = stopRow; this.columns = columns; this.timestamp = timestamp; this.attributes = attributes; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("scannerOpenWithStopTs", org.apache.thrift.protocol.TMessageType.CALL, 0)); scannerOpenWithStopTs_args args = new scannerOpenWithStopTs_args(); args.setTableName(tableName); args.setStartRow(startRow); args.setStopRow(stopRow); args.setColumns(columns); args.setTimestamp(timestamp); args.setAttributes(attributes); args.write(prot); prot.writeMessageEnd(); } public int getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); return (new Client(prot)).recv_scannerOpenWithStopTs(); } } public void scannerGet(int id, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); scannerGet_call method_call = new scannerGet_call(id, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class scannerGet_call extends org.apache.thrift.async.TAsyncMethodCall { private int id; public scannerGet_call(int id, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.id = id; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("scannerGet", org.apache.thrift.protocol.TMessageType.CALL, 0)); scannerGet_args args = new scannerGet_args(); args.setId(id); args.write(prot); prot.writeMessageEnd(); } public List<TRowResult> getResult() throws IOError, IllegalArgument, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); return (new Client(prot)).recv_scannerGet(); } } public void scannerGetList(int id, int nbRows, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); scannerGetList_call method_call = new scannerGetList_call(id, nbRows, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class scannerGetList_call extends org.apache.thrift.async.TAsyncMethodCall { private int id; private int nbRows; public scannerGetList_call(int id, int nbRows, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.id = id; this.nbRows = nbRows; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("scannerGetList", org.apache.thrift.protocol.TMessageType.CALL, 0)); scannerGetList_args args = new scannerGetList_args(); args.setId(id); args.setNbRows(nbRows); args.write(prot); prot.writeMessageEnd(); } public List<TRowResult> getResult() throws IOError, IllegalArgument, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); return (new Client(prot)).recv_scannerGetList(); } } public void scannerClose(int id, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); scannerClose_call method_call = new scannerClose_call(id, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class scannerClose_call extends org.apache.thrift.async.TAsyncMethodCall { private int id; public scannerClose_call(int id, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.id = id; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("scannerClose", org.apache.thrift.protocol.TMessageType.CALL, 0)); scannerClose_args args = new scannerClose_args(); args.setId(id); args.write(prot); prot.writeMessageEnd(); } public void getResult() throws IOError, IllegalArgument, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); (new Client(prot)).recv_scannerClose(); } } public void getRegionInfo(ByteBuffer row, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); getRegionInfo_call method_call = new getRegionInfo_call(row, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class getRegionInfo_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer row; public getRegionInfo_call(ByteBuffer row, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.row = row; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("getRegionInfo", org.apache.thrift.protocol.TMessageType.CALL, 0)); getRegionInfo_args args = new getRegionInfo_args(); args.setRow(row); args.write(prot); prot.writeMessageEnd(); } public TRegionInfo getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); return (new Client(prot)).recv_getRegionInfo(); } } public void append(TAppend append, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); append_call method_call = new append_call(append, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class append_call extends org.apache.thrift.async.TAsyncMethodCall { private TAppend append; public append_call(TAppend append, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.append = append; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("append", org.apache.thrift.protocol.TMessageType.CALL, 0)); append_args args = new append_args(); args.setAppend(append); args.write(prot); prot.writeMessageEnd(); } public List<TCell> getResult() throws IOError, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); return (new Client(prot)).recv_append(); } } public void checkAndPut(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, ByteBuffer value, Mutation mput, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { checkReady(); checkAndPut_call method_call = new checkAndPut_call(tableName, row, column, value, mput, attributes, resultHandler, this, ___protocolFactory, ___transport); this.___currentMethod = method_call; ___manager.call(method_call); } public static class checkAndPut_call extends org.apache.thrift.async.TAsyncMethodCall { private ByteBuffer tableName; private ByteBuffer row; private ByteBuffer column; private ByteBuffer value; private Mutation mput; private Map<ByteBuffer,ByteBuffer> attributes; public checkAndPut_call(ByteBuffer tableName, ByteBuffer row, ByteBuffer column, ByteBuffer value, Mutation mput, Map<ByteBuffer,ByteBuffer> attributes, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { super(client, protocolFactory, transport, resultHandler, false); this.tableName = tableName; this.row = row; this.column = column; this.value = value; this.mput = mput; this.attributes = attributes; } public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("checkAndPut", org.apache.thrift.protocol.TMessageType.CALL, 0)); checkAndPut_args args = new checkAndPut_args(); args.setTableName(tableName); args.setRow(row); args.setColumn(column); args.setValue(value); args.setMput(mput); args.setAttributes(attributes); args.write(prot); prot.writeMessageEnd(); } public boolean getResult() throws IOError, IllegalArgument, org.apache.thrift.TException { if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) { throw new IllegalStateException("Method call not finished!"); } org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array()); org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport); return (new Client(prot)).recv_checkAndPut(); } } } public static class Processor<I extends Iface> extends org.apache.thrift.TBaseProcessor<I> implements org.apache.thrift.TProcessor { private static final Logger LOGGER = LoggerFactory.getLogger(Processor.class.getName()); public Processor(I iface) { super(iface, getProcessMap(new HashMap<String, org.apache.thrift.ProcessFunction<I, ? extends org.apache.thrift.TBase>>())); } protected Processor(I iface, Map<String, org.apache.thrift.ProcessFunction<I, ? extends org.apache.thrift.TBase>> processMap) { super(iface, getProcessMap(processMap)); } private static <I extends Iface> Map<String, org.apache.thrift.ProcessFunction<I, ? extends org.apache.thrift.TBase>> getProcessMap(Map<String, org.apache.thrift.ProcessFunction<I, ? extends org.apache.thrift.TBase>> processMap) { processMap.put("enableTable", new enableTable()); processMap.put("disableTable", new disableTable()); processMap.put("isTableEnabled", new isTableEnabled()); processMap.put("compact", new compact()); processMap.put("majorCompact", new majorCompact()); processMap.put("getTableNames", new getTableNames()); processMap.put("getColumnDescriptors", new getColumnDescriptors()); processMap.put("getTableRegions", new getTableRegions()); processMap.put("createTable", new createTable()); processMap.put("deleteTable", new deleteTable()); processMap.put("get", new get()); processMap.put("getVer", new getVer()); processMap.put("getVerTs", new getVerTs()); processMap.put("getRow", new getRow()); processMap.put("getRowWithColumns", new getRowWithColumns()); processMap.put("getRowTs", new getRowTs()); processMap.put("getRowWithColumnsTs", new getRowWithColumnsTs()); processMap.put("getRows", new getRows()); processMap.put("getRowsWithColumns", new getRowsWithColumns()); processMap.put("getRowsTs", new getRowsTs()); processMap.put("getRowsWithColumnsTs", new getRowsWithColumnsTs()); processMap.put("mutateRow", new mutateRow()); processMap.put("mutateRowTs", new mutateRowTs()); processMap.put("mutateRows", new mutateRows()); processMap.put("mutateRowsTs", new mutateRowsTs()); processMap.put("atomicIncrement", new atomicIncrement()); processMap.put("deleteAll", new deleteAll()); processMap.put("deleteAllTs", new deleteAllTs()); processMap.put("deleteAllRow", new deleteAllRow()); processMap.put("increment", new increment()); processMap.put("incrementRows", new incrementRows()); processMap.put("deleteAllRowTs", new deleteAllRowTs()); processMap.put("scannerOpenWithScan", new scannerOpenWithScan()); processMap.put("scannerOpen", new scannerOpen()); processMap.put("scannerOpenWithStop", new scannerOpenWithStop()); processMap.put("scannerOpenWithPrefix", new scannerOpenWithPrefix()); processMap.put("scannerOpenTs", new scannerOpenTs()); processMap.put("scannerOpenWithStopTs", new scannerOpenWithStopTs()); processMap.put("scannerGet", new scannerGet()); processMap.put("scannerGetList", new scannerGetList()); processMap.put("scannerClose", new scannerClose()); processMap.put("getRegionInfo", new getRegionInfo()); processMap.put("append", new append()); processMap.put("checkAndPut", new checkAndPut()); return processMap; } public static class enableTable<I extends Iface> extends org.apache.thrift.ProcessFunction<I, enableTable_args> { public enableTable() { super("enableTable"); } public enableTable_args getEmptyArgsInstance() { return new enableTable_args(); } protected boolean isOneway() { return false; } public enableTable_result getResult(I iface, enableTable_args args) throws org.apache.thrift.TException { enableTable_result result = new enableTable_result(); try { iface.enableTable(args.tableName); } catch (IOError io) { result.io = io; } return result; } } public static class disableTable<I extends Iface> extends org.apache.thrift.ProcessFunction<I, disableTable_args> { public disableTable() { super("disableTable"); } public disableTable_args getEmptyArgsInstance() { return new disableTable_args(); } protected boolean isOneway() { return false; } public disableTable_result getResult(I iface, disableTable_args args) throws org.apache.thrift.TException { disableTable_result result = new disableTable_result(); try { iface.disableTable(args.tableName); } catch (IOError io) { result.io = io; } return result; } } public static class isTableEnabled<I extends Iface> extends org.apache.thrift.ProcessFunction<I, isTableEnabled_args> { public isTableEnabled() { super("isTableEnabled"); } public isTableEnabled_args getEmptyArgsInstance() { return new isTableEnabled_args(); } protected boolean isOneway() { return false; } public isTableEnabled_result getResult(I iface, isTableEnabled_args args) throws org.apache.thrift.TException { isTableEnabled_result result = new isTableEnabled_result(); try { result.success = iface.isTableEnabled(args.tableName); result.setSuccessIsSet(true); } catch (IOError io) { result.io = io; } return result; } } public static class compact<I extends Iface> extends org.apache.thrift.ProcessFunction<I, compact_args> { public compact() { super("compact"); } public compact_args getEmptyArgsInstance() { return new compact_args(); } protected boolean isOneway() { return false; } public compact_result getResult(I iface, compact_args args) throws org.apache.thrift.TException { compact_result result = new compact_result(); try { iface.compact(args.tableNameOrRegionName); } catch (IOError io) { result.io = io; } return result; } } public static class majorCompact<I extends Iface> extends org.apache.thrift.ProcessFunction<I, majorCompact_args> { public majorCompact() { super("majorCompact"); } public majorCompact_args getEmptyArgsInstance() { return new majorCompact_args(); } protected boolean isOneway() { return false; } public majorCompact_result getResult(I iface, majorCompact_args args) throws org.apache.thrift.TException { majorCompact_result result = new majorCompact_result(); try { iface.majorCompact(args.tableNameOrRegionName); } catch (IOError io) { result.io = io; } return result; } } public static class getTableNames<I extends Iface> extends org.apache.thrift.ProcessFunction<I, getTableNames_args> { public getTableNames() { super("getTableNames"); } public getTableNames_args getEmptyArgsInstance() { return new getTableNames_args(); } protected boolean isOneway() { return false; } public getTableNames_result getResult(I iface, getTableNames_args args) throws org.apache.thrift.TException { getTableNames_result result = new getTableNames_result(); try { result.success = iface.getTableNames(); } catch (IOError io) { result.io = io; } return result; } } public static class getColumnDescriptors<I extends Iface> extends org.apache.thrift.ProcessFunction<I, getColumnDescriptors_args> { public getColumnDescriptors() { super("getColumnDescriptors"); } public getColumnDescriptors_args getEmptyArgsInstance() { return new getColumnDescriptors_args(); } protected boolean isOneway() { return false; } public getColumnDescriptors_result getResult(I iface, getColumnDescriptors_args args) throws org.apache.thrift.TException { getColumnDescriptors_result result = new getColumnDescriptors_result(); try { result.success = iface.getColumnDescriptors(args.tableName); } catch (IOError io) { result.io = io; } return result; } } public static class getTableRegions<I extends Iface> extends org.apache.thrift.ProcessFunction<I, getTableRegions_args> { public getTableRegions() { super("getTableRegions"); } public getTableRegions_args getEmptyArgsInstance() { return new getTableRegions_args(); } protected boolean isOneway() { return false; } public getTableRegions_result getResult(I iface, getTableRegions_args args) throws org.apache.thrift.TException { getTableRegions_result result = new getTableRegions_result(); try { result.success = iface.getTableRegions(args.tableName); } catch (IOError io) { result.io = io; } return result; } } public static class createTable<I extends Iface> extends org.apache.thrift.ProcessFunction<I, createTable_args> { public createTable() { super("createTable"); } public createTable_args getEmptyArgsInstance() { return new createTable_args(); } protected boolean isOneway() { return false; } public createTable_result getResult(I iface, createTable_args args) throws org.apache.thrift.TException { createTable_result result = new createTable_result(); try { iface.createTable(args.tableName, args.columnFamilies); } catch (IOError io) { result.io = io; } catch (IllegalArgument ia) { result.ia = ia; } catch (AlreadyExists exist) { result.exist = exist; } return result; } } public static class deleteTable<I extends Iface> extends org.apache.thrift.ProcessFunction<I, deleteTable_args> { public deleteTable() { super("deleteTable"); } public deleteTable_args getEmptyArgsInstance() { return new deleteTable_args(); } protected boolean isOneway() { return false; } public deleteTable_result getResult(I iface, deleteTable_args args) throws org.apache.thrift.TException { deleteTable_result result = new deleteTable_result(); try { iface.deleteTable(args.tableName); } catch (IOError io) { result.io = io; } return result; } } public static class get<I extends Iface> extends org.apache.thrift.ProcessFunction<I, get_args> { public get() { super("get"); } public get_args getEmptyArgsInstance() { return new get_args(); } protected boolean isOneway() { return false; } public get_result getResult(I iface, get_args args) throws org.apache.thrift.TException { get_result result = new get_result(); try { result.success = iface.get(args.tableName, args.row, args.column, args.attributes); } catch (IOError io) { result.io = io; } return result; } } public static class getVer<I extends Iface> extends org.apache.thrift.ProcessFunction<I, getVer_args> { public getVer() { super("getVer"); } public getVer_args getEmptyArgsInstance() { return new getVer_args(); } protected boolean isOneway() { return false; } public getVer_result getResult(I iface, getVer_args args) throws org.apache.thrift.TException { getVer_result result = new getVer_result(); try { result.success = iface.getVer(args.tableName, args.row, args.column, args.numVersions, args.attributes); } catch (IOError io) { result.io = io; } return result; } } public static class getVerTs<I extends Iface> extends org.apache.thrift.ProcessFunction<I, getVerTs_args> { public getVerTs() { super("getVerTs"); } public getVerTs_args getEmptyArgsInstance() { return new getVerTs_args(); } protected boolean isOneway() { return false; } public getVerTs_result getResult(I iface, getVerTs_args args) throws org.apache.thrift.TException { getVerTs_result result = new getVerTs_result(); try { result.success = iface.getVerTs(args.tableName, args.row, args.column, args.timestamp, args.numVersions, args.attributes); } catch (IOError io) { result.io = io; } return result; } } public static class getRow<I extends Iface> extends org.apache.thrift.ProcessFunction<I, getRow_args> { public getRow() { super("getRow"); } public getRow_args getEmptyArgsInstance() { return new getRow_args(); } protected boolean isOneway() { return false; } public getRow_result getResult(I iface, getRow_args args) throws org.apache.thrift.TException { getRow_result result = new getRow_result(); try { result.success = iface.getRow(args.tableName, args.row, args.attributes); } catch (IOError io) { result.io = io; } return result; } } public static class getRowWithColumns<I extends Iface> extends org.apache.thrift.ProcessFunction<I, getRowWithColumns_args> { public getRowWithColumns() { super("getRowWithColumns"); } public getRowWithColumns_args getEmptyArgsInstance() { return new getRowWithColumns_args(); } protected boolean isOneway() { return false; } public getRowWithColumns_result getResult(I iface, getRowWithColumns_args args) throws org.apache.thrift.TException { getRowWithColumns_result result = new getRowWithColumns_result(); try { result.success = iface.getRowWithColumns(args.tableName, args.row, args.columns, args.attributes); } catch (IOError io) { result.io = io; } return result; } } public static class getRowTs<I extends Iface> extends org.apache.thrift.ProcessFunction<I, getRowTs_args> { public getRowTs() { super("getRowTs"); } public getRowTs_args getEmptyArgsInstance() { return new getRowTs_args(); } protected boolean isOneway() { return false; } public getRowTs_result getResult(I iface, getRowTs_args args) throws org.apache.thrift.TException { getRowTs_result result = new getRowTs_result(); try { result.success = iface.getRowTs(args.tableName, args.row, args.timestamp, args.attributes); } catch (IOError io) { result.io = io; } return result; } } public static class getRowWithColumnsTs<I extends Iface> extends org.apache.thrift.ProcessFunction<I, getRowWithColumnsTs_args> { public getRowWithColumnsTs() { super("getRowWithColumnsTs"); } public getRowWithColumnsTs_args getEmptyArgsInstance() { return new getRowWithColumnsTs_args(); } protected boolean isOneway() { return false; } public getRowWithColumnsTs_result getResult(I iface, getRowWithColumnsTs_args args) throws org.apache.thrift.TException { getRowWithColumnsTs_result result = new getRowWithColumnsTs_result(); try { result.success = iface.getRowWithColumnsTs(args.tableName, args.row, args.columns, args.timestamp, args.attributes); } catch (IOError io) { result.io = io; } return result; } } public static class getRows<I extends Iface> extends org.apache.thrift.ProcessFunction<I, getRows_args> { public getRows() { super("getRows"); } public getRows_args getEmptyArgsInstance() { return new getRows_args(); } protected boolean isOneway() { return false; } public getRows_result getResult(I iface, getRows_args args) throws org.apache.thrift.TException { getRows_result result = new getRows_result(); try { result.success = iface.getRows(args.tableName, args.rows, args.attributes); } catch (IOError io) { result.io = io; } return result; } } public static class getRowsWithColumns<I extends Iface> extends org.apache.thrift.ProcessFunction<I, getRowsWithColumns_args> { public getRowsWithColumns() { super("getRowsWithColumns"); } public getRowsWithColumns_args getEmptyArgsInstance() { return new getRowsWithColumns_args(); } protected boolean isOneway() { return false; } public getRowsWithColumns_result getResult(I iface, getRowsWithColumns_args args) throws org.apache.thrift.TException { getRowsWithColumns_result result = new getRowsWithColumns_result(); try { result.success = iface.getRowsWithColumns(args.tableName, args.rows, args.columns, args.attributes); } catch (IOError io) { result.io = io; } return result; } } public static class getRowsTs<I extends Iface> extends org.apache.thrift.ProcessFunction<I, getRowsTs_args> { public getRowsTs() { super("getRowsTs"); } public getRowsTs_args getEmptyArgsInstance() { return new getRowsTs_args(); } protected boolean isOneway() { return false; } public getRowsTs_result getResult(I iface, getRowsTs_args args) throws org.apache.thrift.TException { getRowsTs_result result = new getRowsTs_result(); try { result.success = iface.getRowsTs(args.tableName, args.rows, args.timestamp, args.attributes); } catch (IOError io) { result.io = io; } return result; } } public static class getRowsWithColumnsTs<I extends Iface> extends org.apache.thrift.ProcessFunction<I, getRowsWithColumnsTs_args> { public getRowsWithColumnsTs() { super("getRowsWithColumnsTs"); } public getRowsWithColumnsTs_args getEmptyArgsInstance() { return new getRowsWithColumnsTs_args(); } protected boolean isOneway() { return false; } public getRowsWithColumnsTs_result getResult(I iface, getRowsWithColumnsTs_args args) throws org.apache.thrift.TException { getRowsWithColumnsTs_result result = new getRowsWithColumnsTs_result(); try { result.success = iface.getRowsWithColumnsTs(args.tableName, args.rows, args.columns, args.timestamp, args.attributes); } catch (IOError io) { result.io = io; } return result; } } public static class mutateRow<I extends Iface> extends org.apache.thrift.ProcessFunction<I, mutateRow_args> { public mutateRow() { super("mutateRow"); } public mutateRow_args getEmptyArgsInstance() { return new mutateRow_args(); } protected boolean isOneway() { return false; } public mutateRow_result getResult(I iface, mutateRow_args args) throws org.apache.thrift.TException { mutateRow_result result = new mutateRow_result(); try { iface.mutateRow(args.tableName, args.row, args.mutations, args.attributes); } catch (IOError io) { result.io = io; } catch (IllegalArgument ia) { result.ia = ia; } return result; } } public static class mutateRowTs<I extends Iface> extends org.apache.thrift.ProcessFunction<I, mutateRowTs_args> { public mutateRowTs() { super("mutateRowTs"); } public mutateRowTs_args getEmptyArgsInstance() { return new mutateRowTs_args(); } protected boolean isOneway() { return false; } public mutateRowTs_result getResult(I iface, mutateRowTs_args args) throws org.apache.thrift.TException { mutateRowTs_result result = new mutateRowTs_result(); try { iface.mutateRowTs(args.tableName, args.row, args.mutations, args.timestamp, args.attributes); } catch (IOError io) { result.io = io; } catch (IllegalArgument ia) { result.ia = ia; } return result; } } public static class mutateRows<I extends Iface> extends org.apache.thrift.ProcessFunction<I, mutateRows_args> { public mutateRows() { super("mutateRows"); } public mutateRows_args getEmptyArgsInstance() { return new mutateRows_args(); } protected boolean isOneway() { return false; } public mutateRows_result getResult(I iface, mutateRows_args args) throws org.apache.thrift.TException { mutateRows_result result = new mutateRows_result(); try { iface.mutateRows(args.tableName, args.rowBatches, args.attributes); } catch (IOError io) { result.io = io; } catch (IllegalArgument ia) { result.ia = ia; } return result; } } public static class mutateRowsTs<I extends Iface> extends org.apache.thrift.ProcessFunction<I, mutateRowsTs_args> { public mutateRowsTs() { super("mutateRowsTs"); } public mutateRowsTs_args getEmptyArgsInstance() { return new mutateRowsTs_args(); } protected boolean isOneway() { return false; } public mutateRowsTs_result getResult(I iface, mutateRowsTs_args args) throws org.apache.thrift.TException { mutateRowsTs_result result = new mutateRowsTs_result(); try { iface.mutateRowsTs(args.tableName, args.rowBatches, args.timestamp, args.attributes); } catch (IOError io) { result.io = io; } catch (IllegalArgument ia) { result.ia = ia; } return result; } } public static class atomicIncrement<I extends Iface> extends org.apache.thrift.ProcessFunction<I, atomicIncrement_args> { public atomicIncrement() { super("atomicIncrement"); } public atomicIncrement_args getEmptyArgsInstance() { return new atomicIncrement_args(); } protected boolean isOneway() { return false; } public atomicIncrement_result getResult(I iface, atomicIncrement_args args) throws org.apache.thrift.TException { atomicIncrement_result result = new atomicIncrement_result(); try { result.success = iface.atomicIncrement(args.tableName, args.row, args.column, args.value); result.setSuccessIsSet(true); } catch (IOError io) { result.io = io; } catch (IllegalArgument ia) { result.ia = ia; } return result; } } public static class deleteAll<I extends Iface> extends org.apache.thrift.ProcessFunction<I, deleteAll_args> { public deleteAll() { super("deleteAll"); } public deleteAll_args getEmptyArgsInstance() { return new deleteAll_args(); } protected boolean isOneway() { return false; } public deleteAll_result getResult(I iface, deleteAll_args args) throws org.apache.thrift.TException { deleteAll_result result = new deleteAll_result(); try { iface.deleteAll(args.tableName, args.row, args.column, args.attributes); } catch (IOError io) { result.io = io; } return result; } } public static class deleteAllTs<I extends Iface> extends org.apache.thrift.ProcessFunction<I, deleteAllTs_args> { public deleteAllTs() { super("deleteAllTs"); } public deleteAllTs_args getEmptyArgsInstance() { return new deleteAllTs_args(); } protected boolean isOneway() { return false; } public deleteAllTs_result getResult(I iface, deleteAllTs_args args) throws org.apache.thrift.TException { deleteAllTs_result result = new deleteAllTs_result(); try { iface.deleteAllTs(args.tableName, args.row, args.column, args.timestamp, args.attributes); } catch (IOError io) { result.io = io; } return result; } } public static class deleteAllRow<I extends Iface> extends org.apache.thrift.ProcessFunction<I, deleteAllRow_args> { public deleteAllRow() { super("deleteAllRow"); } public deleteAllRow_args getEmptyArgsInstance() { return new deleteAllRow_args(); } protected boolean isOneway() { return false; } public deleteAllRow_result getResult(I iface, deleteAllRow_args args) throws org.apache.thrift.TException { deleteAllRow_result result = new deleteAllRow_result(); try { iface.deleteAllRow(args.tableName, args.row, args.attributes); } catch (IOError io) { result.io = io; } return result; } } public static class increment<I extends Iface> extends org.apache.thrift.ProcessFunction<I, increment_args> { public increment() { super("increment"); } public increment_args getEmptyArgsInstance() { return new increment_args(); } protected boolean isOneway() { return false; } public increment_result getResult(I iface, increment_args args) throws org.apache.thrift.TException { increment_result result = new increment_result(); try { iface.increment(args.increment); } catch (IOError io) { result.io = io; } return result; } } public static class incrementRows<I extends Iface> extends org.apache.thrift.ProcessFunction<I, incrementRows_args> { public incrementRows() { super("incrementRows"); } public incrementRows_args getEmptyArgsInstance() { return new incrementRows_args(); } protected boolean isOneway() { return false; } public incrementRows_result getResult(I iface, incrementRows_args args) throws org.apache.thrift.TException { incrementRows_result result = new incrementRows_result(); try { iface.incrementRows(args.increments); } catch (IOError io) { result.io = io; } return result; } } public static class deleteAllRowTs<I extends Iface> extends org.apache.thrift.ProcessFunction<I, deleteAllRowTs_args> { public deleteAllRowTs() { super("deleteAllRowTs"); } public deleteAllRowTs_args getEmptyArgsInstance() { return new deleteAllRowTs_args(); } protected boolean isOneway() { return false; } public deleteAllRowTs_result getResult(I iface, deleteAllRowTs_args args) throws org.apache.thrift.TException { deleteAllRowTs_result result = new deleteAllRowTs_result(); try { iface.deleteAllRowTs(args.tableName, args.row, args.timestamp, args.attributes); } catch (IOError io) { result.io = io; } return result; } } public static class scannerOpenWithScan<I extends Iface> extends org.apache.thrift.ProcessFunction<I, scannerOpenWithScan_args> { public scannerOpenWithScan() { super("scannerOpenWithScan"); } public scannerOpenWithScan_args getEmptyArgsInstance() { return new scannerOpenWithScan_args(); } protected boolean isOneway() { return false; } public scannerOpenWithScan_result getResult(I iface, scannerOpenWithScan_args args) throws org.apache.thrift.TException { scannerOpenWithScan_result result = new scannerOpenWithScan_result(); try { result.success = iface.scannerOpenWithScan(args.tableName, args.scan, args.attributes); result.setSuccessIsSet(true); } catch (IOError io) { result.io = io; } return result; } } public static class scannerOpen<I extends Iface> extends org.apache.thrift.ProcessFunction<I, scannerOpen_args> { public scannerOpen() { super("scannerOpen"); } public scannerOpen_args getEmptyArgsInstance() { return new scannerOpen_args(); } protected boolean isOneway() { return false; } public scannerOpen_result getResult(I iface, scannerOpen_args args) throws org.apache.thrift.TException { scannerOpen_result result = new scannerOpen_result(); try { result.success = iface.scannerOpen(args.tableName, args.startRow, args.columns, args.attributes); result.setSuccessIsSet(true); } catch (IOError io) { result.io = io; } return result; } } public static class scannerOpenWithStop<I extends Iface> extends org.apache.thrift.ProcessFunction<I, scannerOpenWithStop_args> { public scannerOpenWithStop() { super("scannerOpenWithStop"); } public scannerOpenWithStop_args getEmptyArgsInstance() { return new scannerOpenWithStop_args(); } protected boolean isOneway() { return false; } public scannerOpenWithStop_result getResult(I iface, scannerOpenWithStop_args args) throws org.apache.thrift.TException { scannerOpenWithStop_result result = new scannerOpenWithStop_result(); try { result.success = iface.scannerOpenWithStop(args.tableName, args.startRow, args.stopRow, args.columns, args.attributes); result.setSuccessIsSet(true); } catch (IOError io) { result.io = io; } return result; } } public static class scannerOpenWithPrefix<I extends Iface> extends org.apache.thrift.ProcessFunction<I, scannerOpenWithPrefix_args> { public scannerOpenWithPrefix() { super("scannerOpenWithPrefix"); } public scannerOpenWithPrefix_args getEmptyArgsInstance() { return new scannerOpenWithPrefix_args(); } protected boolean isOneway() { return false; } public scannerOpenWithPrefix_result getResult(I iface, scannerOpenWithPrefix_args args) throws org.apache.thrift.TException { scannerOpenWithPrefix_result result = new scannerOpenWithPrefix_result(); try { result.success = iface.scannerOpenWithPrefix(args.tableName, args.startAndPrefix, args.columns, args.attributes); result.setSuccessIsSet(true); } catch (IOError io) { result.io = io; } return result; } } public static class scannerOpenTs<I extends Iface> extends org.apache.thrift.ProcessFunction<I, scannerOpenTs_args> { public scannerOpenTs() { super("scannerOpenTs"); } public scannerOpenTs_args getEmptyArgsInstance() { return new scannerOpenTs_args(); } protected boolean isOneway() { return false; } public scannerOpenTs_result getResult(I iface, scannerOpenTs_args args) throws org.apache.thrift.TException { scannerOpenTs_result result = new scannerOpenTs_result(); try { result.success = iface.scannerOpenTs(args.tableName, args.startRow, args.columns, args.timestamp, args.attributes); result.setSuccessIsSet(true); } catch (IOError io) { result.io = io; } return result; } } public static class scannerOpenWithStopTs<I extends Iface> extends org.apache.thrift.ProcessFunction<I, scannerOpenWithStopTs_args> { public scannerOpenWithStopTs() { super("scannerOpenWithStopTs"); } public scannerOpenWithStopTs_args getEmptyArgsInstance() { return new scannerOpenWithStopTs_args(); } protected boolean isOneway() { return false; } public scannerOpenWithStopTs_result getResult(I iface, scannerOpenWithStopTs_args args) throws org.apache.thrift.TException { scannerOpenWithStopTs_result result = new scannerOpenWithStopTs_result(); try { result.success = iface.scannerOpenWithStopTs(args.tableName, args.startRow, args.stopRow, args.columns, args.timestamp, args.attributes); result.setSuccessIsSet(true); } catch (IOError io) { result.io = io; } return result; } } public static class scannerGet<I extends Iface> extends org.apache.thrift.ProcessFunction<I, scannerGet_args> { public scannerGet() { super("scannerGet"); } public scannerGet_args getEmptyArgsInstance() { return new scannerGet_args(); } protected boolean isOneway() { return false; } public scannerGet_result getResult(I iface, scannerGet_args args) throws org.apache.thrift.TException { scannerGet_result result = new scannerGet_result(); try { result.success = iface.scannerGet(args.id); } catch (IOError io) { result.io = io; } catch (IllegalArgument ia) { result.ia = ia; } return result; } } public static class scannerGetList<I extends Iface> extends org.apache.thrift.ProcessFunction<I, scannerGetList_args> { public scannerGetList() { super("scannerGetList"); } public scannerGetList_args getEmptyArgsInstance() { return new scannerGetList_args(); } protected boolean isOneway() { return false; } public scannerGetList_result getResult(I iface, scannerGetList_args args) throws org.apache.thrift.TException { scannerGetList_result result = new scannerGetList_result(); try { result.success = iface.scannerGetList(args.id, args.nbRows); } catch (IOError io) { result.io = io; } catch (IllegalArgument ia) { result.ia = ia; } return result; } } public static class scannerClose<I extends Iface> extends org.apache.thrift.ProcessFunction<I, scannerClose_args> { public scannerClose() { super("scannerClose"); } public scannerClose_args getEmptyArgsInstance() { return new scannerClose_args(); } protected boolean isOneway() { return false; } public scannerClose_result getResult(I iface, scannerClose_args args) throws org.apache.thrift.TException { scannerClose_result result = new scannerClose_result(); try { iface.scannerClose(args.id); } catch (IOError io) { result.io = io; } catch (IllegalArgument ia) { result.ia = ia; } return result; } } public static class getRegionInfo<I extends Iface> extends org.apache.thrift.ProcessFunction<I, getRegionInfo_args> { public getRegionInfo() { super("getRegionInfo"); } public getRegionInfo_args getEmptyArgsInstance() { return new getRegionInfo_args(); } protected boolean isOneway() { return false; } public getRegionInfo_result getResult(I iface, getRegionInfo_args args) throws org.apache.thrift.TException { getRegionInfo_result result = new getRegionInfo_result(); try { result.success = iface.getRegionInfo(args.row); } catch (IOError io) { result.io = io; } return result; } } public static class append<I extends Iface> extends org.apache.thrift.ProcessFunction<I, append_args> { public append() { super("append"); } public append_args getEmptyArgsInstance() { return new append_args(); } protected boolean isOneway() { return false; } public append_result getResult(I iface, append_args args) throws org.apache.thrift.TException { append_result result = new append_result(); try { result.success = iface.append(args.append); } catch (IOError io) { result.io = io; } return result; } } public static class checkAndPut<I extends Iface> extends org.apache.thrift.ProcessFunction<I, checkAndPut_args> { public checkAndPut() { super("checkAndPut"); } public checkAndPut_args getEmptyArgsInstance() { return new checkAndPut_args(); } protected boolean isOneway() { return false; } public checkAndPut_result getResult(I iface, checkAndPut_args args) throws org.apache.thrift.TException { checkAndPut_result result = new checkAndPut_result(); try { result.success = iface.checkAndPut(args.tableName, args.row, args.column, args.value, args.mput, args.attributes); result.setSuccessIsSet(true); } catch (IOError io) { result.io = io; } catch (IllegalArgument ia) { result.ia = ia; } return result; } } } public static class AsyncProcessor<I extends AsyncIface> extends org.apache.thrift.TBaseAsyncProcessor<I> { private static final Logger LOGGER = LoggerFactory.getLogger(AsyncProcessor.class.getName()); public AsyncProcessor(I iface) { super(iface, getProcessMap(new HashMap<String, org.apache.thrift.AsyncProcessFunction<I, ? extends org.apache.thrift.TBase, ?>>())); } protected AsyncProcessor(I iface, Map<String, org.apache.thrift.AsyncProcessFunction<I, ? extends org.apache.thrift.TBase, ?>> processMap) { super(iface, getProcessMap(processMap)); } private static <I extends AsyncIface> Map<String, org.apache.thrift.AsyncProcessFunction<I, ? extends org.apache.thrift.TBase,?>> getProcessMap(Map<String, org.apache.thrift.AsyncProcessFunction<I, ? extends org.apache.thrift.TBase, ?>> processMap) { processMap.put("enableTable", new enableTable()); processMap.put("disableTable", new disableTable()); processMap.put("isTableEnabled", new isTableEnabled()); processMap.put("compact", new compact()); processMap.put("majorCompact", new majorCompact()); processMap.put("getTableNames", new getTableNames()); processMap.put("getColumnDescriptors", new getColumnDescriptors()); processMap.put("getTableRegions", new getTableRegions()); processMap.put("createTable", new createTable()); processMap.put("deleteTable", new deleteTable()); processMap.put("get", new get()); processMap.put("getVer", new getVer()); processMap.put("getVerTs", new getVerTs()); processMap.put("getRow", new getRow()); processMap.put("getRowWithColumns", new getRowWithColumns()); processMap.put("getRowTs", new getRowTs()); processMap.put("getRowWithColumnsTs", new getRowWithColumnsTs()); processMap.put("getRows", new getRows()); processMap.put("getRowsWithColumns", new getRowsWithColumns()); processMap.put("getRowsTs", new getRowsTs()); processMap.put("getRowsWithColumnsTs", new getRowsWithColumnsTs()); processMap.put("mutateRow", new mutateRow()); processMap.put("mutateRowTs", new mutateRowTs()); processMap.put("mutateRows", new mutateRows()); processMap.put("mutateRowsTs", new mutateRowsTs()); processMap.put("atomicIncrement", new atomicIncrement()); processMap.put("deleteAll", new deleteAll()); processMap.put("deleteAllTs", new deleteAllTs()); processMap.put("deleteAllRow", new deleteAllRow()); processMap.put("increment", new increment()); processMap.put("incrementRows", new incrementRows()); processMap.put("deleteAllRowTs", new deleteAllRowTs()); processMap.put("scannerOpenWithScan", new scannerOpenWithScan()); processMap.put("scannerOpen", new scannerOpen()); processMap.put("scannerOpenWithStop", new scannerOpenWithStop()); processMap.put("scannerOpenWithPrefix", new scannerOpenWithPrefix()); processMap.put("scannerOpenTs", new scannerOpenTs()); processMap.put("scannerOpenWithStopTs", new scannerOpenWithStopTs()); processMap.put("scannerGet", new scannerGet()); processMap.put("scannerGetList", new scannerGetList()); processMap.put("scannerClose", new scannerClose()); processMap.put("getRegionInfo", new getRegionInfo()); processMap.put("append", new append()); processMap.put("checkAndPut", new checkAndPut()); return processMap; } public static class enableTable<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, enableTable_args, Void> { public enableTable() { super("enableTable"); } public enableTable_args getEmptyArgsInstance() { return new enableTable_args(); } public AsyncMethodCallback<Void> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<Void>() { public void onComplete(Void o) { enableTable_result result = new enableTable_result(); try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; enableTable_result result = new enableTable_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, enableTable_args args, org.apache.thrift.async.AsyncMethodCallback<Void> resultHandler) throws TException { iface.enableTable(args.tableName,resultHandler); } } public static class disableTable<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, disableTable_args, Void> { public disableTable() { super("disableTable"); } public disableTable_args getEmptyArgsInstance() { return new disableTable_args(); } public AsyncMethodCallback<Void> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<Void>() { public void onComplete(Void o) { disableTable_result result = new disableTable_result(); try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; disableTable_result result = new disableTable_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, disableTable_args args, org.apache.thrift.async.AsyncMethodCallback<Void> resultHandler) throws TException { iface.disableTable(args.tableName,resultHandler); } } public static class isTableEnabled<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, isTableEnabled_args, Boolean> { public isTableEnabled() { super("isTableEnabled"); } public isTableEnabled_args getEmptyArgsInstance() { return new isTableEnabled_args(); } public AsyncMethodCallback<Boolean> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<Boolean>() { public void onComplete(Boolean o) { isTableEnabled_result result = new isTableEnabled_result(); result.success = o; result.setSuccessIsSet(true); try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; isTableEnabled_result result = new isTableEnabled_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, isTableEnabled_args args, org.apache.thrift.async.AsyncMethodCallback<Boolean> resultHandler) throws TException { iface.isTableEnabled(args.tableName,resultHandler); } } public static class compact<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, compact_args, Void> { public compact() { super("compact"); } public compact_args getEmptyArgsInstance() { return new compact_args(); } public AsyncMethodCallback<Void> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<Void>() { public void onComplete(Void o) { compact_result result = new compact_result(); try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; compact_result result = new compact_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, compact_args args, org.apache.thrift.async.AsyncMethodCallback<Void> resultHandler) throws TException { iface.compact(args.tableNameOrRegionName,resultHandler); } } public static class majorCompact<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, majorCompact_args, Void> { public majorCompact() { super("majorCompact"); } public majorCompact_args getEmptyArgsInstance() { return new majorCompact_args(); } public AsyncMethodCallback<Void> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<Void>() { public void onComplete(Void o) { majorCompact_result result = new majorCompact_result(); try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; majorCompact_result result = new majorCompact_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, majorCompact_args args, org.apache.thrift.async.AsyncMethodCallback<Void> resultHandler) throws TException { iface.majorCompact(args.tableNameOrRegionName,resultHandler); } } public static class getTableNames<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, getTableNames_args, List<ByteBuffer>> { public getTableNames() { super("getTableNames"); } public getTableNames_args getEmptyArgsInstance() { return new getTableNames_args(); } public AsyncMethodCallback<List<ByteBuffer>> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<List<ByteBuffer>>() { public void onComplete(List<ByteBuffer> o) { getTableNames_result result = new getTableNames_result(); result.success = o; try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; getTableNames_result result = new getTableNames_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, getTableNames_args args, org.apache.thrift.async.AsyncMethodCallback<List<ByteBuffer>> resultHandler) throws TException { iface.getTableNames(resultHandler); } } public static class getColumnDescriptors<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, getColumnDescriptors_args, Map<ByteBuffer,ColumnDescriptor>> { public getColumnDescriptors() { super("getColumnDescriptors"); } public getColumnDescriptors_args getEmptyArgsInstance() { return new getColumnDescriptors_args(); } public AsyncMethodCallback<Map<ByteBuffer,ColumnDescriptor>> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<Map<ByteBuffer,ColumnDescriptor>>() { public void onComplete(Map<ByteBuffer,ColumnDescriptor> o) { getColumnDescriptors_result result = new getColumnDescriptors_result(); result.success = o; try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; getColumnDescriptors_result result = new getColumnDescriptors_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, getColumnDescriptors_args args, org.apache.thrift.async.AsyncMethodCallback<Map<ByteBuffer,ColumnDescriptor>> resultHandler) throws TException { iface.getColumnDescriptors(args.tableName,resultHandler); } } public static class getTableRegions<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, getTableRegions_args, List<TRegionInfo>> { public getTableRegions() { super("getTableRegions"); } public getTableRegions_args getEmptyArgsInstance() { return new getTableRegions_args(); } public AsyncMethodCallback<List<TRegionInfo>> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<List<TRegionInfo>>() { public void onComplete(List<TRegionInfo> o) { getTableRegions_result result = new getTableRegions_result(); result.success = o; try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; getTableRegions_result result = new getTableRegions_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, getTableRegions_args args, org.apache.thrift.async.AsyncMethodCallback<List<TRegionInfo>> resultHandler) throws TException { iface.getTableRegions(args.tableName,resultHandler); } } public static class createTable<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, createTable_args, Void> { public createTable() { super("createTable"); } public createTable_args getEmptyArgsInstance() { return new createTable_args(); } public AsyncMethodCallback<Void> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<Void>() { public void onComplete(Void o) { createTable_result result = new createTable_result(); try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; createTable_result result = new createTable_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else if (e instanceof IllegalArgument) { result.ia = (IllegalArgument) e; result.setIaIsSet(true); msg = result; } else if (e instanceof AlreadyExists) { result.exist = (AlreadyExists) e; result.setExistIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, createTable_args args, org.apache.thrift.async.AsyncMethodCallback<Void> resultHandler) throws TException { iface.createTable(args.tableName, args.columnFamilies,resultHandler); } } public static class deleteTable<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, deleteTable_args, Void> { public deleteTable() { super("deleteTable"); } public deleteTable_args getEmptyArgsInstance() { return new deleteTable_args(); } public AsyncMethodCallback<Void> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<Void>() { public void onComplete(Void o) { deleteTable_result result = new deleteTable_result(); try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; deleteTable_result result = new deleteTable_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, deleteTable_args args, org.apache.thrift.async.AsyncMethodCallback<Void> resultHandler) throws TException { iface.deleteTable(args.tableName,resultHandler); } } public static class get<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, get_args, List<TCell>> { public get() { super("get"); } public get_args getEmptyArgsInstance() { return new get_args(); } public AsyncMethodCallback<List<TCell>> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<List<TCell>>() { public void onComplete(List<TCell> o) { get_result result = new get_result(); result.success = o; try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; get_result result = new get_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, get_args args, org.apache.thrift.async.AsyncMethodCallback<List<TCell>> resultHandler) throws TException { iface.get(args.tableName, args.row, args.column, args.attributes,resultHandler); } } public static class getVer<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, getVer_args, List<TCell>> { public getVer() { super("getVer"); } public getVer_args getEmptyArgsInstance() { return new getVer_args(); } public AsyncMethodCallback<List<TCell>> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<List<TCell>>() { public void onComplete(List<TCell> o) { getVer_result result = new getVer_result(); result.success = o; try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; getVer_result result = new getVer_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, getVer_args args, org.apache.thrift.async.AsyncMethodCallback<List<TCell>> resultHandler) throws TException { iface.getVer(args.tableName, args.row, args.column, args.numVersions, args.attributes,resultHandler); } } public static class getVerTs<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, getVerTs_args, List<TCell>> { public getVerTs() { super("getVerTs"); } public getVerTs_args getEmptyArgsInstance() { return new getVerTs_args(); } public AsyncMethodCallback<List<TCell>> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<List<TCell>>() { public void onComplete(List<TCell> o) { getVerTs_result result = new getVerTs_result(); result.success = o; try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; getVerTs_result result = new getVerTs_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, getVerTs_args args, org.apache.thrift.async.AsyncMethodCallback<List<TCell>> resultHandler) throws TException { iface.getVerTs(args.tableName, args.row, args.column, args.timestamp, args.numVersions, args.attributes,resultHandler); } } public static class getRow<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, getRow_args, List<TRowResult>> { public getRow() { super("getRow"); } public getRow_args getEmptyArgsInstance() { return new getRow_args(); } public AsyncMethodCallback<List<TRowResult>> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<List<TRowResult>>() { public void onComplete(List<TRowResult> o) { getRow_result result = new getRow_result(); result.success = o; try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; getRow_result result = new getRow_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, getRow_args args, org.apache.thrift.async.AsyncMethodCallback<List<TRowResult>> resultHandler) throws TException { iface.getRow(args.tableName, args.row, args.attributes,resultHandler); } } public static class getRowWithColumns<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, getRowWithColumns_args, List<TRowResult>> { public getRowWithColumns() { super("getRowWithColumns"); } public getRowWithColumns_args getEmptyArgsInstance() { return new getRowWithColumns_args(); } public AsyncMethodCallback<List<TRowResult>> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<List<TRowResult>>() { public void onComplete(List<TRowResult> o) { getRowWithColumns_result result = new getRowWithColumns_result(); result.success = o; try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; getRowWithColumns_result result = new getRowWithColumns_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, getRowWithColumns_args args, org.apache.thrift.async.AsyncMethodCallback<List<TRowResult>> resultHandler) throws TException { iface.getRowWithColumns(args.tableName, args.row, args.columns, args.attributes,resultHandler); } } public static class getRowTs<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, getRowTs_args, List<TRowResult>> { public getRowTs() { super("getRowTs"); } public getRowTs_args getEmptyArgsInstance() { return new getRowTs_args(); } public AsyncMethodCallback<List<TRowResult>> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<List<TRowResult>>() { public void onComplete(List<TRowResult> o) { getRowTs_result result = new getRowTs_result(); result.success = o; try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; getRowTs_result result = new getRowTs_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, getRowTs_args args, org.apache.thrift.async.AsyncMethodCallback<List<TRowResult>> resultHandler) throws TException { iface.getRowTs(args.tableName, args.row, args.timestamp, args.attributes,resultHandler); } } public static class getRowWithColumnsTs<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, getRowWithColumnsTs_args, List<TRowResult>> { public getRowWithColumnsTs() { super("getRowWithColumnsTs"); } public getRowWithColumnsTs_args getEmptyArgsInstance() { return new getRowWithColumnsTs_args(); } public AsyncMethodCallback<List<TRowResult>> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<List<TRowResult>>() { public void onComplete(List<TRowResult> o) { getRowWithColumnsTs_result result = new getRowWithColumnsTs_result(); result.success = o; try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; getRowWithColumnsTs_result result = new getRowWithColumnsTs_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, getRowWithColumnsTs_args args, org.apache.thrift.async.AsyncMethodCallback<List<TRowResult>> resultHandler) throws TException { iface.getRowWithColumnsTs(args.tableName, args.row, args.columns, args.timestamp, args.attributes,resultHandler); } } public static class getRows<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, getRows_args, List<TRowResult>> { public getRows() { super("getRows"); } public getRows_args getEmptyArgsInstance() { return new getRows_args(); } public AsyncMethodCallback<List<TRowResult>> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<List<TRowResult>>() { public void onComplete(List<TRowResult> o) { getRows_result result = new getRows_result(); result.success = o; try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; getRows_result result = new getRows_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, getRows_args args, org.apache.thrift.async.AsyncMethodCallback<List<TRowResult>> resultHandler) throws TException { iface.getRows(args.tableName, args.rows, args.attributes,resultHandler); } } public static class getRowsWithColumns<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, getRowsWithColumns_args, List<TRowResult>> { public getRowsWithColumns() { super("getRowsWithColumns"); } public getRowsWithColumns_args getEmptyArgsInstance() { return new getRowsWithColumns_args(); } public AsyncMethodCallback<List<TRowResult>> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<List<TRowResult>>() { public void onComplete(List<TRowResult> o) { getRowsWithColumns_result result = new getRowsWithColumns_result(); result.success = o; try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; getRowsWithColumns_result result = new getRowsWithColumns_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, getRowsWithColumns_args args, org.apache.thrift.async.AsyncMethodCallback<List<TRowResult>> resultHandler) throws TException { iface.getRowsWithColumns(args.tableName, args.rows, args.columns, args.attributes,resultHandler); } } public static class getRowsTs<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, getRowsTs_args, List<TRowResult>> { public getRowsTs() { super("getRowsTs"); } public getRowsTs_args getEmptyArgsInstance() { return new getRowsTs_args(); } public AsyncMethodCallback<List<TRowResult>> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<List<TRowResult>>() { public void onComplete(List<TRowResult> o) { getRowsTs_result result = new getRowsTs_result(); result.success = o; try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; getRowsTs_result result = new getRowsTs_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, getRowsTs_args args, org.apache.thrift.async.AsyncMethodCallback<List<TRowResult>> resultHandler) throws TException { iface.getRowsTs(args.tableName, args.rows, args.timestamp, args.attributes,resultHandler); } } public static class getRowsWithColumnsTs<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, getRowsWithColumnsTs_args, List<TRowResult>> { public getRowsWithColumnsTs() { super("getRowsWithColumnsTs"); } public getRowsWithColumnsTs_args getEmptyArgsInstance() { return new getRowsWithColumnsTs_args(); } public AsyncMethodCallback<List<TRowResult>> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<List<TRowResult>>() { public void onComplete(List<TRowResult> o) { getRowsWithColumnsTs_result result = new getRowsWithColumnsTs_result(); result.success = o; try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; getRowsWithColumnsTs_result result = new getRowsWithColumnsTs_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, getRowsWithColumnsTs_args args, org.apache.thrift.async.AsyncMethodCallback<List<TRowResult>> resultHandler) throws TException { iface.getRowsWithColumnsTs(args.tableName, args.rows, args.columns, args.timestamp, args.attributes,resultHandler); } } public static class mutateRow<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, mutateRow_args, Void> { public mutateRow() { super("mutateRow"); } public mutateRow_args getEmptyArgsInstance() { return new mutateRow_args(); } public AsyncMethodCallback<Void> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<Void>() { public void onComplete(Void o) { mutateRow_result result = new mutateRow_result(); try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; mutateRow_result result = new mutateRow_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else if (e instanceof IllegalArgument) { result.ia = (IllegalArgument) e; result.setIaIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, mutateRow_args args, org.apache.thrift.async.AsyncMethodCallback<Void> resultHandler) throws TException { iface.mutateRow(args.tableName, args.row, args.mutations, args.attributes,resultHandler); } } public static class mutateRowTs<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, mutateRowTs_args, Void> { public mutateRowTs() { super("mutateRowTs"); } public mutateRowTs_args getEmptyArgsInstance() { return new mutateRowTs_args(); } public AsyncMethodCallback<Void> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<Void>() { public void onComplete(Void o) { mutateRowTs_result result = new mutateRowTs_result(); try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; mutateRowTs_result result = new mutateRowTs_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else if (e instanceof IllegalArgument) { result.ia = (IllegalArgument) e; result.setIaIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, mutateRowTs_args args, org.apache.thrift.async.AsyncMethodCallback<Void> resultHandler) throws TException { iface.mutateRowTs(args.tableName, args.row, args.mutations, args.timestamp, args.attributes,resultHandler); } } public static class mutateRows<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, mutateRows_args, Void> { public mutateRows() { super("mutateRows"); } public mutateRows_args getEmptyArgsInstance() { return new mutateRows_args(); } public AsyncMethodCallback<Void> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<Void>() { public void onComplete(Void o) { mutateRows_result result = new mutateRows_result(); try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; mutateRows_result result = new mutateRows_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else if (e instanceof IllegalArgument) { result.ia = (IllegalArgument) e; result.setIaIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, mutateRows_args args, org.apache.thrift.async.AsyncMethodCallback<Void> resultHandler) throws TException { iface.mutateRows(args.tableName, args.rowBatches, args.attributes,resultHandler); } } public static class mutateRowsTs<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, mutateRowsTs_args, Void> { public mutateRowsTs() { super("mutateRowsTs"); } public mutateRowsTs_args getEmptyArgsInstance() { return new mutateRowsTs_args(); } public AsyncMethodCallback<Void> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<Void>() { public void onComplete(Void o) { mutateRowsTs_result result = new mutateRowsTs_result(); try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; mutateRowsTs_result result = new mutateRowsTs_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else if (e instanceof IllegalArgument) { result.ia = (IllegalArgument) e; result.setIaIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, mutateRowsTs_args args, org.apache.thrift.async.AsyncMethodCallback<Void> resultHandler) throws TException { iface.mutateRowsTs(args.tableName, args.rowBatches, args.timestamp, args.attributes,resultHandler); } } public static class atomicIncrement<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, atomicIncrement_args, Long> { public atomicIncrement() { super("atomicIncrement"); } public atomicIncrement_args getEmptyArgsInstance() { return new atomicIncrement_args(); } public AsyncMethodCallback<Long> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<Long>() { public void onComplete(Long o) { atomicIncrement_result result = new atomicIncrement_result(); result.success = o; result.setSuccessIsSet(true); try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; atomicIncrement_result result = new atomicIncrement_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else if (e instanceof IllegalArgument) { result.ia = (IllegalArgument) e; result.setIaIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, atomicIncrement_args args, org.apache.thrift.async.AsyncMethodCallback<Long> resultHandler) throws TException { iface.atomicIncrement(args.tableName, args.row, args.column, args.value,resultHandler); } } public static class deleteAll<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, deleteAll_args, Void> { public deleteAll() { super("deleteAll"); } public deleteAll_args getEmptyArgsInstance() { return new deleteAll_args(); } public AsyncMethodCallback<Void> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<Void>() { public void onComplete(Void o) { deleteAll_result result = new deleteAll_result(); try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; deleteAll_result result = new deleteAll_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, deleteAll_args args, org.apache.thrift.async.AsyncMethodCallback<Void> resultHandler) throws TException { iface.deleteAll(args.tableName, args.row, args.column, args.attributes,resultHandler); } } public static class deleteAllTs<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, deleteAllTs_args, Void> { public deleteAllTs() { super("deleteAllTs"); } public deleteAllTs_args getEmptyArgsInstance() { return new deleteAllTs_args(); } public AsyncMethodCallback<Void> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<Void>() { public void onComplete(Void o) { deleteAllTs_result result = new deleteAllTs_result(); try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; deleteAllTs_result result = new deleteAllTs_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, deleteAllTs_args args, org.apache.thrift.async.AsyncMethodCallback<Void> resultHandler) throws TException { iface.deleteAllTs(args.tableName, args.row, args.column, args.timestamp, args.attributes,resultHandler); } } public static class deleteAllRow<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, deleteAllRow_args, Void> { public deleteAllRow() { super("deleteAllRow"); } public deleteAllRow_args getEmptyArgsInstance() { return new deleteAllRow_args(); } public AsyncMethodCallback<Void> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<Void>() { public void onComplete(Void o) { deleteAllRow_result result = new deleteAllRow_result(); try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; deleteAllRow_result result = new deleteAllRow_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, deleteAllRow_args args, org.apache.thrift.async.AsyncMethodCallback<Void> resultHandler) throws TException { iface.deleteAllRow(args.tableName, args.row, args.attributes,resultHandler); } } public static class increment<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, increment_args, Void> { public increment() { super("increment"); } public increment_args getEmptyArgsInstance() { return new increment_args(); } public AsyncMethodCallback<Void> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<Void>() { public void onComplete(Void o) { increment_result result = new increment_result(); try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; increment_result result = new increment_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, increment_args args, org.apache.thrift.async.AsyncMethodCallback<Void> resultHandler) throws TException { iface.increment(args.increment,resultHandler); } } public static class incrementRows<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, incrementRows_args, Void> { public incrementRows() { super("incrementRows"); } public incrementRows_args getEmptyArgsInstance() { return new incrementRows_args(); } public AsyncMethodCallback<Void> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<Void>() { public void onComplete(Void o) { incrementRows_result result = new incrementRows_result(); try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; incrementRows_result result = new incrementRows_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, incrementRows_args args, org.apache.thrift.async.AsyncMethodCallback<Void> resultHandler) throws TException { iface.incrementRows(args.increments,resultHandler); } } public static class deleteAllRowTs<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, deleteAllRowTs_args, Void> { public deleteAllRowTs() { super("deleteAllRowTs"); } public deleteAllRowTs_args getEmptyArgsInstance() { return new deleteAllRowTs_args(); } public AsyncMethodCallback<Void> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<Void>() { public void onComplete(Void o) { deleteAllRowTs_result result = new deleteAllRowTs_result(); try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; deleteAllRowTs_result result = new deleteAllRowTs_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, deleteAllRowTs_args args, org.apache.thrift.async.AsyncMethodCallback<Void> resultHandler) throws TException { iface.deleteAllRowTs(args.tableName, args.row, args.timestamp, args.attributes,resultHandler); } } public static class scannerOpenWithScan<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, scannerOpenWithScan_args, Integer> { public scannerOpenWithScan() { super("scannerOpenWithScan"); } public scannerOpenWithScan_args getEmptyArgsInstance() { return new scannerOpenWithScan_args(); } public AsyncMethodCallback<Integer> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<Integer>() { public void onComplete(Integer o) { scannerOpenWithScan_result result = new scannerOpenWithScan_result(); result.success = o; result.setSuccessIsSet(true); try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; scannerOpenWithScan_result result = new scannerOpenWithScan_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, scannerOpenWithScan_args args, org.apache.thrift.async.AsyncMethodCallback<Integer> resultHandler) throws TException { iface.scannerOpenWithScan(args.tableName, args.scan, args.attributes,resultHandler); } } public static class scannerOpen<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, scannerOpen_args, Integer> { public scannerOpen() { super("scannerOpen"); } public scannerOpen_args getEmptyArgsInstance() { return new scannerOpen_args(); } public AsyncMethodCallback<Integer> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<Integer>() { public void onComplete(Integer o) { scannerOpen_result result = new scannerOpen_result(); result.success = o; result.setSuccessIsSet(true); try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; scannerOpen_result result = new scannerOpen_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, scannerOpen_args args, org.apache.thrift.async.AsyncMethodCallback<Integer> resultHandler) throws TException { iface.scannerOpen(args.tableName, args.startRow, args.columns, args.attributes,resultHandler); } } public static class scannerOpenWithStop<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, scannerOpenWithStop_args, Integer> { public scannerOpenWithStop() { super("scannerOpenWithStop"); } public scannerOpenWithStop_args getEmptyArgsInstance() { return new scannerOpenWithStop_args(); } public AsyncMethodCallback<Integer> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<Integer>() { public void onComplete(Integer o) { scannerOpenWithStop_result result = new scannerOpenWithStop_result(); result.success = o; result.setSuccessIsSet(true); try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; scannerOpenWithStop_result result = new scannerOpenWithStop_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, scannerOpenWithStop_args args, org.apache.thrift.async.AsyncMethodCallback<Integer> resultHandler) throws TException { iface.scannerOpenWithStop(args.tableName, args.startRow, args.stopRow, args.columns, args.attributes,resultHandler); } } public static class scannerOpenWithPrefix<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, scannerOpenWithPrefix_args, Integer> { public scannerOpenWithPrefix() { super("scannerOpenWithPrefix"); } public scannerOpenWithPrefix_args getEmptyArgsInstance() { return new scannerOpenWithPrefix_args(); } public AsyncMethodCallback<Integer> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<Integer>() { public void onComplete(Integer o) { scannerOpenWithPrefix_result result = new scannerOpenWithPrefix_result(); result.success = o; result.setSuccessIsSet(true); try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; scannerOpenWithPrefix_result result = new scannerOpenWithPrefix_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, scannerOpenWithPrefix_args args, org.apache.thrift.async.AsyncMethodCallback<Integer> resultHandler) throws TException { iface.scannerOpenWithPrefix(args.tableName, args.startAndPrefix, args.columns, args.attributes,resultHandler); } } public static class scannerOpenTs<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, scannerOpenTs_args, Integer> { public scannerOpenTs() { super("scannerOpenTs"); } public scannerOpenTs_args getEmptyArgsInstance() { return new scannerOpenTs_args(); } public AsyncMethodCallback<Integer> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<Integer>() { public void onComplete(Integer o) { scannerOpenTs_result result = new scannerOpenTs_result(); result.success = o; result.setSuccessIsSet(true); try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; scannerOpenTs_result result = new scannerOpenTs_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, scannerOpenTs_args args, org.apache.thrift.async.AsyncMethodCallback<Integer> resultHandler) throws TException { iface.scannerOpenTs(args.tableName, args.startRow, args.columns, args.timestamp, args.attributes,resultHandler); } } public static class scannerOpenWithStopTs<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, scannerOpenWithStopTs_args, Integer> { public scannerOpenWithStopTs() { super("scannerOpenWithStopTs"); } public scannerOpenWithStopTs_args getEmptyArgsInstance() { return new scannerOpenWithStopTs_args(); } public AsyncMethodCallback<Integer> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<Integer>() { public void onComplete(Integer o) { scannerOpenWithStopTs_result result = new scannerOpenWithStopTs_result(); result.success = o; result.setSuccessIsSet(true); try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; scannerOpenWithStopTs_result result = new scannerOpenWithStopTs_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, scannerOpenWithStopTs_args args, org.apache.thrift.async.AsyncMethodCallback<Integer> resultHandler) throws TException { iface.scannerOpenWithStopTs(args.tableName, args.startRow, args.stopRow, args.columns, args.timestamp, args.attributes,resultHandler); } } public static class scannerGet<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, scannerGet_args, List<TRowResult>> { public scannerGet() { super("scannerGet"); } public scannerGet_args getEmptyArgsInstance() { return new scannerGet_args(); } public AsyncMethodCallback<List<TRowResult>> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<List<TRowResult>>() { public void onComplete(List<TRowResult> o) { scannerGet_result result = new scannerGet_result(); result.success = o; try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; scannerGet_result result = new scannerGet_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else if (e instanceof IllegalArgument) { result.ia = (IllegalArgument) e; result.setIaIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, scannerGet_args args, org.apache.thrift.async.AsyncMethodCallback<List<TRowResult>> resultHandler) throws TException { iface.scannerGet(args.id,resultHandler); } } public static class scannerGetList<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, scannerGetList_args, List<TRowResult>> { public scannerGetList() { super("scannerGetList"); } public scannerGetList_args getEmptyArgsInstance() { return new scannerGetList_args(); } public AsyncMethodCallback<List<TRowResult>> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<List<TRowResult>>() { public void onComplete(List<TRowResult> o) { scannerGetList_result result = new scannerGetList_result(); result.success = o; try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; scannerGetList_result result = new scannerGetList_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else if (e instanceof IllegalArgument) { result.ia = (IllegalArgument) e; result.setIaIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, scannerGetList_args args, org.apache.thrift.async.AsyncMethodCallback<List<TRowResult>> resultHandler) throws TException { iface.scannerGetList(args.id, args.nbRows,resultHandler); } } public static class scannerClose<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, scannerClose_args, Void> { public scannerClose() { super("scannerClose"); } public scannerClose_args getEmptyArgsInstance() { return new scannerClose_args(); } public AsyncMethodCallback<Void> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<Void>() { public void onComplete(Void o) { scannerClose_result result = new scannerClose_result(); try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; scannerClose_result result = new scannerClose_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else if (e instanceof IllegalArgument) { result.ia = (IllegalArgument) e; result.setIaIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, scannerClose_args args, org.apache.thrift.async.AsyncMethodCallback<Void> resultHandler) throws TException { iface.scannerClose(args.id,resultHandler); } } public static class getRegionInfo<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, getRegionInfo_args, TRegionInfo> { public getRegionInfo() { super("getRegionInfo"); } public getRegionInfo_args getEmptyArgsInstance() { return new getRegionInfo_args(); } public AsyncMethodCallback<TRegionInfo> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<TRegionInfo>() { public void onComplete(TRegionInfo o) { getRegionInfo_result result = new getRegionInfo_result(); result.success = o; try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; getRegionInfo_result result = new getRegionInfo_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, getRegionInfo_args args, org.apache.thrift.async.AsyncMethodCallback<TRegionInfo> resultHandler) throws TException { iface.getRegionInfo(args.row,resultHandler); } } public static class append<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, append_args, List<TCell>> { public append() { super("append"); } public append_args getEmptyArgsInstance() { return new append_args(); } public AsyncMethodCallback<List<TCell>> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<List<TCell>>() { public void onComplete(List<TCell> o) { append_result result = new append_result(); result.success = o; try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; append_result result = new append_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, append_args args, org.apache.thrift.async.AsyncMethodCallback<List<TCell>> resultHandler) throws TException { iface.append(args.append,resultHandler); } } public static class checkAndPut<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, checkAndPut_args, Boolean> { public checkAndPut() { super("checkAndPut"); } public checkAndPut_args getEmptyArgsInstance() { return new checkAndPut_args(); } public AsyncMethodCallback<Boolean> getResultHandler(final AsyncFrameBuffer fb, final int seqid) { final org.apache.thrift.AsyncProcessFunction fcall = this; return new AsyncMethodCallback<Boolean>() { public void onComplete(Boolean o) { checkAndPut_result result = new checkAndPut_result(); result.success = o; result.setSuccessIsSet(true); try { fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid); return; } catch (Exception e) { LOGGER.error("Exception writing to internal frame buffer", e); } fb.close(); } public void onError(Exception e) { byte msgType = org.apache.thrift.protocol.TMessageType.REPLY; org.apache.thrift.TBase msg; checkAndPut_result result = new checkAndPut_result(); if (e instanceof IOError) { result.io = (IOError) e; result.setIoIsSet(true); msg = result; } else if (e instanceof IllegalArgument) { result.ia = (IllegalArgument) e; result.setIaIsSet(true); msg = result; } else { msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION; msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage()); } try { fcall.sendResponse(fb,msg,msgType,seqid); return; } catch (Exception ex) { LOGGER.error("Exception writing to internal frame buffer", ex); } fb.close(); } }; } protected boolean isOneway() { return false; } public void start(I iface, checkAndPut_args args, org.apache.thrift.async.AsyncMethodCallback<Boolean> resultHandler) throws TException { iface.checkAndPut(args.tableName, args.row, args.column, args.value, args.mput, args.attributes,resultHandler); } } } public static class enableTable_args implements org.apache.thrift.TBase<enableTable_args, enableTable_args._Fields>, java.io.Serializable, Cloneable, Comparable<enableTable_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("enableTable_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new enableTable_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new enableTable_argsTupleSchemeFactory()); } /** * name of the table */ public ByteBuffer tableName; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * name of the table */ TABLE_NAME((short)1, "tableName"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Bytes"))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(enableTable_args.class, metaDataMap); } public enableTable_args() { } public enableTable_args( ByteBuffer tableName) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * Performs a deep copy on <i>other</i>. */ public enableTable_args(enableTable_args other) { if (other.isSetTableName()) { this.tableName = other.tableName; } } public enableTable_args deepCopy() { return new enableTable_args(this); } @Override public void clear() { this.tableName = null; } /** * name of the table */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * name of the table */ public enableTable_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public enableTable_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof enableTable_args) return this.equals((enableTable_args)that); return false; } public boolean equals(enableTable_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); return list.hashCode(); } @Override public int compareTo(enableTable_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("enableTable_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class enableTable_argsStandardSchemeFactory implements SchemeFactory { public enableTable_argsStandardScheme getScheme() { return new enableTable_argsStandardScheme(); } } private static class enableTable_argsStandardScheme extends StandardScheme<enableTable_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, enableTable_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, enableTable_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class enableTable_argsTupleSchemeFactory implements SchemeFactory { public enableTable_argsTupleScheme getScheme() { return new enableTable_argsTupleScheme(); } } private static class enableTable_argsTupleScheme extends TupleScheme<enableTable_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, enableTable_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } oprot.writeBitSet(optionals, 1); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, enableTable_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(1); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } } } } public static class enableTable_result implements org.apache.thrift.TBase<enableTable_result, enableTable_result._Fields>, java.io.Serializable, Cloneable, Comparable<enableTable_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("enableTable_result"); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new enableTable_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new enableTable_resultTupleSchemeFactory()); } public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(enableTable_result.class, metaDataMap); } public enableTable_result() { } public enableTable_result( IOError io) { this(); this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public enableTable_result(enableTable_result other) { if (other.isSetIo()) { this.io = new IOError(other.io); } } public enableTable_result deepCopy() { return new enableTable_result(this); } @Override public void clear() { this.io = null; } public IOError getIo() { return this.io; } public enableTable_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof enableTable_result) return this.equals((enableTable_result)that); return false; } public boolean equals(enableTable_result that) { if (that == null) return false; boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(enableTable_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("enableTable_result("); boolean first = true; sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class enableTable_resultStandardSchemeFactory implements SchemeFactory { public enableTable_resultStandardScheme getScheme() { return new enableTable_resultStandardScheme(); } } private static class enableTable_resultStandardScheme extends StandardScheme<enableTable_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, enableTable_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, enableTable_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class enableTable_resultTupleSchemeFactory implements SchemeFactory { public enableTable_resultTupleScheme getScheme() { return new enableTable_resultTupleScheme(); } } private static class enableTable_resultTupleScheme extends TupleScheme<enableTable_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, enableTable_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetIo()) { optionals.set(0); } oprot.writeBitSet(optionals, 1); if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, enableTable_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(1); if (incoming.get(0)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class disableTable_args implements org.apache.thrift.TBase<disableTable_args, disableTable_args._Fields>, java.io.Serializable, Cloneable, Comparable<disableTable_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("disableTable_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new disableTable_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new disableTable_argsTupleSchemeFactory()); } /** * name of the table */ public ByteBuffer tableName; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * name of the table */ TABLE_NAME((short)1, "tableName"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Bytes"))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(disableTable_args.class, metaDataMap); } public disableTable_args() { } public disableTable_args( ByteBuffer tableName) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * Performs a deep copy on <i>other</i>. */ public disableTable_args(disableTable_args other) { if (other.isSetTableName()) { this.tableName = other.tableName; } } public disableTable_args deepCopy() { return new disableTable_args(this); } @Override public void clear() { this.tableName = null; } /** * name of the table */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * name of the table */ public disableTable_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public disableTable_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof disableTable_args) return this.equals((disableTable_args)that); return false; } public boolean equals(disableTable_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); return list.hashCode(); } @Override public int compareTo(disableTable_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("disableTable_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class disableTable_argsStandardSchemeFactory implements SchemeFactory { public disableTable_argsStandardScheme getScheme() { return new disableTable_argsStandardScheme(); } } private static class disableTable_argsStandardScheme extends StandardScheme<disableTable_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, disableTable_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, disableTable_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class disableTable_argsTupleSchemeFactory implements SchemeFactory { public disableTable_argsTupleScheme getScheme() { return new disableTable_argsTupleScheme(); } } private static class disableTable_argsTupleScheme extends TupleScheme<disableTable_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, disableTable_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } oprot.writeBitSet(optionals, 1); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, disableTable_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(1); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } } } } public static class disableTable_result implements org.apache.thrift.TBase<disableTable_result, disableTable_result._Fields>, java.io.Serializable, Cloneable, Comparable<disableTable_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("disableTable_result"); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new disableTable_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new disableTable_resultTupleSchemeFactory()); } public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(disableTable_result.class, metaDataMap); } public disableTable_result() { } public disableTable_result( IOError io) { this(); this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public disableTable_result(disableTable_result other) { if (other.isSetIo()) { this.io = new IOError(other.io); } } public disableTable_result deepCopy() { return new disableTable_result(this); } @Override public void clear() { this.io = null; } public IOError getIo() { return this.io; } public disableTable_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof disableTable_result) return this.equals((disableTable_result)that); return false; } public boolean equals(disableTable_result that) { if (that == null) return false; boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(disableTable_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("disableTable_result("); boolean first = true; sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class disableTable_resultStandardSchemeFactory implements SchemeFactory { public disableTable_resultStandardScheme getScheme() { return new disableTable_resultStandardScheme(); } } private static class disableTable_resultStandardScheme extends StandardScheme<disableTable_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, disableTable_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, disableTable_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class disableTable_resultTupleSchemeFactory implements SchemeFactory { public disableTable_resultTupleScheme getScheme() { return new disableTable_resultTupleScheme(); } } private static class disableTable_resultTupleScheme extends TupleScheme<disableTable_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, disableTable_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetIo()) { optionals.set(0); } oprot.writeBitSet(optionals, 1); if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, disableTable_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(1); if (incoming.get(0)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class isTableEnabled_args implements org.apache.thrift.TBase<isTableEnabled_args, isTableEnabled_args._Fields>, java.io.Serializable, Cloneable, Comparable<isTableEnabled_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("isTableEnabled_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new isTableEnabled_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new isTableEnabled_argsTupleSchemeFactory()); } /** * name of the table to check */ public ByteBuffer tableName; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * name of the table to check */ TABLE_NAME((short)1, "tableName"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Bytes"))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(isTableEnabled_args.class, metaDataMap); } public isTableEnabled_args() { } public isTableEnabled_args( ByteBuffer tableName) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * Performs a deep copy on <i>other</i>. */ public isTableEnabled_args(isTableEnabled_args other) { if (other.isSetTableName()) { this.tableName = other.tableName; } } public isTableEnabled_args deepCopy() { return new isTableEnabled_args(this); } @Override public void clear() { this.tableName = null; } /** * name of the table to check */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * name of the table to check */ public isTableEnabled_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public isTableEnabled_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof isTableEnabled_args) return this.equals((isTableEnabled_args)that); return false; } public boolean equals(isTableEnabled_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); return list.hashCode(); } @Override public int compareTo(isTableEnabled_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("isTableEnabled_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class isTableEnabled_argsStandardSchemeFactory implements SchemeFactory { public isTableEnabled_argsStandardScheme getScheme() { return new isTableEnabled_argsStandardScheme(); } } private static class isTableEnabled_argsStandardScheme extends StandardScheme<isTableEnabled_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, isTableEnabled_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, isTableEnabled_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class isTableEnabled_argsTupleSchemeFactory implements SchemeFactory { public isTableEnabled_argsTupleScheme getScheme() { return new isTableEnabled_argsTupleScheme(); } } private static class isTableEnabled_argsTupleScheme extends TupleScheme<isTableEnabled_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, isTableEnabled_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } oprot.writeBitSet(optionals, 1); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, isTableEnabled_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(1); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } } } } public static class isTableEnabled_result implements org.apache.thrift.TBase<isTableEnabled_result, isTableEnabled_result._Fields>, java.io.Serializable, Cloneable, Comparable<isTableEnabled_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("isTableEnabled_result"); private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.BOOL, (short)0); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new isTableEnabled_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new isTableEnabled_resultTupleSchemeFactory()); } public boolean success; // required public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { SUCCESS((short)0, "success"), IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 0: // SUCCESS return SUCCESS; case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments private static final int __SUCCESS_ISSET_ID = 0; private byte __isset_bitfield = 0; public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.SUCCESS, new org.apache.thrift.meta_data.FieldMetaData("success", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.BOOL))); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(isTableEnabled_result.class, metaDataMap); } public isTableEnabled_result() { } public isTableEnabled_result( boolean success, IOError io) { this(); this.success = success; setSuccessIsSet(true); this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public isTableEnabled_result(isTableEnabled_result other) { __isset_bitfield = other.__isset_bitfield; this.success = other.success; if (other.isSetIo()) { this.io = new IOError(other.io); } } public isTableEnabled_result deepCopy() { return new isTableEnabled_result(this); } @Override public void clear() { setSuccessIsSet(false); this.success = false; this.io = null; } public boolean isSuccess() { return this.success; } public isTableEnabled_result setSuccess(boolean success) { this.success = success; setSuccessIsSet(true); return this; } public void unsetSuccess() { __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __SUCCESS_ISSET_ID); } /** Returns true if field success is set (has been assigned a value) and false otherwise */ public boolean isSetSuccess() { return EncodingUtils.testBit(__isset_bitfield, __SUCCESS_ISSET_ID); } public void setSuccessIsSet(boolean value) { __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __SUCCESS_ISSET_ID, value); } public IOError getIo() { return this.io; } public isTableEnabled_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case SUCCESS: if (value == null) { unsetSuccess(); } else { setSuccess((Boolean)value); } break; case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case SUCCESS: return isSuccess(); case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case SUCCESS: return isSetSuccess(); case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof isTableEnabled_result) return this.equals((isTableEnabled_result)that); return false; } public boolean equals(isTableEnabled_result that) { if (that == null) return false; boolean this_present_success = true; boolean that_present_success = true; if (this_present_success || that_present_success) { if (!(this_present_success && that_present_success)) return false; if (this.success != that.success) return false; } boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_success = true; list.add(present_success); if (present_success) list.add(success); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(isTableEnabled_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess()); if (lastComparison != 0) { return lastComparison; } if (isSetSuccess()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("isTableEnabled_result("); boolean first = true; sb.append("success:"); sb.append(this.success); first = false; if (!first) sb.append(", "); sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { // it doesn't seem like you should have to do this, but java serialization is wacky, and doesn't call the default constructor. __isset_bitfield = 0; read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class isTableEnabled_resultStandardSchemeFactory implements SchemeFactory { public isTableEnabled_resultStandardScheme getScheme() { return new isTableEnabled_resultStandardScheme(); } } private static class isTableEnabled_resultStandardScheme extends StandardScheme<isTableEnabled_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, isTableEnabled_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.BOOL) { struct.success = iprot.readBool(); struct.setSuccessIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, isTableEnabled_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.isSetSuccess()) { oprot.writeFieldBegin(SUCCESS_FIELD_DESC); oprot.writeBool(struct.success); oprot.writeFieldEnd(); } if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class isTableEnabled_resultTupleSchemeFactory implements SchemeFactory { public isTableEnabled_resultTupleScheme getScheme() { return new isTableEnabled_resultTupleScheme(); } } private static class isTableEnabled_resultTupleScheme extends TupleScheme<isTableEnabled_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, isTableEnabled_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetSuccess()) { optionals.set(0); } if (struct.isSetIo()) { optionals.set(1); } oprot.writeBitSet(optionals, 2); if (struct.isSetSuccess()) { oprot.writeBool(struct.success); } if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, isTableEnabled_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { struct.success = iprot.readBool(); struct.setSuccessIsSet(true); } if (incoming.get(1)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class compact_args implements org.apache.thrift.TBase<compact_args, compact_args._Fields>, java.io.Serializable, Cloneable, Comparable<compact_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("compact_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_OR_REGION_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableNameOrRegionName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new compact_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new compact_argsTupleSchemeFactory()); } public ByteBuffer tableNameOrRegionName; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { TABLE_NAME_OR_REGION_NAME((short)1, "tableNameOrRegionName"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME_OR_REGION_NAME return TABLE_NAME_OR_REGION_NAME; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME_OR_REGION_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableNameOrRegionName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Bytes"))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(compact_args.class, metaDataMap); } public compact_args() { } public compact_args( ByteBuffer tableNameOrRegionName) { this(); this.tableNameOrRegionName = org.apache.thrift.TBaseHelper.copyBinary(tableNameOrRegionName); } /** * Performs a deep copy on <i>other</i>. */ public compact_args(compact_args other) { if (other.isSetTableNameOrRegionName()) { this.tableNameOrRegionName = other.tableNameOrRegionName; } } public compact_args deepCopy() { return new compact_args(this); } @Override public void clear() { this.tableNameOrRegionName = null; } public byte[] getTableNameOrRegionName() { setTableNameOrRegionName(org.apache.thrift.TBaseHelper.rightSize(tableNameOrRegionName)); return tableNameOrRegionName == null ? null : tableNameOrRegionName.array(); } public ByteBuffer bufferForTableNameOrRegionName() { return org.apache.thrift.TBaseHelper.copyBinary(tableNameOrRegionName); } public compact_args setTableNameOrRegionName(byte[] tableNameOrRegionName) { this.tableNameOrRegionName = tableNameOrRegionName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableNameOrRegionName, tableNameOrRegionName.length)); return this; } public compact_args setTableNameOrRegionName(ByteBuffer tableNameOrRegionName) { this.tableNameOrRegionName = org.apache.thrift.TBaseHelper.copyBinary(tableNameOrRegionName); return this; } public void unsetTableNameOrRegionName() { this.tableNameOrRegionName = null; } /** Returns true if field tableNameOrRegionName is set (has been assigned a value) and false otherwise */ public boolean isSetTableNameOrRegionName() { return this.tableNameOrRegionName != null; } public void setTableNameOrRegionNameIsSet(boolean value) { if (!value) { this.tableNameOrRegionName = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME_OR_REGION_NAME: if (value == null) { unsetTableNameOrRegionName(); } else { setTableNameOrRegionName((ByteBuffer)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME_OR_REGION_NAME: return getTableNameOrRegionName(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME_OR_REGION_NAME: return isSetTableNameOrRegionName(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof compact_args) return this.equals((compact_args)that); return false; } public boolean equals(compact_args that) { if (that == null) return false; boolean this_present_tableNameOrRegionName = true && this.isSetTableNameOrRegionName(); boolean that_present_tableNameOrRegionName = true && that.isSetTableNameOrRegionName(); if (this_present_tableNameOrRegionName || that_present_tableNameOrRegionName) { if (!(this_present_tableNameOrRegionName && that_present_tableNameOrRegionName)) return false; if (!this.tableNameOrRegionName.equals(that.tableNameOrRegionName)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableNameOrRegionName = true && (isSetTableNameOrRegionName()); list.add(present_tableNameOrRegionName); if (present_tableNameOrRegionName) list.add(tableNameOrRegionName); return list.hashCode(); } @Override public int compareTo(compact_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableNameOrRegionName()).compareTo(other.isSetTableNameOrRegionName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableNameOrRegionName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableNameOrRegionName, other.tableNameOrRegionName); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("compact_args("); boolean first = true; sb.append("tableNameOrRegionName:"); if (this.tableNameOrRegionName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableNameOrRegionName, sb); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class compact_argsStandardSchemeFactory implements SchemeFactory { public compact_argsStandardScheme getScheme() { return new compact_argsStandardScheme(); } } private static class compact_argsStandardScheme extends StandardScheme<compact_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, compact_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME_OR_REGION_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableNameOrRegionName = iprot.readBinary(); struct.setTableNameOrRegionNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, compact_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableNameOrRegionName != null) { oprot.writeFieldBegin(TABLE_NAME_OR_REGION_NAME_FIELD_DESC); oprot.writeBinary(struct.tableNameOrRegionName); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class compact_argsTupleSchemeFactory implements SchemeFactory { public compact_argsTupleScheme getScheme() { return new compact_argsTupleScheme(); } } private static class compact_argsTupleScheme extends TupleScheme<compact_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, compact_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableNameOrRegionName()) { optionals.set(0); } oprot.writeBitSet(optionals, 1); if (struct.isSetTableNameOrRegionName()) { oprot.writeBinary(struct.tableNameOrRegionName); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, compact_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(1); if (incoming.get(0)) { struct.tableNameOrRegionName = iprot.readBinary(); struct.setTableNameOrRegionNameIsSet(true); } } } } public static class compact_result implements org.apache.thrift.TBase<compact_result, compact_result._Fields>, java.io.Serializable, Cloneable, Comparable<compact_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("compact_result"); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new compact_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new compact_resultTupleSchemeFactory()); } public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(compact_result.class, metaDataMap); } public compact_result() { } public compact_result( IOError io) { this(); this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public compact_result(compact_result other) { if (other.isSetIo()) { this.io = new IOError(other.io); } } public compact_result deepCopy() { return new compact_result(this); } @Override public void clear() { this.io = null; } public IOError getIo() { return this.io; } public compact_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof compact_result) return this.equals((compact_result)that); return false; } public boolean equals(compact_result that) { if (that == null) return false; boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(compact_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("compact_result("); boolean first = true; sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class compact_resultStandardSchemeFactory implements SchemeFactory { public compact_resultStandardScheme getScheme() { return new compact_resultStandardScheme(); } } private static class compact_resultStandardScheme extends StandardScheme<compact_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, compact_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, compact_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class compact_resultTupleSchemeFactory implements SchemeFactory { public compact_resultTupleScheme getScheme() { return new compact_resultTupleScheme(); } } private static class compact_resultTupleScheme extends TupleScheme<compact_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, compact_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetIo()) { optionals.set(0); } oprot.writeBitSet(optionals, 1); if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, compact_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(1); if (incoming.get(0)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class majorCompact_args implements org.apache.thrift.TBase<majorCompact_args, majorCompact_args._Fields>, java.io.Serializable, Cloneable, Comparable<majorCompact_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("majorCompact_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_OR_REGION_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableNameOrRegionName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new majorCompact_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new majorCompact_argsTupleSchemeFactory()); } public ByteBuffer tableNameOrRegionName; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { TABLE_NAME_OR_REGION_NAME((short)1, "tableNameOrRegionName"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME_OR_REGION_NAME return TABLE_NAME_OR_REGION_NAME; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME_OR_REGION_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableNameOrRegionName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Bytes"))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(majorCompact_args.class, metaDataMap); } public majorCompact_args() { } public majorCompact_args( ByteBuffer tableNameOrRegionName) { this(); this.tableNameOrRegionName = org.apache.thrift.TBaseHelper.copyBinary(tableNameOrRegionName); } /** * Performs a deep copy on <i>other</i>. */ public majorCompact_args(majorCompact_args other) { if (other.isSetTableNameOrRegionName()) { this.tableNameOrRegionName = other.tableNameOrRegionName; } } public majorCompact_args deepCopy() { return new majorCompact_args(this); } @Override public void clear() { this.tableNameOrRegionName = null; } public byte[] getTableNameOrRegionName() { setTableNameOrRegionName(org.apache.thrift.TBaseHelper.rightSize(tableNameOrRegionName)); return tableNameOrRegionName == null ? null : tableNameOrRegionName.array(); } public ByteBuffer bufferForTableNameOrRegionName() { return org.apache.thrift.TBaseHelper.copyBinary(tableNameOrRegionName); } public majorCompact_args setTableNameOrRegionName(byte[] tableNameOrRegionName) { this.tableNameOrRegionName = tableNameOrRegionName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableNameOrRegionName, tableNameOrRegionName.length)); return this; } public majorCompact_args setTableNameOrRegionName(ByteBuffer tableNameOrRegionName) { this.tableNameOrRegionName = org.apache.thrift.TBaseHelper.copyBinary(tableNameOrRegionName); return this; } public void unsetTableNameOrRegionName() { this.tableNameOrRegionName = null; } /** Returns true if field tableNameOrRegionName is set (has been assigned a value) and false otherwise */ public boolean isSetTableNameOrRegionName() { return this.tableNameOrRegionName != null; } public void setTableNameOrRegionNameIsSet(boolean value) { if (!value) { this.tableNameOrRegionName = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME_OR_REGION_NAME: if (value == null) { unsetTableNameOrRegionName(); } else { setTableNameOrRegionName((ByteBuffer)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME_OR_REGION_NAME: return getTableNameOrRegionName(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME_OR_REGION_NAME: return isSetTableNameOrRegionName(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof majorCompact_args) return this.equals((majorCompact_args)that); return false; } public boolean equals(majorCompact_args that) { if (that == null) return false; boolean this_present_tableNameOrRegionName = true && this.isSetTableNameOrRegionName(); boolean that_present_tableNameOrRegionName = true && that.isSetTableNameOrRegionName(); if (this_present_tableNameOrRegionName || that_present_tableNameOrRegionName) { if (!(this_present_tableNameOrRegionName && that_present_tableNameOrRegionName)) return false; if (!this.tableNameOrRegionName.equals(that.tableNameOrRegionName)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableNameOrRegionName = true && (isSetTableNameOrRegionName()); list.add(present_tableNameOrRegionName); if (present_tableNameOrRegionName) list.add(tableNameOrRegionName); return list.hashCode(); } @Override public int compareTo(majorCompact_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableNameOrRegionName()).compareTo(other.isSetTableNameOrRegionName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableNameOrRegionName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableNameOrRegionName, other.tableNameOrRegionName); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("majorCompact_args("); boolean first = true; sb.append("tableNameOrRegionName:"); if (this.tableNameOrRegionName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableNameOrRegionName, sb); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class majorCompact_argsStandardSchemeFactory implements SchemeFactory { public majorCompact_argsStandardScheme getScheme() { return new majorCompact_argsStandardScheme(); } } private static class majorCompact_argsStandardScheme extends StandardScheme<majorCompact_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, majorCompact_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME_OR_REGION_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableNameOrRegionName = iprot.readBinary(); struct.setTableNameOrRegionNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, majorCompact_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableNameOrRegionName != null) { oprot.writeFieldBegin(TABLE_NAME_OR_REGION_NAME_FIELD_DESC); oprot.writeBinary(struct.tableNameOrRegionName); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class majorCompact_argsTupleSchemeFactory implements SchemeFactory { public majorCompact_argsTupleScheme getScheme() { return new majorCompact_argsTupleScheme(); } } private static class majorCompact_argsTupleScheme extends TupleScheme<majorCompact_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, majorCompact_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableNameOrRegionName()) { optionals.set(0); } oprot.writeBitSet(optionals, 1); if (struct.isSetTableNameOrRegionName()) { oprot.writeBinary(struct.tableNameOrRegionName); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, majorCompact_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(1); if (incoming.get(0)) { struct.tableNameOrRegionName = iprot.readBinary(); struct.setTableNameOrRegionNameIsSet(true); } } } } public static class majorCompact_result implements org.apache.thrift.TBase<majorCompact_result, majorCompact_result._Fields>, java.io.Serializable, Cloneable, Comparable<majorCompact_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("majorCompact_result"); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new majorCompact_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new majorCompact_resultTupleSchemeFactory()); } public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(majorCompact_result.class, metaDataMap); } public majorCompact_result() { } public majorCompact_result( IOError io) { this(); this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public majorCompact_result(majorCompact_result other) { if (other.isSetIo()) { this.io = new IOError(other.io); } } public majorCompact_result deepCopy() { return new majorCompact_result(this); } @Override public void clear() { this.io = null; } public IOError getIo() { return this.io; } public majorCompact_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof majorCompact_result) return this.equals((majorCompact_result)that); return false; } public boolean equals(majorCompact_result that) { if (that == null) return false; boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(majorCompact_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("majorCompact_result("); boolean first = true; sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class majorCompact_resultStandardSchemeFactory implements SchemeFactory { public majorCompact_resultStandardScheme getScheme() { return new majorCompact_resultStandardScheme(); } } private static class majorCompact_resultStandardScheme extends StandardScheme<majorCompact_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, majorCompact_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, majorCompact_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class majorCompact_resultTupleSchemeFactory implements SchemeFactory { public majorCompact_resultTupleScheme getScheme() { return new majorCompact_resultTupleScheme(); } } private static class majorCompact_resultTupleScheme extends TupleScheme<majorCompact_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, majorCompact_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetIo()) { optionals.set(0); } oprot.writeBitSet(optionals, 1); if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, majorCompact_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(1); if (incoming.get(0)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class getTableNames_args implements org.apache.thrift.TBase<getTableNames_args, getTableNames_args._Fields>, java.io.Serializable, Cloneable, Comparable<getTableNames_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getTableNames_args"); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new getTableNames_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new getTableNames_argsTupleSchemeFactory()); } /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { ; private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(getTableNames_args.class, metaDataMap); } public getTableNames_args() { } /** * Performs a deep copy on <i>other</i>. */ public getTableNames_args(getTableNames_args other) { } public getTableNames_args deepCopy() { return new getTableNames_args(this); } @Override public void clear() { } public void setFieldValue(_Fields field, Object value) { switch (field) { } } public Object getFieldValue(_Fields field) { switch (field) { } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof getTableNames_args) return this.equals((getTableNames_args)that); return false; } public boolean equals(getTableNames_args that) { if (that == null) return false; return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); return list.hashCode(); } @Override public int compareTo(getTableNames_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("getTableNames_args("); boolean first = true; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class getTableNames_argsStandardSchemeFactory implements SchemeFactory { public getTableNames_argsStandardScheme getScheme() { return new getTableNames_argsStandardScheme(); } } private static class getTableNames_argsStandardScheme extends StandardScheme<getTableNames_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, getTableNames_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, getTableNames_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class getTableNames_argsTupleSchemeFactory implements SchemeFactory { public getTableNames_argsTupleScheme getScheme() { return new getTableNames_argsTupleScheme(); } } private static class getTableNames_argsTupleScheme extends TupleScheme<getTableNames_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, getTableNames_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; } @Override public void read(org.apache.thrift.protocol.TProtocol prot, getTableNames_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; } } } public static class getTableNames_result implements org.apache.thrift.TBase<getTableNames_result, getTableNames_result._Fields>, java.io.Serializable, Cloneable, Comparable<getTableNames_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getTableNames_result"); private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.LIST, (short)0); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new getTableNames_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new getTableNames_resultTupleSchemeFactory()); } public List<ByteBuffer> success; // required public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { SUCCESS((short)0, "success"), IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 0: // SUCCESS return SUCCESS; case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.SUCCESS, new org.apache.thrift.meta_data.FieldMetaData("success", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(getTableNames_result.class, metaDataMap); } public getTableNames_result() { } public getTableNames_result( List<ByteBuffer> success, IOError io) { this(); this.success = success; this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public getTableNames_result(getTableNames_result other) { if (other.isSetSuccess()) { List<ByteBuffer> __this__success = new ArrayList<ByteBuffer>(other.success.size()); for (ByteBuffer other_element : other.success) { __this__success.add(other_element); } this.success = __this__success; } if (other.isSetIo()) { this.io = new IOError(other.io); } } public getTableNames_result deepCopy() { return new getTableNames_result(this); } @Override public void clear() { this.success = null; this.io = null; } public int getSuccessSize() { return (this.success == null) ? 0 : this.success.size(); } public java.util.Iterator<ByteBuffer> getSuccessIterator() { return (this.success == null) ? null : this.success.iterator(); } public void addToSuccess(ByteBuffer elem) { if (this.success == null) { this.success = new ArrayList<ByteBuffer>(); } this.success.add(elem); } public List<ByteBuffer> getSuccess() { return this.success; } public getTableNames_result setSuccess(List<ByteBuffer> success) { this.success = success; return this; } public void unsetSuccess() { this.success = null; } /** Returns true if field success is set (has been assigned a value) and false otherwise */ public boolean isSetSuccess() { return this.success != null; } public void setSuccessIsSet(boolean value) { if (!value) { this.success = null; } } public IOError getIo() { return this.io; } public getTableNames_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case SUCCESS: if (value == null) { unsetSuccess(); } else { setSuccess((List<ByteBuffer>)value); } break; case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case SUCCESS: return getSuccess(); case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case SUCCESS: return isSetSuccess(); case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof getTableNames_result) return this.equals((getTableNames_result)that); return false; } public boolean equals(getTableNames_result that) { if (that == null) return false; boolean this_present_success = true && this.isSetSuccess(); boolean that_present_success = true && that.isSetSuccess(); if (this_present_success || that_present_success) { if (!(this_present_success && that_present_success)) return false; if (!this.success.equals(that.success)) return false; } boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_success = true && (isSetSuccess()); list.add(present_success); if (present_success) list.add(success); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(getTableNames_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess()); if (lastComparison != 0) { return lastComparison; } if (isSetSuccess()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("getTableNames_result("); boolean first = true; sb.append("success:"); if (this.success == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.success, sb); } first = false; if (!first) sb.append(", "); sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class getTableNames_resultStandardSchemeFactory implements SchemeFactory { public getTableNames_resultStandardScheme getScheme() { return new getTableNames_resultStandardScheme(); } } private static class getTableNames_resultStandardScheme extends StandardScheme<getTableNames_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, getTableNames_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list50 = iprot.readListBegin(); struct.success = new ArrayList<ByteBuffer>(_list50.size); ByteBuffer _elem51; for (int _i52 = 0; _i52 < _list50.size; ++_i52) { _elem51 = iprot.readBinary(); struct.success.add(_elem51); } iprot.readListEnd(); } struct.setSuccessIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, getTableNames_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.success != null) { oprot.writeFieldBegin(SUCCESS_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.success.size())); for (ByteBuffer _iter53 : struct.success) { oprot.writeBinary(_iter53); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class getTableNames_resultTupleSchemeFactory implements SchemeFactory { public getTableNames_resultTupleScheme getScheme() { return new getTableNames_resultTupleScheme(); } } private static class getTableNames_resultTupleScheme extends TupleScheme<getTableNames_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, getTableNames_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetSuccess()) { optionals.set(0); } if (struct.isSetIo()) { optionals.set(1); } oprot.writeBitSet(optionals, 2); if (struct.isSetSuccess()) { { oprot.writeI32(struct.success.size()); for (ByteBuffer _iter54 : struct.success) { oprot.writeBinary(_iter54); } } } if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, getTableNames_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { { org.apache.thrift.protocol.TList _list55 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.success = new ArrayList<ByteBuffer>(_list55.size); ByteBuffer _elem56; for (int _i57 = 0; _i57 < _list55.size; ++_i57) { _elem56 = iprot.readBinary(); struct.success.add(_elem56); } } struct.setSuccessIsSet(true); } if (incoming.get(1)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class getColumnDescriptors_args implements org.apache.thrift.TBase<getColumnDescriptors_args, getColumnDescriptors_args._Fields>, java.io.Serializable, Cloneable, Comparable<getColumnDescriptors_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getColumnDescriptors_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new getColumnDescriptors_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new getColumnDescriptors_argsTupleSchemeFactory()); } /** * table name */ public ByteBuffer tableName; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * table name */ TABLE_NAME((short)1, "tableName"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(getColumnDescriptors_args.class, metaDataMap); } public getColumnDescriptors_args() { } public getColumnDescriptors_args( ByteBuffer tableName) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * Performs a deep copy on <i>other</i>. */ public getColumnDescriptors_args(getColumnDescriptors_args other) { if (other.isSetTableName()) { this.tableName = other.tableName; } } public getColumnDescriptors_args deepCopy() { return new getColumnDescriptors_args(this); } @Override public void clear() { this.tableName = null; } /** * table name */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * table name */ public getColumnDescriptors_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public getColumnDescriptors_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof getColumnDescriptors_args) return this.equals((getColumnDescriptors_args)that); return false; } public boolean equals(getColumnDescriptors_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); return list.hashCode(); } @Override public int compareTo(getColumnDescriptors_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("getColumnDescriptors_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class getColumnDescriptors_argsStandardSchemeFactory implements SchemeFactory { public getColumnDescriptors_argsStandardScheme getScheme() { return new getColumnDescriptors_argsStandardScheme(); } } private static class getColumnDescriptors_argsStandardScheme extends StandardScheme<getColumnDescriptors_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, getColumnDescriptors_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, getColumnDescriptors_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class getColumnDescriptors_argsTupleSchemeFactory implements SchemeFactory { public getColumnDescriptors_argsTupleScheme getScheme() { return new getColumnDescriptors_argsTupleScheme(); } } private static class getColumnDescriptors_argsTupleScheme extends TupleScheme<getColumnDescriptors_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, getColumnDescriptors_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } oprot.writeBitSet(optionals, 1); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, getColumnDescriptors_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(1); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } } } } public static class getColumnDescriptors_result implements org.apache.thrift.TBase<getColumnDescriptors_result, getColumnDescriptors_result._Fields>, java.io.Serializable, Cloneable, Comparable<getColumnDescriptors_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getColumnDescriptors_result"); private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.MAP, (short)0); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new getColumnDescriptors_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new getColumnDescriptors_resultTupleSchemeFactory()); } public Map<ByteBuffer,ColumnDescriptor> success; // required public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { SUCCESS((short)0, "success"), IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 0: // SUCCESS return SUCCESS; case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.SUCCESS, new org.apache.thrift.meta_data.FieldMetaData("success", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.MapMetaData(org.apache.thrift.protocol.TType.MAP, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"), new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, ColumnDescriptor.class)))); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(getColumnDescriptors_result.class, metaDataMap); } public getColumnDescriptors_result() { } public getColumnDescriptors_result( Map<ByteBuffer,ColumnDescriptor> success, IOError io) { this(); this.success = success; this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public getColumnDescriptors_result(getColumnDescriptors_result other) { if (other.isSetSuccess()) { Map<ByteBuffer,ColumnDescriptor> __this__success = new HashMap<ByteBuffer,ColumnDescriptor>(other.success.size()); for (Map.Entry<ByteBuffer, ColumnDescriptor> other_element : other.success.entrySet()) { ByteBuffer other_element_key = other_element.getKey(); ColumnDescriptor other_element_value = other_element.getValue(); ByteBuffer __this__success_copy_key = other_element_key; ColumnDescriptor __this__success_copy_value = new ColumnDescriptor(other_element_value); __this__success.put(__this__success_copy_key, __this__success_copy_value); } this.success = __this__success; } if (other.isSetIo()) { this.io = new IOError(other.io); } } public getColumnDescriptors_result deepCopy() { return new getColumnDescriptors_result(this); } @Override public void clear() { this.success = null; this.io = null; } public int getSuccessSize() { return (this.success == null) ? 0 : this.success.size(); } public void putToSuccess(ByteBuffer key, ColumnDescriptor val) { if (this.success == null) { this.success = new HashMap<ByteBuffer,ColumnDescriptor>(); } this.success.put(key, val); } public Map<ByteBuffer,ColumnDescriptor> getSuccess() { return this.success; } public getColumnDescriptors_result setSuccess(Map<ByteBuffer,ColumnDescriptor> success) { this.success = success; return this; } public void unsetSuccess() { this.success = null; } /** Returns true if field success is set (has been assigned a value) and false otherwise */ public boolean isSetSuccess() { return this.success != null; } public void setSuccessIsSet(boolean value) { if (!value) { this.success = null; } } public IOError getIo() { return this.io; } public getColumnDescriptors_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case SUCCESS: if (value == null) { unsetSuccess(); } else { setSuccess((Map<ByteBuffer,ColumnDescriptor>)value); } break; case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case SUCCESS: return getSuccess(); case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case SUCCESS: return isSetSuccess(); case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof getColumnDescriptors_result) return this.equals((getColumnDescriptors_result)that); return false; } public boolean equals(getColumnDescriptors_result that) { if (that == null) return false; boolean this_present_success = true && this.isSetSuccess(); boolean that_present_success = true && that.isSetSuccess(); if (this_present_success || that_present_success) { if (!(this_present_success && that_present_success)) return false; if (!this.success.equals(that.success)) return false; } boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_success = true && (isSetSuccess()); list.add(present_success); if (present_success) list.add(success); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(getColumnDescriptors_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess()); if (lastComparison != 0) { return lastComparison; } if (isSetSuccess()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("getColumnDescriptors_result("); boolean first = true; sb.append("success:"); if (this.success == null) { sb.append("null"); } else { sb.append(this.success); } first = false; if (!first) sb.append(", "); sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class getColumnDescriptors_resultStandardSchemeFactory implements SchemeFactory { public getColumnDescriptors_resultStandardScheme getScheme() { return new getColumnDescriptors_resultStandardScheme(); } } private static class getColumnDescriptors_resultStandardScheme extends StandardScheme<getColumnDescriptors_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, getColumnDescriptors_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.MAP) { { org.apache.thrift.protocol.TMap _map58 = iprot.readMapBegin(); struct.success = new HashMap<ByteBuffer,ColumnDescriptor>(2*_map58.size); ByteBuffer _key59; ColumnDescriptor _val60; for (int _i61 = 0; _i61 < _map58.size; ++_i61) { _key59 = iprot.readBinary(); _val60 = new ColumnDescriptor(); _val60.read(iprot); struct.success.put(_key59, _val60); } iprot.readMapEnd(); } struct.setSuccessIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, getColumnDescriptors_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.success != null) { oprot.writeFieldBegin(SUCCESS_FIELD_DESC); { oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRUCT, struct.success.size())); for (Map.Entry<ByteBuffer, ColumnDescriptor> _iter62 : struct.success.entrySet()) { oprot.writeBinary(_iter62.getKey()); _iter62.getValue().write(oprot); } oprot.writeMapEnd(); } oprot.writeFieldEnd(); } if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class getColumnDescriptors_resultTupleSchemeFactory implements SchemeFactory { public getColumnDescriptors_resultTupleScheme getScheme() { return new getColumnDescriptors_resultTupleScheme(); } } private static class getColumnDescriptors_resultTupleScheme extends TupleScheme<getColumnDescriptors_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, getColumnDescriptors_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetSuccess()) { optionals.set(0); } if (struct.isSetIo()) { optionals.set(1); } oprot.writeBitSet(optionals, 2); if (struct.isSetSuccess()) { { oprot.writeI32(struct.success.size()); for (Map.Entry<ByteBuffer, ColumnDescriptor> _iter63 : struct.success.entrySet()) { oprot.writeBinary(_iter63.getKey()); _iter63.getValue().write(oprot); } } } if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, getColumnDescriptors_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { { org.apache.thrift.protocol.TMap _map64 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRUCT, iprot.readI32()); struct.success = new HashMap<ByteBuffer,ColumnDescriptor>(2*_map64.size); ByteBuffer _key65; ColumnDescriptor _val66; for (int _i67 = 0; _i67 < _map64.size; ++_i67) { _key65 = iprot.readBinary(); _val66 = new ColumnDescriptor(); _val66.read(iprot); struct.success.put(_key65, _val66); } } struct.setSuccessIsSet(true); } if (incoming.get(1)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class getTableRegions_args implements org.apache.thrift.TBase<getTableRegions_args, getTableRegions_args._Fields>, java.io.Serializable, Cloneable, Comparable<getTableRegions_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getTableRegions_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new getTableRegions_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new getTableRegions_argsTupleSchemeFactory()); } /** * table name */ public ByteBuffer tableName; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * table name */ TABLE_NAME((short)1, "tableName"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(getTableRegions_args.class, metaDataMap); } public getTableRegions_args() { } public getTableRegions_args( ByteBuffer tableName) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * Performs a deep copy on <i>other</i>. */ public getTableRegions_args(getTableRegions_args other) { if (other.isSetTableName()) { this.tableName = other.tableName; } } public getTableRegions_args deepCopy() { return new getTableRegions_args(this); } @Override public void clear() { this.tableName = null; } /** * table name */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * table name */ public getTableRegions_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public getTableRegions_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof getTableRegions_args) return this.equals((getTableRegions_args)that); return false; } public boolean equals(getTableRegions_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); return list.hashCode(); } @Override public int compareTo(getTableRegions_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("getTableRegions_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class getTableRegions_argsStandardSchemeFactory implements SchemeFactory { public getTableRegions_argsStandardScheme getScheme() { return new getTableRegions_argsStandardScheme(); } } private static class getTableRegions_argsStandardScheme extends StandardScheme<getTableRegions_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, getTableRegions_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, getTableRegions_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class getTableRegions_argsTupleSchemeFactory implements SchemeFactory { public getTableRegions_argsTupleScheme getScheme() { return new getTableRegions_argsTupleScheme(); } } private static class getTableRegions_argsTupleScheme extends TupleScheme<getTableRegions_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, getTableRegions_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } oprot.writeBitSet(optionals, 1); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, getTableRegions_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(1); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } } } } public static class getTableRegions_result implements org.apache.thrift.TBase<getTableRegions_result, getTableRegions_result._Fields>, java.io.Serializable, Cloneable, Comparable<getTableRegions_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getTableRegions_result"); private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.LIST, (short)0); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new getTableRegions_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new getTableRegions_resultTupleSchemeFactory()); } public List<TRegionInfo> success; // required public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { SUCCESS((short)0, "success"), IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 0: // SUCCESS return SUCCESS; case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.SUCCESS, new org.apache.thrift.meta_data.FieldMetaData("success", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, TRegionInfo.class)))); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(getTableRegions_result.class, metaDataMap); } public getTableRegions_result() { } public getTableRegions_result( List<TRegionInfo> success, IOError io) { this(); this.success = success; this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public getTableRegions_result(getTableRegions_result other) { if (other.isSetSuccess()) { List<TRegionInfo> __this__success = new ArrayList<TRegionInfo>(other.success.size()); for (TRegionInfo other_element : other.success) { __this__success.add(new TRegionInfo(other_element)); } this.success = __this__success; } if (other.isSetIo()) { this.io = new IOError(other.io); } } public getTableRegions_result deepCopy() { return new getTableRegions_result(this); } @Override public void clear() { this.success = null; this.io = null; } public int getSuccessSize() { return (this.success == null) ? 0 : this.success.size(); } public java.util.Iterator<TRegionInfo> getSuccessIterator() { return (this.success == null) ? null : this.success.iterator(); } public void addToSuccess(TRegionInfo elem) { if (this.success == null) { this.success = new ArrayList<TRegionInfo>(); } this.success.add(elem); } public List<TRegionInfo> getSuccess() { return this.success; } public getTableRegions_result setSuccess(List<TRegionInfo> success) { this.success = success; return this; } public void unsetSuccess() { this.success = null; } /** Returns true if field success is set (has been assigned a value) and false otherwise */ public boolean isSetSuccess() { return this.success != null; } public void setSuccessIsSet(boolean value) { if (!value) { this.success = null; } } public IOError getIo() { return this.io; } public getTableRegions_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case SUCCESS: if (value == null) { unsetSuccess(); } else { setSuccess((List<TRegionInfo>)value); } break; case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case SUCCESS: return getSuccess(); case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case SUCCESS: return isSetSuccess(); case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof getTableRegions_result) return this.equals((getTableRegions_result)that); return false; } public boolean equals(getTableRegions_result that) { if (that == null) return false; boolean this_present_success = true && this.isSetSuccess(); boolean that_present_success = true && that.isSetSuccess(); if (this_present_success || that_present_success) { if (!(this_present_success && that_present_success)) return false; if (!this.success.equals(that.success)) return false; } boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_success = true && (isSetSuccess()); list.add(present_success); if (present_success) list.add(success); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(getTableRegions_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess()); if (lastComparison != 0) { return lastComparison; } if (isSetSuccess()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("getTableRegions_result("); boolean first = true; sb.append("success:"); if (this.success == null) { sb.append("null"); } else { sb.append(this.success); } first = false; if (!first) sb.append(", "); sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class getTableRegions_resultStandardSchemeFactory implements SchemeFactory { public getTableRegions_resultStandardScheme getScheme() { return new getTableRegions_resultStandardScheme(); } } private static class getTableRegions_resultStandardScheme extends StandardScheme<getTableRegions_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, getTableRegions_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list68 = iprot.readListBegin(); struct.success = new ArrayList<TRegionInfo>(_list68.size); TRegionInfo _elem69; for (int _i70 = 0; _i70 < _list68.size; ++_i70) { _elem69 = new TRegionInfo(); _elem69.read(iprot); struct.success.add(_elem69); } iprot.readListEnd(); } struct.setSuccessIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, getTableRegions_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.success != null) { oprot.writeFieldBegin(SUCCESS_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size())); for (TRegionInfo _iter71 : struct.success) { _iter71.write(oprot); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class getTableRegions_resultTupleSchemeFactory implements SchemeFactory { public getTableRegions_resultTupleScheme getScheme() { return new getTableRegions_resultTupleScheme(); } } private static class getTableRegions_resultTupleScheme extends TupleScheme<getTableRegions_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, getTableRegions_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetSuccess()) { optionals.set(0); } if (struct.isSetIo()) { optionals.set(1); } oprot.writeBitSet(optionals, 2); if (struct.isSetSuccess()) { { oprot.writeI32(struct.success.size()); for (TRegionInfo _iter72 : struct.success) { _iter72.write(oprot); } } } if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, getTableRegions_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { { org.apache.thrift.protocol.TList _list73 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32()); struct.success = new ArrayList<TRegionInfo>(_list73.size); TRegionInfo _elem74; for (int _i75 = 0; _i75 < _list73.size; ++_i75) { _elem74 = new TRegionInfo(); _elem74.read(iprot); struct.success.add(_elem74); } } struct.setSuccessIsSet(true); } if (incoming.get(1)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class createTable_args implements org.apache.thrift.TBase<createTable_args, createTable_args._Fields>, java.io.Serializable, Cloneable, Comparable<createTable_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("createTable_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final org.apache.thrift.protocol.TField COLUMN_FAMILIES_FIELD_DESC = new org.apache.thrift.protocol.TField("columnFamilies", org.apache.thrift.protocol.TType.LIST, (short)2); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new createTable_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new createTable_argsTupleSchemeFactory()); } /** * name of table to create */ public ByteBuffer tableName; // required /** * list of column family descriptors */ public List<ColumnDescriptor> columnFamilies; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * name of table to create */ TABLE_NAME((short)1, "tableName"), /** * list of column family descriptors */ COLUMN_FAMILIES((short)2, "columnFamilies"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; case 2: // COLUMN_FAMILIES return COLUMN_FAMILIES; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.COLUMN_FAMILIES, new org.apache.thrift.meta_data.FieldMetaData("columnFamilies", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, ColumnDescriptor.class)))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(createTable_args.class, metaDataMap); } public createTable_args() { } public createTable_args( ByteBuffer tableName, List<ColumnDescriptor> columnFamilies) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); this.columnFamilies = columnFamilies; } /** * Performs a deep copy on <i>other</i>. */ public createTable_args(createTable_args other) { if (other.isSetTableName()) { this.tableName = other.tableName; } if (other.isSetColumnFamilies()) { List<ColumnDescriptor> __this__columnFamilies = new ArrayList<ColumnDescriptor>(other.columnFamilies.size()); for (ColumnDescriptor other_element : other.columnFamilies) { __this__columnFamilies.add(new ColumnDescriptor(other_element)); } this.columnFamilies = __this__columnFamilies; } } public createTable_args deepCopy() { return new createTable_args(this); } @Override public void clear() { this.tableName = null; this.columnFamilies = null; } /** * name of table to create */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * name of table to create */ public createTable_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public createTable_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } public int getColumnFamiliesSize() { return (this.columnFamilies == null) ? 0 : this.columnFamilies.size(); } public java.util.Iterator<ColumnDescriptor> getColumnFamiliesIterator() { return (this.columnFamilies == null) ? null : this.columnFamilies.iterator(); } public void addToColumnFamilies(ColumnDescriptor elem) { if (this.columnFamilies == null) { this.columnFamilies = new ArrayList<ColumnDescriptor>(); } this.columnFamilies.add(elem); } /** * list of column family descriptors */ public List<ColumnDescriptor> getColumnFamilies() { return this.columnFamilies; } /** * list of column family descriptors */ public createTable_args setColumnFamilies(List<ColumnDescriptor> columnFamilies) { this.columnFamilies = columnFamilies; return this; } public void unsetColumnFamilies() { this.columnFamilies = null; } /** Returns true if field columnFamilies is set (has been assigned a value) and false otherwise */ public boolean isSetColumnFamilies() { return this.columnFamilies != null; } public void setColumnFamiliesIsSet(boolean value) { if (!value) { this.columnFamilies = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; case COLUMN_FAMILIES: if (value == null) { unsetColumnFamilies(); } else { setColumnFamilies((List<ColumnDescriptor>)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); case COLUMN_FAMILIES: return getColumnFamilies(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); case COLUMN_FAMILIES: return isSetColumnFamilies(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof createTable_args) return this.equals((createTable_args)that); return false; } public boolean equals(createTable_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } boolean this_present_columnFamilies = true && this.isSetColumnFamilies(); boolean that_present_columnFamilies = true && that.isSetColumnFamilies(); if (this_present_columnFamilies || that_present_columnFamilies) { if (!(this_present_columnFamilies && that_present_columnFamilies)) return false; if (!this.columnFamilies.equals(that.columnFamilies)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); boolean present_columnFamilies = true && (isSetColumnFamilies()); list.add(present_columnFamilies); if (present_columnFamilies) list.add(columnFamilies); return list.hashCode(); } @Override public int compareTo(createTable_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetColumnFamilies()).compareTo(other.isSetColumnFamilies()); if (lastComparison != 0) { return lastComparison; } if (isSetColumnFamilies()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.columnFamilies, other.columnFamilies); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("createTable_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; if (!first) sb.append(", "); sb.append("columnFamilies:"); if (this.columnFamilies == null) { sb.append("null"); } else { sb.append(this.columnFamilies); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class createTable_argsStandardSchemeFactory implements SchemeFactory { public createTable_argsStandardScheme getScheme() { return new createTable_argsStandardScheme(); } } private static class createTable_argsStandardScheme extends StandardScheme<createTable_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, createTable_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // COLUMN_FAMILIES if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list76 = iprot.readListBegin(); struct.columnFamilies = new ArrayList<ColumnDescriptor>(_list76.size); ColumnDescriptor _elem77; for (int _i78 = 0; _i78 < _list76.size; ++_i78) { _elem77 = new ColumnDescriptor(); _elem77.read(iprot); struct.columnFamilies.add(_elem77); } iprot.readListEnd(); } struct.setColumnFamiliesIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, createTable_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } if (struct.columnFamilies != null) { oprot.writeFieldBegin(COLUMN_FAMILIES_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.columnFamilies.size())); for (ColumnDescriptor _iter79 : struct.columnFamilies) { _iter79.write(oprot); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class createTable_argsTupleSchemeFactory implements SchemeFactory { public createTable_argsTupleScheme getScheme() { return new createTable_argsTupleScheme(); } } private static class createTable_argsTupleScheme extends TupleScheme<createTable_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, createTable_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } if (struct.isSetColumnFamilies()) { optionals.set(1); } oprot.writeBitSet(optionals, 2); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } if (struct.isSetColumnFamilies()) { { oprot.writeI32(struct.columnFamilies.size()); for (ColumnDescriptor _iter80 : struct.columnFamilies) { _iter80.write(oprot); } } } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, createTable_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } if (incoming.get(1)) { { org.apache.thrift.protocol.TList _list81 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32()); struct.columnFamilies = new ArrayList<ColumnDescriptor>(_list81.size); ColumnDescriptor _elem82; for (int _i83 = 0; _i83 < _list81.size; ++_i83) { _elem82 = new ColumnDescriptor(); _elem82.read(iprot); struct.columnFamilies.add(_elem82); } } struct.setColumnFamiliesIsSet(true); } } } } public static class createTable_result implements org.apache.thrift.TBase<createTable_result, createTable_result._Fields>, java.io.Serializable, Cloneable, Comparable<createTable_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("createTable_result"); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final org.apache.thrift.protocol.TField IA_FIELD_DESC = new org.apache.thrift.protocol.TField("ia", org.apache.thrift.protocol.TType.STRUCT, (short)2); private static final org.apache.thrift.protocol.TField EXIST_FIELD_DESC = new org.apache.thrift.protocol.TField("exist", org.apache.thrift.protocol.TType.STRUCT, (short)3); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new createTable_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new createTable_resultTupleSchemeFactory()); } public IOError io; // required public IllegalArgument ia; // required public AlreadyExists exist; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { IO((short)1, "io"), IA((short)2, "ia"), EXIST((short)3, "exist"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // IO return IO; case 2: // IA return IA; case 3: // EXIST return EXIST; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); tmpMap.put(_Fields.IA, new org.apache.thrift.meta_data.FieldMetaData("ia", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); tmpMap.put(_Fields.EXIST, new org.apache.thrift.meta_data.FieldMetaData("exist", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(createTable_result.class, metaDataMap); } public createTable_result() { } public createTable_result( IOError io, IllegalArgument ia, AlreadyExists exist) { this(); this.io = io; this.ia = ia; this.exist = exist; } /** * Performs a deep copy on <i>other</i>. */ public createTable_result(createTable_result other) { if (other.isSetIo()) { this.io = new IOError(other.io); } if (other.isSetIa()) { this.ia = new IllegalArgument(other.ia); } if (other.isSetExist()) { this.exist = new AlreadyExists(other.exist); } } public createTable_result deepCopy() { return new createTable_result(this); } @Override public void clear() { this.io = null; this.ia = null; this.exist = null; } public IOError getIo() { return this.io; } public createTable_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public IllegalArgument getIa() { return this.ia; } public createTable_result setIa(IllegalArgument ia) { this.ia = ia; return this; } public void unsetIa() { this.ia = null; } /** Returns true if field ia is set (has been assigned a value) and false otherwise */ public boolean isSetIa() { return this.ia != null; } public void setIaIsSet(boolean value) { if (!value) { this.ia = null; } } public AlreadyExists getExist() { return this.exist; } public createTable_result setExist(AlreadyExists exist) { this.exist = exist; return this; } public void unsetExist() { this.exist = null; } /** Returns true if field exist is set (has been assigned a value) and false otherwise */ public boolean isSetExist() { return this.exist != null; } public void setExistIsSet(boolean value) { if (!value) { this.exist = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; case IA: if (value == null) { unsetIa(); } else { setIa((IllegalArgument)value); } break; case EXIST: if (value == null) { unsetExist(); } else { setExist((AlreadyExists)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case IO: return getIo(); case IA: return getIa(); case EXIST: return getExist(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case IO: return isSetIo(); case IA: return isSetIa(); case EXIST: return isSetExist(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof createTable_result) return this.equals((createTable_result)that); return false; } public boolean equals(createTable_result that) { if (that == null) return false; boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } boolean this_present_ia = true && this.isSetIa(); boolean that_present_ia = true && that.isSetIa(); if (this_present_ia || that_present_ia) { if (!(this_present_ia && that_present_ia)) return false; if (!this.ia.equals(that.ia)) return false; } boolean this_present_exist = true && this.isSetExist(); boolean that_present_exist = true && that.isSetExist(); if (this_present_exist || that_present_exist) { if (!(this_present_exist && that_present_exist)) return false; if (!this.exist.equals(that.exist)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); boolean present_ia = true && (isSetIa()); list.add(present_ia); if (present_ia) list.add(ia); boolean present_exist = true && (isSetExist()); list.add(present_exist); if (present_exist) list.add(exist); return list.hashCode(); } @Override public int compareTo(createTable_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIa()).compareTo(other.isSetIa()); if (lastComparison != 0) { return lastComparison; } if (isSetIa()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ia, other.ia); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetExist()).compareTo(other.isSetExist()); if (lastComparison != 0) { return lastComparison; } if (isSetExist()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.exist, other.exist); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("createTable_result("); boolean first = true; sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; if (!first) sb.append(", "); sb.append("ia:"); if (this.ia == null) { sb.append("null"); } else { sb.append(this.ia); } first = false; if (!first) sb.append(", "); sb.append("exist:"); if (this.exist == null) { sb.append("null"); } else { sb.append(this.exist); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class createTable_resultStandardSchemeFactory implements SchemeFactory { public createTable_resultStandardScheme getScheme() { return new createTable_resultStandardScheme(); } } private static class createTable_resultStandardScheme extends StandardScheme<createTable_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, createTable_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // IA if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.ia = new IllegalArgument(); struct.ia.read(iprot); struct.setIaIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 3: // EXIST if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.exist = new AlreadyExists(); struct.exist.read(iprot); struct.setExistIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, createTable_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } if (struct.ia != null) { oprot.writeFieldBegin(IA_FIELD_DESC); struct.ia.write(oprot); oprot.writeFieldEnd(); } if (struct.exist != null) { oprot.writeFieldBegin(EXIST_FIELD_DESC); struct.exist.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class createTable_resultTupleSchemeFactory implements SchemeFactory { public createTable_resultTupleScheme getScheme() { return new createTable_resultTupleScheme(); } } private static class createTable_resultTupleScheme extends TupleScheme<createTable_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, createTable_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetIo()) { optionals.set(0); } if (struct.isSetIa()) { optionals.set(1); } if (struct.isSetExist()) { optionals.set(2); } oprot.writeBitSet(optionals, 3); if (struct.isSetIo()) { struct.io.write(oprot); } if (struct.isSetIa()) { struct.ia.write(oprot); } if (struct.isSetExist()) { struct.exist.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, createTable_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(3); if (incoming.get(0)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } if (incoming.get(1)) { struct.ia = new IllegalArgument(); struct.ia.read(iprot); struct.setIaIsSet(true); } if (incoming.get(2)) { struct.exist = new AlreadyExists(); struct.exist.read(iprot); struct.setExistIsSet(true); } } } } public static class deleteTable_args implements org.apache.thrift.TBase<deleteTable_args, deleteTable_args._Fields>, java.io.Serializable, Cloneable, Comparable<deleteTable_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("deleteTable_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new deleteTable_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new deleteTable_argsTupleSchemeFactory()); } /** * name of table to delete */ public ByteBuffer tableName; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * name of table to delete */ TABLE_NAME((short)1, "tableName"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(deleteTable_args.class, metaDataMap); } public deleteTable_args() { } public deleteTable_args( ByteBuffer tableName) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * Performs a deep copy on <i>other</i>. */ public deleteTable_args(deleteTable_args other) { if (other.isSetTableName()) { this.tableName = other.tableName; } } public deleteTable_args deepCopy() { return new deleteTable_args(this); } @Override public void clear() { this.tableName = null; } /** * name of table to delete */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * name of table to delete */ public deleteTable_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public deleteTable_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof deleteTable_args) return this.equals((deleteTable_args)that); return false; } public boolean equals(deleteTable_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); return list.hashCode(); } @Override public int compareTo(deleteTable_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("deleteTable_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class deleteTable_argsStandardSchemeFactory implements SchemeFactory { public deleteTable_argsStandardScheme getScheme() { return new deleteTable_argsStandardScheme(); } } private static class deleteTable_argsStandardScheme extends StandardScheme<deleteTable_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, deleteTable_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, deleteTable_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class deleteTable_argsTupleSchemeFactory implements SchemeFactory { public deleteTable_argsTupleScheme getScheme() { return new deleteTable_argsTupleScheme(); } } private static class deleteTable_argsTupleScheme extends TupleScheme<deleteTable_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, deleteTable_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } oprot.writeBitSet(optionals, 1); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, deleteTable_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(1); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } } } } public static class deleteTable_result implements org.apache.thrift.TBase<deleteTable_result, deleteTable_result._Fields>, java.io.Serializable, Cloneable, Comparable<deleteTable_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("deleteTable_result"); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new deleteTable_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new deleteTable_resultTupleSchemeFactory()); } public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(deleteTable_result.class, metaDataMap); } public deleteTable_result() { } public deleteTable_result( IOError io) { this(); this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public deleteTable_result(deleteTable_result other) { if (other.isSetIo()) { this.io = new IOError(other.io); } } public deleteTable_result deepCopy() { return new deleteTable_result(this); } @Override public void clear() { this.io = null; } public IOError getIo() { return this.io; } public deleteTable_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof deleteTable_result) return this.equals((deleteTable_result)that); return false; } public boolean equals(deleteTable_result that) { if (that == null) return false; boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(deleteTable_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("deleteTable_result("); boolean first = true; sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class deleteTable_resultStandardSchemeFactory implements SchemeFactory { public deleteTable_resultStandardScheme getScheme() { return new deleteTable_resultStandardScheme(); } } private static class deleteTable_resultStandardScheme extends StandardScheme<deleteTable_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, deleteTable_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, deleteTable_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class deleteTable_resultTupleSchemeFactory implements SchemeFactory { public deleteTable_resultTupleScheme getScheme() { return new deleteTable_resultTupleScheme(); } } private static class deleteTable_resultTupleScheme extends TupleScheme<deleteTable_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, deleteTable_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetIo()) { optionals.set(0); } oprot.writeBitSet(optionals, 1); if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, deleteTable_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(1); if (incoming.get(0)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class get_args implements org.apache.thrift.TBase<get_args, get_args._Fields>, java.io.Serializable, Cloneable, Comparable<get_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("get_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final org.apache.thrift.protocol.TField ROW_FIELD_DESC = new org.apache.thrift.protocol.TField("row", org.apache.thrift.protocol.TType.STRING, (short)2); private static final org.apache.thrift.protocol.TField COLUMN_FIELD_DESC = new org.apache.thrift.protocol.TField("column", org.apache.thrift.protocol.TType.STRING, (short)3); private static final org.apache.thrift.protocol.TField ATTRIBUTES_FIELD_DESC = new org.apache.thrift.protocol.TField("attributes", org.apache.thrift.protocol.TType.MAP, (short)4); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new get_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new get_argsTupleSchemeFactory()); } /** * name of table */ public ByteBuffer tableName; // required /** * row key */ public ByteBuffer row; // required /** * column name */ public ByteBuffer column; // required /** * Get attributes */ public Map<ByteBuffer,ByteBuffer> attributes; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * name of table */ TABLE_NAME((short)1, "tableName"), /** * row key */ ROW((short)2, "row"), /** * column name */ COLUMN((short)3, "column"), /** * Get attributes */ ATTRIBUTES((short)4, "attributes"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; case 2: // ROW return ROW; case 3: // COLUMN return COLUMN; case 4: // ATTRIBUTES return ATTRIBUTES; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.ROW, new org.apache.thrift.meta_data.FieldMetaData("row", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.COLUMN, new org.apache.thrift.meta_data.FieldMetaData("column", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.ATTRIBUTES, new org.apache.thrift.meta_data.FieldMetaData("attributes", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.MapMetaData(org.apache.thrift.protocol.TType.MAP, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"), new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(get_args.class, metaDataMap); } public get_args() { } public get_args( ByteBuffer tableName, ByteBuffer row, ByteBuffer column, Map<ByteBuffer,ByteBuffer> attributes) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); this.row = org.apache.thrift.TBaseHelper.copyBinary(row); this.column = org.apache.thrift.TBaseHelper.copyBinary(column); this.attributes = attributes; } /** * Performs a deep copy on <i>other</i>. */ public get_args(get_args other) { if (other.isSetTableName()) { this.tableName = other.tableName; } if (other.isSetRow()) { this.row = other.row; } if (other.isSetColumn()) { this.column = other.column; } if (other.isSetAttributes()) { Map<ByteBuffer,ByteBuffer> __this__attributes = new HashMap<ByteBuffer,ByteBuffer>(other.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> other_element : other.attributes.entrySet()) { ByteBuffer other_element_key = other_element.getKey(); ByteBuffer other_element_value = other_element.getValue(); ByteBuffer __this__attributes_copy_key = other_element_key; ByteBuffer __this__attributes_copy_value = other_element_value; __this__attributes.put(__this__attributes_copy_key, __this__attributes_copy_value); } this.attributes = __this__attributes; } } public get_args deepCopy() { return new get_args(this); } @Override public void clear() { this.tableName = null; this.row = null; this.column = null; this.attributes = null; } /** * name of table */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * name of table */ public get_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public get_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } /** * row key */ public byte[] getRow() { setRow(org.apache.thrift.TBaseHelper.rightSize(row)); return row == null ? null : row.array(); } public ByteBuffer bufferForRow() { return org.apache.thrift.TBaseHelper.copyBinary(row); } /** * row key */ public get_args setRow(byte[] row) { this.row = row == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(row, row.length)); return this; } public get_args setRow(ByteBuffer row) { this.row = org.apache.thrift.TBaseHelper.copyBinary(row); return this; } public void unsetRow() { this.row = null; } /** Returns true if field row is set (has been assigned a value) and false otherwise */ public boolean isSetRow() { return this.row != null; } public void setRowIsSet(boolean value) { if (!value) { this.row = null; } } /** * column name */ public byte[] getColumn() { setColumn(org.apache.thrift.TBaseHelper.rightSize(column)); return column == null ? null : column.array(); } public ByteBuffer bufferForColumn() { return org.apache.thrift.TBaseHelper.copyBinary(column); } /** * column name */ public get_args setColumn(byte[] column) { this.column = column == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(column, column.length)); return this; } public get_args setColumn(ByteBuffer column) { this.column = org.apache.thrift.TBaseHelper.copyBinary(column); return this; } public void unsetColumn() { this.column = null; } /** Returns true if field column is set (has been assigned a value) and false otherwise */ public boolean isSetColumn() { return this.column != null; } public void setColumnIsSet(boolean value) { if (!value) { this.column = null; } } public int getAttributesSize() { return (this.attributes == null) ? 0 : this.attributes.size(); } public void putToAttributes(ByteBuffer key, ByteBuffer val) { if (this.attributes == null) { this.attributes = new HashMap<ByteBuffer,ByteBuffer>(); } this.attributes.put(key, val); } /** * Get attributes */ public Map<ByteBuffer,ByteBuffer> getAttributes() { return this.attributes; } /** * Get attributes */ public get_args setAttributes(Map<ByteBuffer,ByteBuffer> attributes) { this.attributes = attributes; return this; } public void unsetAttributes() { this.attributes = null; } /** Returns true if field attributes is set (has been assigned a value) and false otherwise */ public boolean isSetAttributes() { return this.attributes != null; } public void setAttributesIsSet(boolean value) { if (!value) { this.attributes = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; case ROW: if (value == null) { unsetRow(); } else { setRow((ByteBuffer)value); } break; case COLUMN: if (value == null) { unsetColumn(); } else { setColumn((ByteBuffer)value); } break; case ATTRIBUTES: if (value == null) { unsetAttributes(); } else { setAttributes((Map<ByteBuffer,ByteBuffer>)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); case ROW: return getRow(); case COLUMN: return getColumn(); case ATTRIBUTES: return getAttributes(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); case ROW: return isSetRow(); case COLUMN: return isSetColumn(); case ATTRIBUTES: return isSetAttributes(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof get_args) return this.equals((get_args)that); return false; } public boolean equals(get_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } boolean this_present_row = true && this.isSetRow(); boolean that_present_row = true && that.isSetRow(); if (this_present_row || that_present_row) { if (!(this_present_row && that_present_row)) return false; if (!this.row.equals(that.row)) return false; } boolean this_present_column = true && this.isSetColumn(); boolean that_present_column = true && that.isSetColumn(); if (this_present_column || that_present_column) { if (!(this_present_column && that_present_column)) return false; if (!this.column.equals(that.column)) return false; } boolean this_present_attributes = true && this.isSetAttributes(); boolean that_present_attributes = true && that.isSetAttributes(); if (this_present_attributes || that_present_attributes) { if (!(this_present_attributes && that_present_attributes)) return false; if (!this.attributes.equals(that.attributes)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); boolean present_row = true && (isSetRow()); list.add(present_row); if (present_row) list.add(row); boolean present_column = true && (isSetColumn()); list.add(present_column); if (present_column) list.add(column); boolean present_attributes = true && (isSetAttributes()); list.add(present_attributes); if (present_attributes) list.add(attributes); return list.hashCode(); } @Override public int compareTo(get_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetRow()).compareTo(other.isSetRow()); if (lastComparison != 0) { return lastComparison; } if (isSetRow()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.row, other.row); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetColumn()).compareTo(other.isSetColumn()); if (lastComparison != 0) { return lastComparison; } if (isSetColumn()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.column, other.column); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetAttributes()).compareTo(other.isSetAttributes()); if (lastComparison != 0) { return lastComparison; } if (isSetAttributes()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.attributes, other.attributes); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("get_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; if (!first) sb.append(", "); sb.append("row:"); if (this.row == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.row, sb); } first = false; if (!first) sb.append(", "); sb.append("column:"); if (this.column == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.column, sb); } first = false; if (!first) sb.append(", "); sb.append("attributes:"); if (this.attributes == null) { sb.append("null"); } else { sb.append(this.attributes); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class get_argsStandardSchemeFactory implements SchemeFactory { public get_argsStandardScheme getScheme() { return new get_argsStandardScheme(); } } private static class get_argsStandardScheme extends StandardScheme<get_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, get_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // ROW if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.row = iprot.readBinary(); struct.setRowIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 3: // COLUMN if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.column = iprot.readBinary(); struct.setColumnIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 4: // ATTRIBUTES if (schemeField.type == org.apache.thrift.protocol.TType.MAP) { { org.apache.thrift.protocol.TMap _map84 = iprot.readMapBegin(); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map84.size); ByteBuffer _key85; ByteBuffer _val86; for (int _i87 = 0; _i87 < _map84.size; ++_i87) { _key85 = iprot.readBinary(); _val86 = iprot.readBinary(); struct.attributes.put(_key85, _val86); } iprot.readMapEnd(); } struct.setAttributesIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, get_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } if (struct.row != null) { oprot.writeFieldBegin(ROW_FIELD_DESC); oprot.writeBinary(struct.row); oprot.writeFieldEnd(); } if (struct.column != null) { oprot.writeFieldBegin(COLUMN_FIELD_DESC); oprot.writeBinary(struct.column); oprot.writeFieldEnd(); } if (struct.attributes != null) { oprot.writeFieldBegin(ATTRIBUTES_FIELD_DESC); { oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, struct.attributes.size())); for (Map.Entry<ByteBuffer, ByteBuffer> _iter88 : struct.attributes.entrySet()) { oprot.writeBinary(_iter88.getKey()); oprot.writeBinary(_iter88.getValue()); } oprot.writeMapEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class get_argsTupleSchemeFactory implements SchemeFactory { public get_argsTupleScheme getScheme() { return new get_argsTupleScheme(); } } private static class get_argsTupleScheme extends TupleScheme<get_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, get_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } if (struct.isSetRow()) { optionals.set(1); } if (struct.isSetColumn()) { optionals.set(2); } if (struct.isSetAttributes()) { optionals.set(3); } oprot.writeBitSet(optionals, 4); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } if (struct.isSetRow()) { oprot.writeBinary(struct.row); } if (struct.isSetColumn()) { oprot.writeBinary(struct.column); } if (struct.isSetAttributes()) { { oprot.writeI32(struct.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> _iter89 : struct.attributes.entrySet()) { oprot.writeBinary(_iter89.getKey()); oprot.writeBinary(_iter89.getValue()); } } } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, get_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(4); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } if (incoming.get(1)) { struct.row = iprot.readBinary(); struct.setRowIsSet(true); } if (incoming.get(2)) { struct.column = iprot.readBinary(); struct.setColumnIsSet(true); } if (incoming.get(3)) { { org.apache.thrift.protocol.TMap _map90 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map90.size); ByteBuffer _key91; ByteBuffer _val92; for (int _i93 = 0; _i93 < _map90.size; ++_i93) { _key91 = iprot.readBinary(); _val92 = iprot.readBinary(); struct.attributes.put(_key91, _val92); } } struct.setAttributesIsSet(true); } } } } public static class get_result implements org.apache.thrift.TBase<get_result, get_result._Fields>, java.io.Serializable, Cloneable, Comparable<get_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("get_result"); private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.LIST, (short)0); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new get_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new get_resultTupleSchemeFactory()); } public List<TCell> success; // required public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { SUCCESS((short)0, "success"), IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 0: // SUCCESS return SUCCESS; case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.SUCCESS, new org.apache.thrift.meta_data.FieldMetaData("success", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, TCell.class)))); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(get_result.class, metaDataMap); } public get_result() { } public get_result( List<TCell> success, IOError io) { this(); this.success = success; this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public get_result(get_result other) { if (other.isSetSuccess()) { List<TCell> __this__success = new ArrayList<TCell>(other.success.size()); for (TCell other_element : other.success) { __this__success.add(new TCell(other_element)); } this.success = __this__success; } if (other.isSetIo()) { this.io = new IOError(other.io); } } public get_result deepCopy() { return new get_result(this); } @Override public void clear() { this.success = null; this.io = null; } public int getSuccessSize() { return (this.success == null) ? 0 : this.success.size(); } public java.util.Iterator<TCell> getSuccessIterator() { return (this.success == null) ? null : this.success.iterator(); } public void addToSuccess(TCell elem) { if (this.success == null) { this.success = new ArrayList<TCell>(); } this.success.add(elem); } public List<TCell> getSuccess() { return this.success; } public get_result setSuccess(List<TCell> success) { this.success = success; return this; } public void unsetSuccess() { this.success = null; } /** Returns true if field success is set (has been assigned a value) and false otherwise */ public boolean isSetSuccess() { return this.success != null; } public void setSuccessIsSet(boolean value) { if (!value) { this.success = null; } } public IOError getIo() { return this.io; } public get_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case SUCCESS: if (value == null) { unsetSuccess(); } else { setSuccess((List<TCell>)value); } break; case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case SUCCESS: return getSuccess(); case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case SUCCESS: return isSetSuccess(); case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof get_result) return this.equals((get_result)that); return false; } public boolean equals(get_result that) { if (that == null) return false; boolean this_present_success = true && this.isSetSuccess(); boolean that_present_success = true && that.isSetSuccess(); if (this_present_success || that_present_success) { if (!(this_present_success && that_present_success)) return false; if (!this.success.equals(that.success)) return false; } boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_success = true && (isSetSuccess()); list.add(present_success); if (present_success) list.add(success); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(get_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess()); if (lastComparison != 0) { return lastComparison; } if (isSetSuccess()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("get_result("); boolean first = true; sb.append("success:"); if (this.success == null) { sb.append("null"); } else { sb.append(this.success); } first = false; if (!first) sb.append(", "); sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class get_resultStandardSchemeFactory implements SchemeFactory { public get_resultStandardScheme getScheme() { return new get_resultStandardScheme(); } } private static class get_resultStandardScheme extends StandardScheme<get_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, get_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list94 = iprot.readListBegin(); struct.success = new ArrayList<TCell>(_list94.size); TCell _elem95; for (int _i96 = 0; _i96 < _list94.size; ++_i96) { _elem95 = new TCell(); _elem95.read(iprot); struct.success.add(_elem95); } iprot.readListEnd(); } struct.setSuccessIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, get_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.success != null) { oprot.writeFieldBegin(SUCCESS_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size())); for (TCell _iter97 : struct.success) { _iter97.write(oprot); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class get_resultTupleSchemeFactory implements SchemeFactory { public get_resultTupleScheme getScheme() { return new get_resultTupleScheme(); } } private static class get_resultTupleScheme extends TupleScheme<get_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, get_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetSuccess()) { optionals.set(0); } if (struct.isSetIo()) { optionals.set(1); } oprot.writeBitSet(optionals, 2); if (struct.isSetSuccess()) { { oprot.writeI32(struct.success.size()); for (TCell _iter98 : struct.success) { _iter98.write(oprot); } } } if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, get_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { { org.apache.thrift.protocol.TList _list99 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32()); struct.success = new ArrayList<TCell>(_list99.size); TCell _elem100; for (int _i101 = 0; _i101 < _list99.size; ++_i101) { _elem100 = new TCell(); _elem100.read(iprot); struct.success.add(_elem100); } } struct.setSuccessIsSet(true); } if (incoming.get(1)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class getVer_args implements org.apache.thrift.TBase<getVer_args, getVer_args._Fields>, java.io.Serializable, Cloneable, Comparable<getVer_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getVer_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final org.apache.thrift.protocol.TField ROW_FIELD_DESC = new org.apache.thrift.protocol.TField("row", org.apache.thrift.protocol.TType.STRING, (short)2); private static final org.apache.thrift.protocol.TField COLUMN_FIELD_DESC = new org.apache.thrift.protocol.TField("column", org.apache.thrift.protocol.TType.STRING, (short)3); private static final org.apache.thrift.protocol.TField NUM_VERSIONS_FIELD_DESC = new org.apache.thrift.protocol.TField("numVersions", org.apache.thrift.protocol.TType.I32, (short)4); private static final org.apache.thrift.protocol.TField ATTRIBUTES_FIELD_DESC = new org.apache.thrift.protocol.TField("attributes", org.apache.thrift.protocol.TType.MAP, (short)5); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new getVer_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new getVer_argsTupleSchemeFactory()); } /** * name of table */ public ByteBuffer tableName; // required /** * row key */ public ByteBuffer row; // required /** * column name */ public ByteBuffer column; // required /** * number of versions to retrieve */ public int numVersions; // required /** * Get attributes */ public Map<ByteBuffer,ByteBuffer> attributes; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * name of table */ TABLE_NAME((short)1, "tableName"), /** * row key */ ROW((short)2, "row"), /** * column name */ COLUMN((short)3, "column"), /** * number of versions to retrieve */ NUM_VERSIONS((short)4, "numVersions"), /** * Get attributes */ ATTRIBUTES((short)5, "attributes"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; case 2: // ROW return ROW; case 3: // COLUMN return COLUMN; case 4: // NUM_VERSIONS return NUM_VERSIONS; case 5: // ATTRIBUTES return ATTRIBUTES; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments private static final int __NUMVERSIONS_ISSET_ID = 0; private byte __isset_bitfield = 0; public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.ROW, new org.apache.thrift.meta_data.FieldMetaData("row", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.COLUMN, new org.apache.thrift.meta_data.FieldMetaData("column", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.NUM_VERSIONS, new org.apache.thrift.meta_data.FieldMetaData("numVersions", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.I32))); tmpMap.put(_Fields.ATTRIBUTES, new org.apache.thrift.meta_data.FieldMetaData("attributes", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.MapMetaData(org.apache.thrift.protocol.TType.MAP, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"), new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(getVer_args.class, metaDataMap); } public getVer_args() { } public getVer_args( ByteBuffer tableName, ByteBuffer row, ByteBuffer column, int numVersions, Map<ByteBuffer,ByteBuffer> attributes) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); this.row = org.apache.thrift.TBaseHelper.copyBinary(row); this.column = org.apache.thrift.TBaseHelper.copyBinary(column); this.numVersions = numVersions; setNumVersionsIsSet(true); this.attributes = attributes; } /** * Performs a deep copy on <i>other</i>. */ public getVer_args(getVer_args other) { __isset_bitfield = other.__isset_bitfield; if (other.isSetTableName()) { this.tableName = other.tableName; } if (other.isSetRow()) { this.row = other.row; } if (other.isSetColumn()) { this.column = other.column; } this.numVersions = other.numVersions; if (other.isSetAttributes()) { Map<ByteBuffer,ByteBuffer> __this__attributes = new HashMap<ByteBuffer,ByteBuffer>(other.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> other_element : other.attributes.entrySet()) { ByteBuffer other_element_key = other_element.getKey(); ByteBuffer other_element_value = other_element.getValue(); ByteBuffer __this__attributes_copy_key = other_element_key; ByteBuffer __this__attributes_copy_value = other_element_value; __this__attributes.put(__this__attributes_copy_key, __this__attributes_copy_value); } this.attributes = __this__attributes; } } public getVer_args deepCopy() { return new getVer_args(this); } @Override public void clear() { this.tableName = null; this.row = null; this.column = null; setNumVersionsIsSet(false); this.numVersions = 0; this.attributes = null; } /** * name of table */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * name of table */ public getVer_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public getVer_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } /** * row key */ public byte[] getRow() { setRow(org.apache.thrift.TBaseHelper.rightSize(row)); return row == null ? null : row.array(); } public ByteBuffer bufferForRow() { return org.apache.thrift.TBaseHelper.copyBinary(row); } /** * row key */ public getVer_args setRow(byte[] row) { this.row = row == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(row, row.length)); return this; } public getVer_args setRow(ByteBuffer row) { this.row = org.apache.thrift.TBaseHelper.copyBinary(row); return this; } public void unsetRow() { this.row = null; } /** Returns true if field row is set (has been assigned a value) and false otherwise */ public boolean isSetRow() { return this.row != null; } public void setRowIsSet(boolean value) { if (!value) { this.row = null; } } /** * column name */ public byte[] getColumn() { setColumn(org.apache.thrift.TBaseHelper.rightSize(column)); return column == null ? null : column.array(); } public ByteBuffer bufferForColumn() { return org.apache.thrift.TBaseHelper.copyBinary(column); } /** * column name */ public getVer_args setColumn(byte[] column) { this.column = column == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(column, column.length)); return this; } public getVer_args setColumn(ByteBuffer column) { this.column = org.apache.thrift.TBaseHelper.copyBinary(column); return this; } public void unsetColumn() { this.column = null; } /** Returns true if field column is set (has been assigned a value) and false otherwise */ public boolean isSetColumn() { return this.column != null; } public void setColumnIsSet(boolean value) { if (!value) { this.column = null; } } /** * number of versions to retrieve */ public int getNumVersions() { return this.numVersions; } /** * number of versions to retrieve */ public getVer_args setNumVersions(int numVersions) { this.numVersions = numVersions; setNumVersionsIsSet(true); return this; } public void unsetNumVersions() { __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __NUMVERSIONS_ISSET_ID); } /** Returns true if field numVersions is set (has been assigned a value) and false otherwise */ public boolean isSetNumVersions() { return EncodingUtils.testBit(__isset_bitfield, __NUMVERSIONS_ISSET_ID); } public void setNumVersionsIsSet(boolean value) { __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __NUMVERSIONS_ISSET_ID, value); } public int getAttributesSize() { return (this.attributes == null) ? 0 : this.attributes.size(); } public void putToAttributes(ByteBuffer key, ByteBuffer val) { if (this.attributes == null) { this.attributes = new HashMap<ByteBuffer,ByteBuffer>(); } this.attributes.put(key, val); } /** * Get attributes */ public Map<ByteBuffer,ByteBuffer> getAttributes() { return this.attributes; } /** * Get attributes */ public getVer_args setAttributes(Map<ByteBuffer,ByteBuffer> attributes) { this.attributes = attributes; return this; } public void unsetAttributes() { this.attributes = null; } /** Returns true if field attributes is set (has been assigned a value) and false otherwise */ public boolean isSetAttributes() { return this.attributes != null; } public void setAttributesIsSet(boolean value) { if (!value) { this.attributes = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; case ROW: if (value == null) { unsetRow(); } else { setRow((ByteBuffer)value); } break; case COLUMN: if (value == null) { unsetColumn(); } else { setColumn((ByteBuffer)value); } break; case NUM_VERSIONS: if (value == null) { unsetNumVersions(); } else { setNumVersions((Integer)value); } break; case ATTRIBUTES: if (value == null) { unsetAttributes(); } else { setAttributes((Map<ByteBuffer,ByteBuffer>)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); case ROW: return getRow(); case COLUMN: return getColumn(); case NUM_VERSIONS: return getNumVersions(); case ATTRIBUTES: return getAttributes(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); case ROW: return isSetRow(); case COLUMN: return isSetColumn(); case NUM_VERSIONS: return isSetNumVersions(); case ATTRIBUTES: return isSetAttributes(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof getVer_args) return this.equals((getVer_args)that); return false; } public boolean equals(getVer_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } boolean this_present_row = true && this.isSetRow(); boolean that_present_row = true && that.isSetRow(); if (this_present_row || that_present_row) { if (!(this_present_row && that_present_row)) return false; if (!this.row.equals(that.row)) return false; } boolean this_present_column = true && this.isSetColumn(); boolean that_present_column = true && that.isSetColumn(); if (this_present_column || that_present_column) { if (!(this_present_column && that_present_column)) return false; if (!this.column.equals(that.column)) return false; } boolean this_present_numVersions = true; boolean that_present_numVersions = true; if (this_present_numVersions || that_present_numVersions) { if (!(this_present_numVersions && that_present_numVersions)) return false; if (this.numVersions != that.numVersions) return false; } boolean this_present_attributes = true && this.isSetAttributes(); boolean that_present_attributes = true && that.isSetAttributes(); if (this_present_attributes || that_present_attributes) { if (!(this_present_attributes && that_present_attributes)) return false; if (!this.attributes.equals(that.attributes)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); boolean present_row = true && (isSetRow()); list.add(present_row); if (present_row) list.add(row); boolean present_column = true && (isSetColumn()); list.add(present_column); if (present_column) list.add(column); boolean present_numVersions = true; list.add(present_numVersions); if (present_numVersions) list.add(numVersions); boolean present_attributes = true && (isSetAttributes()); list.add(present_attributes); if (present_attributes) list.add(attributes); return list.hashCode(); } @Override public int compareTo(getVer_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetRow()).compareTo(other.isSetRow()); if (lastComparison != 0) { return lastComparison; } if (isSetRow()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.row, other.row); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetColumn()).compareTo(other.isSetColumn()); if (lastComparison != 0) { return lastComparison; } if (isSetColumn()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.column, other.column); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetNumVersions()).compareTo(other.isSetNumVersions()); if (lastComparison != 0) { return lastComparison; } if (isSetNumVersions()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numVersions, other.numVersions); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetAttributes()).compareTo(other.isSetAttributes()); if (lastComparison != 0) { return lastComparison; } if (isSetAttributes()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.attributes, other.attributes); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("getVer_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; if (!first) sb.append(", "); sb.append("row:"); if (this.row == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.row, sb); } first = false; if (!first) sb.append(", "); sb.append("column:"); if (this.column == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.column, sb); } first = false; if (!first) sb.append(", "); sb.append("numVersions:"); sb.append(this.numVersions); first = false; if (!first) sb.append(", "); sb.append("attributes:"); if (this.attributes == null) { sb.append("null"); } else { sb.append(this.attributes); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { // it doesn't seem like you should have to do this, but java serialization is wacky, and doesn't call the default constructor. __isset_bitfield = 0; read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class getVer_argsStandardSchemeFactory implements SchemeFactory { public getVer_argsStandardScheme getScheme() { return new getVer_argsStandardScheme(); } } private static class getVer_argsStandardScheme extends StandardScheme<getVer_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, getVer_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // ROW if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.row = iprot.readBinary(); struct.setRowIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 3: // COLUMN if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.column = iprot.readBinary(); struct.setColumnIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 4: // NUM_VERSIONS if (schemeField.type == org.apache.thrift.protocol.TType.I32) { struct.numVersions = iprot.readI32(); struct.setNumVersionsIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 5: // ATTRIBUTES if (schemeField.type == org.apache.thrift.protocol.TType.MAP) { { org.apache.thrift.protocol.TMap _map102 = iprot.readMapBegin(); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map102.size); ByteBuffer _key103; ByteBuffer _val104; for (int _i105 = 0; _i105 < _map102.size; ++_i105) { _key103 = iprot.readBinary(); _val104 = iprot.readBinary(); struct.attributes.put(_key103, _val104); } iprot.readMapEnd(); } struct.setAttributesIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, getVer_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } if (struct.row != null) { oprot.writeFieldBegin(ROW_FIELD_DESC); oprot.writeBinary(struct.row); oprot.writeFieldEnd(); } if (struct.column != null) { oprot.writeFieldBegin(COLUMN_FIELD_DESC); oprot.writeBinary(struct.column); oprot.writeFieldEnd(); } oprot.writeFieldBegin(NUM_VERSIONS_FIELD_DESC); oprot.writeI32(struct.numVersions); oprot.writeFieldEnd(); if (struct.attributes != null) { oprot.writeFieldBegin(ATTRIBUTES_FIELD_DESC); { oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, struct.attributes.size())); for (Map.Entry<ByteBuffer, ByteBuffer> _iter106 : struct.attributes.entrySet()) { oprot.writeBinary(_iter106.getKey()); oprot.writeBinary(_iter106.getValue()); } oprot.writeMapEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class getVer_argsTupleSchemeFactory implements SchemeFactory { public getVer_argsTupleScheme getScheme() { return new getVer_argsTupleScheme(); } } private static class getVer_argsTupleScheme extends TupleScheme<getVer_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, getVer_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } if (struct.isSetRow()) { optionals.set(1); } if (struct.isSetColumn()) { optionals.set(2); } if (struct.isSetNumVersions()) { optionals.set(3); } if (struct.isSetAttributes()) { optionals.set(4); } oprot.writeBitSet(optionals, 5); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } if (struct.isSetRow()) { oprot.writeBinary(struct.row); } if (struct.isSetColumn()) { oprot.writeBinary(struct.column); } if (struct.isSetNumVersions()) { oprot.writeI32(struct.numVersions); } if (struct.isSetAttributes()) { { oprot.writeI32(struct.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> _iter107 : struct.attributes.entrySet()) { oprot.writeBinary(_iter107.getKey()); oprot.writeBinary(_iter107.getValue()); } } } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, getVer_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(5); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } if (incoming.get(1)) { struct.row = iprot.readBinary(); struct.setRowIsSet(true); } if (incoming.get(2)) { struct.column = iprot.readBinary(); struct.setColumnIsSet(true); } if (incoming.get(3)) { struct.numVersions = iprot.readI32(); struct.setNumVersionsIsSet(true); } if (incoming.get(4)) { { org.apache.thrift.protocol.TMap _map108 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map108.size); ByteBuffer _key109; ByteBuffer _val110; for (int _i111 = 0; _i111 < _map108.size; ++_i111) { _key109 = iprot.readBinary(); _val110 = iprot.readBinary(); struct.attributes.put(_key109, _val110); } } struct.setAttributesIsSet(true); } } } } public static class getVer_result implements org.apache.thrift.TBase<getVer_result, getVer_result._Fields>, java.io.Serializable, Cloneable, Comparable<getVer_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getVer_result"); private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.LIST, (short)0); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new getVer_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new getVer_resultTupleSchemeFactory()); } public List<TCell> success; // required public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { SUCCESS((short)0, "success"), IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 0: // SUCCESS return SUCCESS; case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.SUCCESS, new org.apache.thrift.meta_data.FieldMetaData("success", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, TCell.class)))); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(getVer_result.class, metaDataMap); } public getVer_result() { } public getVer_result( List<TCell> success, IOError io) { this(); this.success = success; this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public getVer_result(getVer_result other) { if (other.isSetSuccess()) { List<TCell> __this__success = new ArrayList<TCell>(other.success.size()); for (TCell other_element : other.success) { __this__success.add(new TCell(other_element)); } this.success = __this__success; } if (other.isSetIo()) { this.io = new IOError(other.io); } } public getVer_result deepCopy() { return new getVer_result(this); } @Override public void clear() { this.success = null; this.io = null; } public int getSuccessSize() { return (this.success == null) ? 0 : this.success.size(); } public java.util.Iterator<TCell> getSuccessIterator() { return (this.success == null) ? null : this.success.iterator(); } public void addToSuccess(TCell elem) { if (this.success == null) { this.success = new ArrayList<TCell>(); } this.success.add(elem); } public List<TCell> getSuccess() { return this.success; } public getVer_result setSuccess(List<TCell> success) { this.success = success; return this; } public void unsetSuccess() { this.success = null; } /** Returns true if field success is set (has been assigned a value) and false otherwise */ public boolean isSetSuccess() { return this.success != null; } public void setSuccessIsSet(boolean value) { if (!value) { this.success = null; } } public IOError getIo() { return this.io; } public getVer_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case SUCCESS: if (value == null) { unsetSuccess(); } else { setSuccess((List<TCell>)value); } break; case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case SUCCESS: return getSuccess(); case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case SUCCESS: return isSetSuccess(); case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof getVer_result) return this.equals((getVer_result)that); return false; } public boolean equals(getVer_result that) { if (that == null) return false; boolean this_present_success = true && this.isSetSuccess(); boolean that_present_success = true && that.isSetSuccess(); if (this_present_success || that_present_success) { if (!(this_present_success && that_present_success)) return false; if (!this.success.equals(that.success)) return false; } boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_success = true && (isSetSuccess()); list.add(present_success); if (present_success) list.add(success); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(getVer_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess()); if (lastComparison != 0) { return lastComparison; } if (isSetSuccess()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("getVer_result("); boolean first = true; sb.append("success:"); if (this.success == null) { sb.append("null"); } else { sb.append(this.success); } first = false; if (!first) sb.append(", "); sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class getVer_resultStandardSchemeFactory implements SchemeFactory { public getVer_resultStandardScheme getScheme() { return new getVer_resultStandardScheme(); } } private static class getVer_resultStandardScheme extends StandardScheme<getVer_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, getVer_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list112 = iprot.readListBegin(); struct.success = new ArrayList<TCell>(_list112.size); TCell _elem113; for (int _i114 = 0; _i114 < _list112.size; ++_i114) { _elem113 = new TCell(); _elem113.read(iprot); struct.success.add(_elem113); } iprot.readListEnd(); } struct.setSuccessIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, getVer_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.success != null) { oprot.writeFieldBegin(SUCCESS_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size())); for (TCell _iter115 : struct.success) { _iter115.write(oprot); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class getVer_resultTupleSchemeFactory implements SchemeFactory { public getVer_resultTupleScheme getScheme() { return new getVer_resultTupleScheme(); } } private static class getVer_resultTupleScheme extends TupleScheme<getVer_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, getVer_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetSuccess()) { optionals.set(0); } if (struct.isSetIo()) { optionals.set(1); } oprot.writeBitSet(optionals, 2); if (struct.isSetSuccess()) { { oprot.writeI32(struct.success.size()); for (TCell _iter116 : struct.success) { _iter116.write(oprot); } } } if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, getVer_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { { org.apache.thrift.protocol.TList _list117 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32()); struct.success = new ArrayList<TCell>(_list117.size); TCell _elem118; for (int _i119 = 0; _i119 < _list117.size; ++_i119) { _elem118 = new TCell(); _elem118.read(iprot); struct.success.add(_elem118); } } struct.setSuccessIsSet(true); } if (incoming.get(1)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class getVerTs_args implements org.apache.thrift.TBase<getVerTs_args, getVerTs_args._Fields>, java.io.Serializable, Cloneable, Comparable<getVerTs_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getVerTs_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final org.apache.thrift.protocol.TField ROW_FIELD_DESC = new org.apache.thrift.protocol.TField("row", org.apache.thrift.protocol.TType.STRING, (short)2); private static final org.apache.thrift.protocol.TField COLUMN_FIELD_DESC = new org.apache.thrift.protocol.TField("column", org.apache.thrift.protocol.TType.STRING, (short)3); private static final org.apache.thrift.protocol.TField TIMESTAMP_FIELD_DESC = new org.apache.thrift.protocol.TField("timestamp", org.apache.thrift.protocol.TType.I64, (short)4); private static final org.apache.thrift.protocol.TField NUM_VERSIONS_FIELD_DESC = new org.apache.thrift.protocol.TField("numVersions", org.apache.thrift.protocol.TType.I32, (short)5); private static final org.apache.thrift.protocol.TField ATTRIBUTES_FIELD_DESC = new org.apache.thrift.protocol.TField("attributes", org.apache.thrift.protocol.TType.MAP, (short)6); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new getVerTs_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new getVerTs_argsTupleSchemeFactory()); } /** * name of table */ public ByteBuffer tableName; // required /** * row key */ public ByteBuffer row; // required /** * column name */ public ByteBuffer column; // required /** * timestamp */ public long timestamp; // required /** * number of versions to retrieve */ public int numVersions; // required /** * Get attributes */ public Map<ByteBuffer,ByteBuffer> attributes; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * name of table */ TABLE_NAME((short)1, "tableName"), /** * row key */ ROW((short)2, "row"), /** * column name */ COLUMN((short)3, "column"), /** * timestamp */ TIMESTAMP((short)4, "timestamp"), /** * number of versions to retrieve */ NUM_VERSIONS((short)5, "numVersions"), /** * Get attributes */ ATTRIBUTES((short)6, "attributes"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; case 2: // ROW return ROW; case 3: // COLUMN return COLUMN; case 4: // TIMESTAMP return TIMESTAMP; case 5: // NUM_VERSIONS return NUM_VERSIONS; case 6: // ATTRIBUTES return ATTRIBUTES; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments private static final int __TIMESTAMP_ISSET_ID = 0; private static final int __NUMVERSIONS_ISSET_ID = 1; private byte __isset_bitfield = 0; public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.ROW, new org.apache.thrift.meta_data.FieldMetaData("row", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.COLUMN, new org.apache.thrift.meta_data.FieldMetaData("column", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.TIMESTAMP, new org.apache.thrift.meta_data.FieldMetaData("timestamp", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.I64))); tmpMap.put(_Fields.NUM_VERSIONS, new org.apache.thrift.meta_data.FieldMetaData("numVersions", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.I32))); tmpMap.put(_Fields.ATTRIBUTES, new org.apache.thrift.meta_data.FieldMetaData("attributes", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.MapMetaData(org.apache.thrift.protocol.TType.MAP, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"), new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(getVerTs_args.class, metaDataMap); } public getVerTs_args() { } public getVerTs_args( ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, int numVersions, Map<ByteBuffer,ByteBuffer> attributes) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); this.row = org.apache.thrift.TBaseHelper.copyBinary(row); this.column = org.apache.thrift.TBaseHelper.copyBinary(column); this.timestamp = timestamp; setTimestampIsSet(true); this.numVersions = numVersions; setNumVersionsIsSet(true); this.attributes = attributes; } /** * Performs a deep copy on <i>other</i>. */ public getVerTs_args(getVerTs_args other) { __isset_bitfield = other.__isset_bitfield; if (other.isSetTableName()) { this.tableName = other.tableName; } if (other.isSetRow()) { this.row = other.row; } if (other.isSetColumn()) { this.column = other.column; } this.timestamp = other.timestamp; this.numVersions = other.numVersions; if (other.isSetAttributes()) { Map<ByteBuffer,ByteBuffer> __this__attributes = new HashMap<ByteBuffer,ByteBuffer>(other.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> other_element : other.attributes.entrySet()) { ByteBuffer other_element_key = other_element.getKey(); ByteBuffer other_element_value = other_element.getValue(); ByteBuffer __this__attributes_copy_key = other_element_key; ByteBuffer __this__attributes_copy_value = other_element_value; __this__attributes.put(__this__attributes_copy_key, __this__attributes_copy_value); } this.attributes = __this__attributes; } } public getVerTs_args deepCopy() { return new getVerTs_args(this); } @Override public void clear() { this.tableName = null; this.row = null; this.column = null; setTimestampIsSet(false); this.timestamp = 0; setNumVersionsIsSet(false); this.numVersions = 0; this.attributes = null; } /** * name of table */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * name of table */ public getVerTs_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public getVerTs_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } /** * row key */ public byte[] getRow() { setRow(org.apache.thrift.TBaseHelper.rightSize(row)); return row == null ? null : row.array(); } public ByteBuffer bufferForRow() { return org.apache.thrift.TBaseHelper.copyBinary(row); } /** * row key */ public getVerTs_args setRow(byte[] row) { this.row = row == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(row, row.length)); return this; } public getVerTs_args setRow(ByteBuffer row) { this.row = org.apache.thrift.TBaseHelper.copyBinary(row); return this; } public void unsetRow() { this.row = null; } /** Returns true if field row is set (has been assigned a value) and false otherwise */ public boolean isSetRow() { return this.row != null; } public void setRowIsSet(boolean value) { if (!value) { this.row = null; } } /** * column name */ public byte[] getColumn() { setColumn(org.apache.thrift.TBaseHelper.rightSize(column)); return column == null ? null : column.array(); } public ByteBuffer bufferForColumn() { return org.apache.thrift.TBaseHelper.copyBinary(column); } /** * column name */ public getVerTs_args setColumn(byte[] column) { this.column = column == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(column, column.length)); return this; } public getVerTs_args setColumn(ByteBuffer column) { this.column = org.apache.thrift.TBaseHelper.copyBinary(column); return this; } public void unsetColumn() { this.column = null; } /** Returns true if field column is set (has been assigned a value) and false otherwise */ public boolean isSetColumn() { return this.column != null; } public void setColumnIsSet(boolean value) { if (!value) { this.column = null; } } /** * timestamp */ public long getTimestamp() { return this.timestamp; } /** * timestamp */ public getVerTs_args setTimestamp(long timestamp) { this.timestamp = timestamp; setTimestampIsSet(true); return this; } public void unsetTimestamp() { __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __TIMESTAMP_ISSET_ID); } /** Returns true if field timestamp is set (has been assigned a value) and false otherwise */ public boolean isSetTimestamp() { return EncodingUtils.testBit(__isset_bitfield, __TIMESTAMP_ISSET_ID); } public void setTimestampIsSet(boolean value) { __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __TIMESTAMP_ISSET_ID, value); } /** * number of versions to retrieve */ public int getNumVersions() { return this.numVersions; } /** * number of versions to retrieve */ public getVerTs_args setNumVersions(int numVersions) { this.numVersions = numVersions; setNumVersionsIsSet(true); return this; } public void unsetNumVersions() { __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __NUMVERSIONS_ISSET_ID); } /** Returns true if field numVersions is set (has been assigned a value) and false otherwise */ public boolean isSetNumVersions() { return EncodingUtils.testBit(__isset_bitfield, __NUMVERSIONS_ISSET_ID); } public void setNumVersionsIsSet(boolean value) { __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __NUMVERSIONS_ISSET_ID, value); } public int getAttributesSize() { return (this.attributes == null) ? 0 : this.attributes.size(); } public void putToAttributes(ByteBuffer key, ByteBuffer val) { if (this.attributes == null) { this.attributes = new HashMap<ByteBuffer,ByteBuffer>(); } this.attributes.put(key, val); } /** * Get attributes */ public Map<ByteBuffer,ByteBuffer> getAttributes() { return this.attributes; } /** * Get attributes */ public getVerTs_args setAttributes(Map<ByteBuffer,ByteBuffer> attributes) { this.attributes = attributes; return this; } public void unsetAttributes() { this.attributes = null; } /** Returns true if field attributes is set (has been assigned a value) and false otherwise */ public boolean isSetAttributes() { return this.attributes != null; } public void setAttributesIsSet(boolean value) { if (!value) { this.attributes = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; case ROW: if (value == null) { unsetRow(); } else { setRow((ByteBuffer)value); } break; case COLUMN: if (value == null) { unsetColumn(); } else { setColumn((ByteBuffer)value); } break; case TIMESTAMP: if (value == null) { unsetTimestamp(); } else { setTimestamp((Long)value); } break; case NUM_VERSIONS: if (value == null) { unsetNumVersions(); } else { setNumVersions((Integer)value); } break; case ATTRIBUTES: if (value == null) { unsetAttributes(); } else { setAttributes((Map<ByteBuffer,ByteBuffer>)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); case ROW: return getRow(); case COLUMN: return getColumn(); case TIMESTAMP: return getTimestamp(); case NUM_VERSIONS: return getNumVersions(); case ATTRIBUTES: return getAttributes(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); case ROW: return isSetRow(); case COLUMN: return isSetColumn(); case TIMESTAMP: return isSetTimestamp(); case NUM_VERSIONS: return isSetNumVersions(); case ATTRIBUTES: return isSetAttributes(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof getVerTs_args) return this.equals((getVerTs_args)that); return false; } public boolean equals(getVerTs_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } boolean this_present_row = true && this.isSetRow(); boolean that_present_row = true && that.isSetRow(); if (this_present_row || that_present_row) { if (!(this_present_row && that_present_row)) return false; if (!this.row.equals(that.row)) return false; } boolean this_present_column = true && this.isSetColumn(); boolean that_present_column = true && that.isSetColumn(); if (this_present_column || that_present_column) { if (!(this_present_column && that_present_column)) return false; if (!this.column.equals(that.column)) return false; } boolean this_present_timestamp = true; boolean that_present_timestamp = true; if (this_present_timestamp || that_present_timestamp) { if (!(this_present_timestamp && that_present_timestamp)) return false; if (this.timestamp != that.timestamp) return false; } boolean this_present_numVersions = true; boolean that_present_numVersions = true; if (this_present_numVersions || that_present_numVersions) { if (!(this_present_numVersions && that_present_numVersions)) return false; if (this.numVersions != that.numVersions) return false; } boolean this_present_attributes = true && this.isSetAttributes(); boolean that_present_attributes = true && that.isSetAttributes(); if (this_present_attributes || that_present_attributes) { if (!(this_present_attributes && that_present_attributes)) return false; if (!this.attributes.equals(that.attributes)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); boolean present_row = true && (isSetRow()); list.add(present_row); if (present_row) list.add(row); boolean present_column = true && (isSetColumn()); list.add(present_column); if (present_column) list.add(column); boolean present_timestamp = true; list.add(present_timestamp); if (present_timestamp) list.add(timestamp); boolean present_numVersions = true; list.add(present_numVersions); if (present_numVersions) list.add(numVersions); boolean present_attributes = true && (isSetAttributes()); list.add(present_attributes); if (present_attributes) list.add(attributes); return list.hashCode(); } @Override public int compareTo(getVerTs_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetRow()).compareTo(other.isSetRow()); if (lastComparison != 0) { return lastComparison; } if (isSetRow()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.row, other.row); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetColumn()).compareTo(other.isSetColumn()); if (lastComparison != 0) { return lastComparison; } if (isSetColumn()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.column, other.column); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetTimestamp()).compareTo(other.isSetTimestamp()); if (lastComparison != 0) { return lastComparison; } if (isSetTimestamp()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.timestamp, other.timestamp); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetNumVersions()).compareTo(other.isSetNumVersions()); if (lastComparison != 0) { return lastComparison; } if (isSetNumVersions()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numVersions, other.numVersions); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetAttributes()).compareTo(other.isSetAttributes()); if (lastComparison != 0) { return lastComparison; } if (isSetAttributes()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.attributes, other.attributes); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("getVerTs_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; if (!first) sb.append(", "); sb.append("row:"); if (this.row == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.row, sb); } first = false; if (!first) sb.append(", "); sb.append("column:"); if (this.column == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.column, sb); } first = false; if (!first) sb.append(", "); sb.append("timestamp:"); sb.append(this.timestamp); first = false; if (!first) sb.append(", "); sb.append("numVersions:"); sb.append(this.numVersions); first = false; if (!first) sb.append(", "); sb.append("attributes:"); if (this.attributes == null) { sb.append("null"); } else { sb.append(this.attributes); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { // it doesn't seem like you should have to do this, but java serialization is wacky, and doesn't call the default constructor. __isset_bitfield = 0; read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class getVerTs_argsStandardSchemeFactory implements SchemeFactory { public getVerTs_argsStandardScheme getScheme() { return new getVerTs_argsStandardScheme(); } } private static class getVerTs_argsStandardScheme extends StandardScheme<getVerTs_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, getVerTs_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // ROW if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.row = iprot.readBinary(); struct.setRowIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 3: // COLUMN if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.column = iprot.readBinary(); struct.setColumnIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 4: // TIMESTAMP if (schemeField.type == org.apache.thrift.protocol.TType.I64) { struct.timestamp = iprot.readI64(); struct.setTimestampIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 5: // NUM_VERSIONS if (schemeField.type == org.apache.thrift.protocol.TType.I32) { struct.numVersions = iprot.readI32(); struct.setNumVersionsIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 6: // ATTRIBUTES if (schemeField.type == org.apache.thrift.protocol.TType.MAP) { { org.apache.thrift.protocol.TMap _map120 = iprot.readMapBegin(); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map120.size); ByteBuffer _key121; ByteBuffer _val122; for (int _i123 = 0; _i123 < _map120.size; ++_i123) { _key121 = iprot.readBinary(); _val122 = iprot.readBinary(); struct.attributes.put(_key121, _val122); } iprot.readMapEnd(); } struct.setAttributesIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, getVerTs_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } if (struct.row != null) { oprot.writeFieldBegin(ROW_FIELD_DESC); oprot.writeBinary(struct.row); oprot.writeFieldEnd(); } if (struct.column != null) { oprot.writeFieldBegin(COLUMN_FIELD_DESC); oprot.writeBinary(struct.column); oprot.writeFieldEnd(); } oprot.writeFieldBegin(TIMESTAMP_FIELD_DESC); oprot.writeI64(struct.timestamp); oprot.writeFieldEnd(); oprot.writeFieldBegin(NUM_VERSIONS_FIELD_DESC); oprot.writeI32(struct.numVersions); oprot.writeFieldEnd(); if (struct.attributes != null) { oprot.writeFieldBegin(ATTRIBUTES_FIELD_DESC); { oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, struct.attributes.size())); for (Map.Entry<ByteBuffer, ByteBuffer> _iter124 : struct.attributes.entrySet()) { oprot.writeBinary(_iter124.getKey()); oprot.writeBinary(_iter124.getValue()); } oprot.writeMapEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class getVerTs_argsTupleSchemeFactory implements SchemeFactory { public getVerTs_argsTupleScheme getScheme() { return new getVerTs_argsTupleScheme(); } } private static class getVerTs_argsTupleScheme extends TupleScheme<getVerTs_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, getVerTs_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } if (struct.isSetRow()) { optionals.set(1); } if (struct.isSetColumn()) { optionals.set(2); } if (struct.isSetTimestamp()) { optionals.set(3); } if (struct.isSetNumVersions()) { optionals.set(4); } if (struct.isSetAttributes()) { optionals.set(5); } oprot.writeBitSet(optionals, 6); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } if (struct.isSetRow()) { oprot.writeBinary(struct.row); } if (struct.isSetColumn()) { oprot.writeBinary(struct.column); } if (struct.isSetTimestamp()) { oprot.writeI64(struct.timestamp); } if (struct.isSetNumVersions()) { oprot.writeI32(struct.numVersions); } if (struct.isSetAttributes()) { { oprot.writeI32(struct.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> _iter125 : struct.attributes.entrySet()) { oprot.writeBinary(_iter125.getKey()); oprot.writeBinary(_iter125.getValue()); } } } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, getVerTs_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(6); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } if (incoming.get(1)) { struct.row = iprot.readBinary(); struct.setRowIsSet(true); } if (incoming.get(2)) { struct.column = iprot.readBinary(); struct.setColumnIsSet(true); } if (incoming.get(3)) { struct.timestamp = iprot.readI64(); struct.setTimestampIsSet(true); } if (incoming.get(4)) { struct.numVersions = iprot.readI32(); struct.setNumVersionsIsSet(true); } if (incoming.get(5)) { { org.apache.thrift.protocol.TMap _map126 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map126.size); ByteBuffer _key127; ByteBuffer _val128; for (int _i129 = 0; _i129 < _map126.size; ++_i129) { _key127 = iprot.readBinary(); _val128 = iprot.readBinary(); struct.attributes.put(_key127, _val128); } } struct.setAttributesIsSet(true); } } } } public static class getVerTs_result implements org.apache.thrift.TBase<getVerTs_result, getVerTs_result._Fields>, java.io.Serializable, Cloneable, Comparable<getVerTs_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getVerTs_result"); private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.LIST, (short)0); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new getVerTs_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new getVerTs_resultTupleSchemeFactory()); } public List<TCell> success; // required public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { SUCCESS((short)0, "success"), IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 0: // SUCCESS return SUCCESS; case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.SUCCESS, new org.apache.thrift.meta_data.FieldMetaData("success", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, TCell.class)))); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(getVerTs_result.class, metaDataMap); } public getVerTs_result() { } public getVerTs_result( List<TCell> success, IOError io) { this(); this.success = success; this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public getVerTs_result(getVerTs_result other) { if (other.isSetSuccess()) { List<TCell> __this__success = new ArrayList<TCell>(other.success.size()); for (TCell other_element : other.success) { __this__success.add(new TCell(other_element)); } this.success = __this__success; } if (other.isSetIo()) { this.io = new IOError(other.io); } } public getVerTs_result deepCopy() { return new getVerTs_result(this); } @Override public void clear() { this.success = null; this.io = null; } public int getSuccessSize() { return (this.success == null) ? 0 : this.success.size(); } public java.util.Iterator<TCell> getSuccessIterator() { return (this.success == null) ? null : this.success.iterator(); } public void addToSuccess(TCell elem) { if (this.success == null) { this.success = new ArrayList<TCell>(); } this.success.add(elem); } public List<TCell> getSuccess() { return this.success; } public getVerTs_result setSuccess(List<TCell> success) { this.success = success; return this; } public void unsetSuccess() { this.success = null; } /** Returns true if field success is set (has been assigned a value) and false otherwise */ public boolean isSetSuccess() { return this.success != null; } public void setSuccessIsSet(boolean value) { if (!value) { this.success = null; } } public IOError getIo() { return this.io; } public getVerTs_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case SUCCESS: if (value == null) { unsetSuccess(); } else { setSuccess((List<TCell>)value); } break; case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case SUCCESS: return getSuccess(); case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case SUCCESS: return isSetSuccess(); case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof getVerTs_result) return this.equals((getVerTs_result)that); return false; } public boolean equals(getVerTs_result that) { if (that == null) return false; boolean this_present_success = true && this.isSetSuccess(); boolean that_present_success = true && that.isSetSuccess(); if (this_present_success || that_present_success) { if (!(this_present_success && that_present_success)) return false; if (!this.success.equals(that.success)) return false; } boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_success = true && (isSetSuccess()); list.add(present_success); if (present_success) list.add(success); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(getVerTs_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess()); if (lastComparison != 0) { return lastComparison; } if (isSetSuccess()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("getVerTs_result("); boolean first = true; sb.append("success:"); if (this.success == null) { sb.append("null"); } else { sb.append(this.success); } first = false; if (!first) sb.append(", "); sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class getVerTs_resultStandardSchemeFactory implements SchemeFactory { public getVerTs_resultStandardScheme getScheme() { return new getVerTs_resultStandardScheme(); } } private static class getVerTs_resultStandardScheme extends StandardScheme<getVerTs_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, getVerTs_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list130 = iprot.readListBegin(); struct.success = new ArrayList<TCell>(_list130.size); TCell _elem131; for (int _i132 = 0; _i132 < _list130.size; ++_i132) { _elem131 = new TCell(); _elem131.read(iprot); struct.success.add(_elem131); } iprot.readListEnd(); } struct.setSuccessIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, getVerTs_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.success != null) { oprot.writeFieldBegin(SUCCESS_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size())); for (TCell _iter133 : struct.success) { _iter133.write(oprot); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class getVerTs_resultTupleSchemeFactory implements SchemeFactory { public getVerTs_resultTupleScheme getScheme() { return new getVerTs_resultTupleScheme(); } } private static class getVerTs_resultTupleScheme extends TupleScheme<getVerTs_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, getVerTs_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetSuccess()) { optionals.set(0); } if (struct.isSetIo()) { optionals.set(1); } oprot.writeBitSet(optionals, 2); if (struct.isSetSuccess()) { { oprot.writeI32(struct.success.size()); for (TCell _iter134 : struct.success) { _iter134.write(oprot); } } } if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, getVerTs_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { { org.apache.thrift.protocol.TList _list135 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32()); struct.success = new ArrayList<TCell>(_list135.size); TCell _elem136; for (int _i137 = 0; _i137 < _list135.size; ++_i137) { _elem136 = new TCell(); _elem136.read(iprot); struct.success.add(_elem136); } } struct.setSuccessIsSet(true); } if (incoming.get(1)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class getRow_args implements org.apache.thrift.TBase<getRow_args, getRow_args._Fields>, java.io.Serializable, Cloneable, Comparable<getRow_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getRow_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final org.apache.thrift.protocol.TField ROW_FIELD_DESC = new org.apache.thrift.protocol.TField("row", org.apache.thrift.protocol.TType.STRING, (short)2); private static final org.apache.thrift.protocol.TField ATTRIBUTES_FIELD_DESC = new org.apache.thrift.protocol.TField("attributes", org.apache.thrift.protocol.TType.MAP, (short)3); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new getRow_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new getRow_argsTupleSchemeFactory()); } /** * name of table */ public ByteBuffer tableName; // required /** * row key */ public ByteBuffer row; // required /** * Get attributes */ public Map<ByteBuffer,ByteBuffer> attributes; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * name of table */ TABLE_NAME((short)1, "tableName"), /** * row key */ ROW((short)2, "row"), /** * Get attributes */ ATTRIBUTES((short)3, "attributes"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; case 2: // ROW return ROW; case 3: // ATTRIBUTES return ATTRIBUTES; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.ROW, new org.apache.thrift.meta_data.FieldMetaData("row", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.ATTRIBUTES, new org.apache.thrift.meta_data.FieldMetaData("attributes", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.MapMetaData(org.apache.thrift.protocol.TType.MAP, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"), new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(getRow_args.class, metaDataMap); } public getRow_args() { } public getRow_args( ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); this.row = org.apache.thrift.TBaseHelper.copyBinary(row); this.attributes = attributes; } /** * Performs a deep copy on <i>other</i>. */ public getRow_args(getRow_args other) { if (other.isSetTableName()) { this.tableName = other.tableName; } if (other.isSetRow()) { this.row = other.row; } if (other.isSetAttributes()) { Map<ByteBuffer,ByteBuffer> __this__attributes = new HashMap<ByteBuffer,ByteBuffer>(other.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> other_element : other.attributes.entrySet()) { ByteBuffer other_element_key = other_element.getKey(); ByteBuffer other_element_value = other_element.getValue(); ByteBuffer __this__attributes_copy_key = other_element_key; ByteBuffer __this__attributes_copy_value = other_element_value; __this__attributes.put(__this__attributes_copy_key, __this__attributes_copy_value); } this.attributes = __this__attributes; } } public getRow_args deepCopy() { return new getRow_args(this); } @Override public void clear() { this.tableName = null; this.row = null; this.attributes = null; } /** * name of table */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * name of table */ public getRow_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public getRow_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } /** * row key */ public byte[] getRow() { setRow(org.apache.thrift.TBaseHelper.rightSize(row)); return row == null ? null : row.array(); } public ByteBuffer bufferForRow() { return org.apache.thrift.TBaseHelper.copyBinary(row); } /** * row key */ public getRow_args setRow(byte[] row) { this.row = row == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(row, row.length)); return this; } public getRow_args setRow(ByteBuffer row) { this.row = org.apache.thrift.TBaseHelper.copyBinary(row); return this; } public void unsetRow() { this.row = null; } /** Returns true if field row is set (has been assigned a value) and false otherwise */ public boolean isSetRow() { return this.row != null; } public void setRowIsSet(boolean value) { if (!value) { this.row = null; } } public int getAttributesSize() { return (this.attributes == null) ? 0 : this.attributes.size(); } public void putToAttributes(ByteBuffer key, ByteBuffer val) { if (this.attributes == null) { this.attributes = new HashMap<ByteBuffer,ByteBuffer>(); } this.attributes.put(key, val); } /** * Get attributes */ public Map<ByteBuffer,ByteBuffer> getAttributes() { return this.attributes; } /** * Get attributes */ public getRow_args setAttributes(Map<ByteBuffer,ByteBuffer> attributes) { this.attributes = attributes; return this; } public void unsetAttributes() { this.attributes = null; } /** Returns true if field attributes is set (has been assigned a value) and false otherwise */ public boolean isSetAttributes() { return this.attributes != null; } public void setAttributesIsSet(boolean value) { if (!value) { this.attributes = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; case ROW: if (value == null) { unsetRow(); } else { setRow((ByteBuffer)value); } break; case ATTRIBUTES: if (value == null) { unsetAttributes(); } else { setAttributes((Map<ByteBuffer,ByteBuffer>)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); case ROW: return getRow(); case ATTRIBUTES: return getAttributes(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); case ROW: return isSetRow(); case ATTRIBUTES: return isSetAttributes(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof getRow_args) return this.equals((getRow_args)that); return false; } public boolean equals(getRow_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } boolean this_present_row = true && this.isSetRow(); boolean that_present_row = true && that.isSetRow(); if (this_present_row || that_present_row) { if (!(this_present_row && that_present_row)) return false; if (!this.row.equals(that.row)) return false; } boolean this_present_attributes = true && this.isSetAttributes(); boolean that_present_attributes = true && that.isSetAttributes(); if (this_present_attributes || that_present_attributes) { if (!(this_present_attributes && that_present_attributes)) return false; if (!this.attributes.equals(that.attributes)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); boolean present_row = true && (isSetRow()); list.add(present_row); if (present_row) list.add(row); boolean present_attributes = true && (isSetAttributes()); list.add(present_attributes); if (present_attributes) list.add(attributes); return list.hashCode(); } @Override public int compareTo(getRow_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetRow()).compareTo(other.isSetRow()); if (lastComparison != 0) { return lastComparison; } if (isSetRow()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.row, other.row); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetAttributes()).compareTo(other.isSetAttributes()); if (lastComparison != 0) { return lastComparison; } if (isSetAttributes()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.attributes, other.attributes); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("getRow_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; if (!first) sb.append(", "); sb.append("row:"); if (this.row == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.row, sb); } first = false; if (!first) sb.append(", "); sb.append("attributes:"); if (this.attributes == null) { sb.append("null"); } else { sb.append(this.attributes); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class getRow_argsStandardSchemeFactory implements SchemeFactory { public getRow_argsStandardScheme getScheme() { return new getRow_argsStandardScheme(); } } private static class getRow_argsStandardScheme extends StandardScheme<getRow_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, getRow_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // ROW if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.row = iprot.readBinary(); struct.setRowIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 3: // ATTRIBUTES if (schemeField.type == org.apache.thrift.protocol.TType.MAP) { { org.apache.thrift.protocol.TMap _map138 = iprot.readMapBegin(); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map138.size); ByteBuffer _key139; ByteBuffer _val140; for (int _i141 = 0; _i141 < _map138.size; ++_i141) { _key139 = iprot.readBinary(); _val140 = iprot.readBinary(); struct.attributes.put(_key139, _val140); } iprot.readMapEnd(); } struct.setAttributesIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, getRow_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } if (struct.row != null) { oprot.writeFieldBegin(ROW_FIELD_DESC); oprot.writeBinary(struct.row); oprot.writeFieldEnd(); } if (struct.attributes != null) { oprot.writeFieldBegin(ATTRIBUTES_FIELD_DESC); { oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, struct.attributes.size())); for (Map.Entry<ByteBuffer, ByteBuffer> _iter142 : struct.attributes.entrySet()) { oprot.writeBinary(_iter142.getKey()); oprot.writeBinary(_iter142.getValue()); } oprot.writeMapEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class getRow_argsTupleSchemeFactory implements SchemeFactory { public getRow_argsTupleScheme getScheme() { return new getRow_argsTupleScheme(); } } private static class getRow_argsTupleScheme extends TupleScheme<getRow_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, getRow_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } if (struct.isSetRow()) { optionals.set(1); } if (struct.isSetAttributes()) { optionals.set(2); } oprot.writeBitSet(optionals, 3); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } if (struct.isSetRow()) { oprot.writeBinary(struct.row); } if (struct.isSetAttributes()) { { oprot.writeI32(struct.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> _iter143 : struct.attributes.entrySet()) { oprot.writeBinary(_iter143.getKey()); oprot.writeBinary(_iter143.getValue()); } } } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, getRow_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(3); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } if (incoming.get(1)) { struct.row = iprot.readBinary(); struct.setRowIsSet(true); } if (incoming.get(2)) { { org.apache.thrift.protocol.TMap _map144 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map144.size); ByteBuffer _key145; ByteBuffer _val146; for (int _i147 = 0; _i147 < _map144.size; ++_i147) { _key145 = iprot.readBinary(); _val146 = iprot.readBinary(); struct.attributes.put(_key145, _val146); } } struct.setAttributesIsSet(true); } } } } public static class getRow_result implements org.apache.thrift.TBase<getRow_result, getRow_result._Fields>, java.io.Serializable, Cloneable, Comparable<getRow_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getRow_result"); private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.LIST, (short)0); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new getRow_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new getRow_resultTupleSchemeFactory()); } public List<TRowResult> success; // required public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { SUCCESS((short)0, "success"), IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 0: // SUCCESS return SUCCESS; case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.SUCCESS, new org.apache.thrift.meta_data.FieldMetaData("success", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, TRowResult.class)))); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(getRow_result.class, metaDataMap); } public getRow_result() { } public getRow_result( List<TRowResult> success, IOError io) { this(); this.success = success; this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public getRow_result(getRow_result other) { if (other.isSetSuccess()) { List<TRowResult> __this__success = new ArrayList<TRowResult>(other.success.size()); for (TRowResult other_element : other.success) { __this__success.add(new TRowResult(other_element)); } this.success = __this__success; } if (other.isSetIo()) { this.io = new IOError(other.io); } } public getRow_result deepCopy() { return new getRow_result(this); } @Override public void clear() { this.success = null; this.io = null; } public int getSuccessSize() { return (this.success == null) ? 0 : this.success.size(); } public java.util.Iterator<TRowResult> getSuccessIterator() { return (this.success == null) ? null : this.success.iterator(); } public void addToSuccess(TRowResult elem) { if (this.success == null) { this.success = new ArrayList<TRowResult>(); } this.success.add(elem); } public List<TRowResult> getSuccess() { return this.success; } public getRow_result setSuccess(List<TRowResult> success) { this.success = success; return this; } public void unsetSuccess() { this.success = null; } /** Returns true if field success is set (has been assigned a value) and false otherwise */ public boolean isSetSuccess() { return this.success != null; } public void setSuccessIsSet(boolean value) { if (!value) { this.success = null; } } public IOError getIo() { return this.io; } public getRow_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case SUCCESS: if (value == null) { unsetSuccess(); } else { setSuccess((List<TRowResult>)value); } break; case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case SUCCESS: return getSuccess(); case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case SUCCESS: return isSetSuccess(); case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof getRow_result) return this.equals((getRow_result)that); return false; } public boolean equals(getRow_result that) { if (that == null) return false; boolean this_present_success = true && this.isSetSuccess(); boolean that_present_success = true && that.isSetSuccess(); if (this_present_success || that_present_success) { if (!(this_present_success && that_present_success)) return false; if (!this.success.equals(that.success)) return false; } boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_success = true && (isSetSuccess()); list.add(present_success); if (present_success) list.add(success); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(getRow_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess()); if (lastComparison != 0) { return lastComparison; } if (isSetSuccess()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("getRow_result("); boolean first = true; sb.append("success:"); if (this.success == null) { sb.append("null"); } else { sb.append(this.success); } first = false; if (!first) sb.append(", "); sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class getRow_resultStandardSchemeFactory implements SchemeFactory { public getRow_resultStandardScheme getScheme() { return new getRow_resultStandardScheme(); } } private static class getRow_resultStandardScheme extends StandardScheme<getRow_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, getRow_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list148 = iprot.readListBegin(); struct.success = new ArrayList<TRowResult>(_list148.size); TRowResult _elem149; for (int _i150 = 0; _i150 < _list148.size; ++_i150) { _elem149 = new TRowResult(); _elem149.read(iprot); struct.success.add(_elem149); } iprot.readListEnd(); } struct.setSuccessIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, getRow_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.success != null) { oprot.writeFieldBegin(SUCCESS_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size())); for (TRowResult _iter151 : struct.success) { _iter151.write(oprot); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class getRow_resultTupleSchemeFactory implements SchemeFactory { public getRow_resultTupleScheme getScheme() { return new getRow_resultTupleScheme(); } } private static class getRow_resultTupleScheme extends TupleScheme<getRow_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, getRow_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetSuccess()) { optionals.set(0); } if (struct.isSetIo()) { optionals.set(1); } oprot.writeBitSet(optionals, 2); if (struct.isSetSuccess()) { { oprot.writeI32(struct.success.size()); for (TRowResult _iter152 : struct.success) { _iter152.write(oprot); } } } if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, getRow_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { { org.apache.thrift.protocol.TList _list153 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32()); struct.success = new ArrayList<TRowResult>(_list153.size); TRowResult _elem154; for (int _i155 = 0; _i155 < _list153.size; ++_i155) { _elem154 = new TRowResult(); _elem154.read(iprot); struct.success.add(_elem154); } } struct.setSuccessIsSet(true); } if (incoming.get(1)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class getRowWithColumns_args implements org.apache.thrift.TBase<getRowWithColumns_args, getRowWithColumns_args._Fields>, java.io.Serializable, Cloneable, Comparable<getRowWithColumns_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getRowWithColumns_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final org.apache.thrift.protocol.TField ROW_FIELD_DESC = new org.apache.thrift.protocol.TField("row", org.apache.thrift.protocol.TType.STRING, (short)2); private static final org.apache.thrift.protocol.TField COLUMNS_FIELD_DESC = new org.apache.thrift.protocol.TField("columns", org.apache.thrift.protocol.TType.LIST, (short)3); private static final org.apache.thrift.protocol.TField ATTRIBUTES_FIELD_DESC = new org.apache.thrift.protocol.TField("attributes", org.apache.thrift.protocol.TType.MAP, (short)4); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new getRowWithColumns_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new getRowWithColumns_argsTupleSchemeFactory()); } /** * name of table */ public ByteBuffer tableName; // required /** * row key */ public ByteBuffer row; // required /** * List of columns to return, null for all columns */ public List<ByteBuffer> columns; // required /** * Get attributes */ public Map<ByteBuffer,ByteBuffer> attributes; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * name of table */ TABLE_NAME((short)1, "tableName"), /** * row key */ ROW((short)2, "row"), /** * List of columns to return, null for all columns */ COLUMNS((short)3, "columns"), /** * Get attributes */ ATTRIBUTES((short)4, "attributes"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; case 2: // ROW return ROW; case 3: // COLUMNS return COLUMNS; case 4: // ATTRIBUTES return ATTRIBUTES; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.ROW, new org.apache.thrift.meta_data.FieldMetaData("row", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.COLUMNS, new org.apache.thrift.meta_data.FieldMetaData("columns", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); tmpMap.put(_Fields.ATTRIBUTES, new org.apache.thrift.meta_data.FieldMetaData("attributes", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.MapMetaData(org.apache.thrift.protocol.TType.MAP, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"), new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(getRowWithColumns_args.class, metaDataMap); } public getRowWithColumns_args() { } public getRowWithColumns_args( ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); this.row = org.apache.thrift.TBaseHelper.copyBinary(row); this.columns = columns; this.attributes = attributes; } /** * Performs a deep copy on <i>other</i>. */ public getRowWithColumns_args(getRowWithColumns_args other) { if (other.isSetTableName()) { this.tableName = other.tableName; } if (other.isSetRow()) { this.row = other.row; } if (other.isSetColumns()) { List<ByteBuffer> __this__columns = new ArrayList<ByteBuffer>(other.columns.size()); for (ByteBuffer other_element : other.columns) { __this__columns.add(other_element); } this.columns = __this__columns; } if (other.isSetAttributes()) { Map<ByteBuffer,ByteBuffer> __this__attributes = new HashMap<ByteBuffer,ByteBuffer>(other.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> other_element : other.attributes.entrySet()) { ByteBuffer other_element_key = other_element.getKey(); ByteBuffer other_element_value = other_element.getValue(); ByteBuffer __this__attributes_copy_key = other_element_key; ByteBuffer __this__attributes_copy_value = other_element_value; __this__attributes.put(__this__attributes_copy_key, __this__attributes_copy_value); } this.attributes = __this__attributes; } } public getRowWithColumns_args deepCopy() { return new getRowWithColumns_args(this); } @Override public void clear() { this.tableName = null; this.row = null; this.columns = null; this.attributes = null; } /** * name of table */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * name of table */ public getRowWithColumns_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public getRowWithColumns_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } /** * row key */ public byte[] getRow() { setRow(org.apache.thrift.TBaseHelper.rightSize(row)); return row == null ? null : row.array(); } public ByteBuffer bufferForRow() { return org.apache.thrift.TBaseHelper.copyBinary(row); } /** * row key */ public getRowWithColumns_args setRow(byte[] row) { this.row = row == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(row, row.length)); return this; } public getRowWithColumns_args setRow(ByteBuffer row) { this.row = org.apache.thrift.TBaseHelper.copyBinary(row); return this; } public void unsetRow() { this.row = null; } /** Returns true if field row is set (has been assigned a value) and false otherwise */ public boolean isSetRow() { return this.row != null; } public void setRowIsSet(boolean value) { if (!value) { this.row = null; } } public int getColumnsSize() { return (this.columns == null) ? 0 : this.columns.size(); } public java.util.Iterator<ByteBuffer> getColumnsIterator() { return (this.columns == null) ? null : this.columns.iterator(); } public void addToColumns(ByteBuffer elem) { if (this.columns == null) { this.columns = new ArrayList<ByteBuffer>(); } this.columns.add(elem); } /** * List of columns to return, null for all columns */ public List<ByteBuffer> getColumns() { return this.columns; } /** * List of columns to return, null for all columns */ public getRowWithColumns_args setColumns(List<ByteBuffer> columns) { this.columns = columns; return this; } public void unsetColumns() { this.columns = null; } /** Returns true if field columns is set (has been assigned a value) and false otherwise */ public boolean isSetColumns() { return this.columns != null; } public void setColumnsIsSet(boolean value) { if (!value) { this.columns = null; } } public int getAttributesSize() { return (this.attributes == null) ? 0 : this.attributes.size(); } public void putToAttributes(ByteBuffer key, ByteBuffer val) { if (this.attributes == null) { this.attributes = new HashMap<ByteBuffer,ByteBuffer>(); } this.attributes.put(key, val); } /** * Get attributes */ public Map<ByteBuffer,ByteBuffer> getAttributes() { return this.attributes; } /** * Get attributes */ public getRowWithColumns_args setAttributes(Map<ByteBuffer,ByteBuffer> attributes) { this.attributes = attributes; return this; } public void unsetAttributes() { this.attributes = null; } /** Returns true if field attributes is set (has been assigned a value) and false otherwise */ public boolean isSetAttributes() { return this.attributes != null; } public void setAttributesIsSet(boolean value) { if (!value) { this.attributes = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; case ROW: if (value == null) { unsetRow(); } else { setRow((ByteBuffer)value); } break; case COLUMNS: if (value == null) { unsetColumns(); } else { setColumns((List<ByteBuffer>)value); } break; case ATTRIBUTES: if (value == null) { unsetAttributes(); } else { setAttributes((Map<ByteBuffer,ByteBuffer>)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); case ROW: return getRow(); case COLUMNS: return getColumns(); case ATTRIBUTES: return getAttributes(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); case ROW: return isSetRow(); case COLUMNS: return isSetColumns(); case ATTRIBUTES: return isSetAttributes(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof getRowWithColumns_args) return this.equals((getRowWithColumns_args)that); return false; } public boolean equals(getRowWithColumns_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } boolean this_present_row = true && this.isSetRow(); boolean that_present_row = true && that.isSetRow(); if (this_present_row || that_present_row) { if (!(this_present_row && that_present_row)) return false; if (!this.row.equals(that.row)) return false; } boolean this_present_columns = true && this.isSetColumns(); boolean that_present_columns = true && that.isSetColumns(); if (this_present_columns || that_present_columns) { if (!(this_present_columns && that_present_columns)) return false; if (!this.columns.equals(that.columns)) return false; } boolean this_present_attributes = true && this.isSetAttributes(); boolean that_present_attributes = true && that.isSetAttributes(); if (this_present_attributes || that_present_attributes) { if (!(this_present_attributes && that_present_attributes)) return false; if (!this.attributes.equals(that.attributes)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); boolean present_row = true && (isSetRow()); list.add(present_row); if (present_row) list.add(row); boolean present_columns = true && (isSetColumns()); list.add(present_columns); if (present_columns) list.add(columns); boolean present_attributes = true && (isSetAttributes()); list.add(present_attributes); if (present_attributes) list.add(attributes); return list.hashCode(); } @Override public int compareTo(getRowWithColumns_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetRow()).compareTo(other.isSetRow()); if (lastComparison != 0) { return lastComparison; } if (isSetRow()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.row, other.row); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetColumns()).compareTo(other.isSetColumns()); if (lastComparison != 0) { return lastComparison; } if (isSetColumns()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.columns, other.columns); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetAttributes()).compareTo(other.isSetAttributes()); if (lastComparison != 0) { return lastComparison; } if (isSetAttributes()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.attributes, other.attributes); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("getRowWithColumns_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; if (!first) sb.append(", "); sb.append("row:"); if (this.row == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.row, sb); } first = false; if (!first) sb.append(", "); sb.append("columns:"); if (this.columns == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.columns, sb); } first = false; if (!first) sb.append(", "); sb.append("attributes:"); if (this.attributes == null) { sb.append("null"); } else { sb.append(this.attributes); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class getRowWithColumns_argsStandardSchemeFactory implements SchemeFactory { public getRowWithColumns_argsStandardScheme getScheme() { return new getRowWithColumns_argsStandardScheme(); } } private static class getRowWithColumns_argsStandardScheme extends StandardScheme<getRowWithColumns_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, getRowWithColumns_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // ROW if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.row = iprot.readBinary(); struct.setRowIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 3: // COLUMNS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list156 = iprot.readListBegin(); struct.columns = new ArrayList<ByteBuffer>(_list156.size); ByteBuffer _elem157; for (int _i158 = 0; _i158 < _list156.size; ++_i158) { _elem157 = iprot.readBinary(); struct.columns.add(_elem157); } iprot.readListEnd(); } struct.setColumnsIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 4: // ATTRIBUTES if (schemeField.type == org.apache.thrift.protocol.TType.MAP) { { org.apache.thrift.protocol.TMap _map159 = iprot.readMapBegin(); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map159.size); ByteBuffer _key160; ByteBuffer _val161; for (int _i162 = 0; _i162 < _map159.size; ++_i162) { _key160 = iprot.readBinary(); _val161 = iprot.readBinary(); struct.attributes.put(_key160, _val161); } iprot.readMapEnd(); } struct.setAttributesIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, getRowWithColumns_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } if (struct.row != null) { oprot.writeFieldBegin(ROW_FIELD_DESC); oprot.writeBinary(struct.row); oprot.writeFieldEnd(); } if (struct.columns != null) { oprot.writeFieldBegin(COLUMNS_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.columns.size())); for (ByteBuffer _iter163 : struct.columns) { oprot.writeBinary(_iter163); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } if (struct.attributes != null) { oprot.writeFieldBegin(ATTRIBUTES_FIELD_DESC); { oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, struct.attributes.size())); for (Map.Entry<ByteBuffer, ByteBuffer> _iter164 : struct.attributes.entrySet()) { oprot.writeBinary(_iter164.getKey()); oprot.writeBinary(_iter164.getValue()); } oprot.writeMapEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class getRowWithColumns_argsTupleSchemeFactory implements SchemeFactory { public getRowWithColumns_argsTupleScheme getScheme() { return new getRowWithColumns_argsTupleScheme(); } } private static class getRowWithColumns_argsTupleScheme extends TupleScheme<getRowWithColumns_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, getRowWithColumns_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } if (struct.isSetRow()) { optionals.set(1); } if (struct.isSetColumns()) { optionals.set(2); } if (struct.isSetAttributes()) { optionals.set(3); } oprot.writeBitSet(optionals, 4); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } if (struct.isSetRow()) { oprot.writeBinary(struct.row); } if (struct.isSetColumns()) { { oprot.writeI32(struct.columns.size()); for (ByteBuffer _iter165 : struct.columns) { oprot.writeBinary(_iter165); } } } if (struct.isSetAttributes()) { { oprot.writeI32(struct.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> _iter166 : struct.attributes.entrySet()) { oprot.writeBinary(_iter166.getKey()); oprot.writeBinary(_iter166.getValue()); } } } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, getRowWithColumns_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(4); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } if (incoming.get(1)) { struct.row = iprot.readBinary(); struct.setRowIsSet(true); } if (incoming.get(2)) { { org.apache.thrift.protocol.TList _list167 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.columns = new ArrayList<ByteBuffer>(_list167.size); ByteBuffer _elem168; for (int _i169 = 0; _i169 < _list167.size; ++_i169) { _elem168 = iprot.readBinary(); struct.columns.add(_elem168); } } struct.setColumnsIsSet(true); } if (incoming.get(3)) { { org.apache.thrift.protocol.TMap _map170 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map170.size); ByteBuffer _key171; ByteBuffer _val172; for (int _i173 = 0; _i173 < _map170.size; ++_i173) { _key171 = iprot.readBinary(); _val172 = iprot.readBinary(); struct.attributes.put(_key171, _val172); } } struct.setAttributesIsSet(true); } } } } public static class getRowWithColumns_result implements org.apache.thrift.TBase<getRowWithColumns_result, getRowWithColumns_result._Fields>, java.io.Serializable, Cloneable, Comparable<getRowWithColumns_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getRowWithColumns_result"); private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.LIST, (short)0); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new getRowWithColumns_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new getRowWithColumns_resultTupleSchemeFactory()); } public List<TRowResult> success; // required public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { SUCCESS((short)0, "success"), IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 0: // SUCCESS return SUCCESS; case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.SUCCESS, new org.apache.thrift.meta_data.FieldMetaData("success", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, TRowResult.class)))); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(getRowWithColumns_result.class, metaDataMap); } public getRowWithColumns_result() { } public getRowWithColumns_result( List<TRowResult> success, IOError io) { this(); this.success = success; this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public getRowWithColumns_result(getRowWithColumns_result other) { if (other.isSetSuccess()) { List<TRowResult> __this__success = new ArrayList<TRowResult>(other.success.size()); for (TRowResult other_element : other.success) { __this__success.add(new TRowResult(other_element)); } this.success = __this__success; } if (other.isSetIo()) { this.io = new IOError(other.io); } } public getRowWithColumns_result deepCopy() { return new getRowWithColumns_result(this); } @Override public void clear() { this.success = null; this.io = null; } public int getSuccessSize() { return (this.success == null) ? 0 : this.success.size(); } public java.util.Iterator<TRowResult> getSuccessIterator() { return (this.success == null) ? null : this.success.iterator(); } public void addToSuccess(TRowResult elem) { if (this.success == null) { this.success = new ArrayList<TRowResult>(); } this.success.add(elem); } public List<TRowResult> getSuccess() { return this.success; } public getRowWithColumns_result setSuccess(List<TRowResult> success) { this.success = success; return this; } public void unsetSuccess() { this.success = null; } /** Returns true if field success is set (has been assigned a value) and false otherwise */ public boolean isSetSuccess() { return this.success != null; } public void setSuccessIsSet(boolean value) { if (!value) { this.success = null; } } public IOError getIo() { return this.io; } public getRowWithColumns_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case SUCCESS: if (value == null) { unsetSuccess(); } else { setSuccess((List<TRowResult>)value); } break; case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case SUCCESS: return getSuccess(); case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case SUCCESS: return isSetSuccess(); case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof getRowWithColumns_result) return this.equals((getRowWithColumns_result)that); return false; } public boolean equals(getRowWithColumns_result that) { if (that == null) return false; boolean this_present_success = true && this.isSetSuccess(); boolean that_present_success = true && that.isSetSuccess(); if (this_present_success || that_present_success) { if (!(this_present_success && that_present_success)) return false; if (!this.success.equals(that.success)) return false; } boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_success = true && (isSetSuccess()); list.add(present_success); if (present_success) list.add(success); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(getRowWithColumns_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess()); if (lastComparison != 0) { return lastComparison; } if (isSetSuccess()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("getRowWithColumns_result("); boolean first = true; sb.append("success:"); if (this.success == null) { sb.append("null"); } else { sb.append(this.success); } first = false; if (!first) sb.append(", "); sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class getRowWithColumns_resultStandardSchemeFactory implements SchemeFactory { public getRowWithColumns_resultStandardScheme getScheme() { return new getRowWithColumns_resultStandardScheme(); } } private static class getRowWithColumns_resultStandardScheme extends StandardScheme<getRowWithColumns_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, getRowWithColumns_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list174 = iprot.readListBegin(); struct.success = new ArrayList<TRowResult>(_list174.size); TRowResult _elem175; for (int _i176 = 0; _i176 < _list174.size; ++_i176) { _elem175 = new TRowResult(); _elem175.read(iprot); struct.success.add(_elem175); } iprot.readListEnd(); } struct.setSuccessIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, getRowWithColumns_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.success != null) { oprot.writeFieldBegin(SUCCESS_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size())); for (TRowResult _iter177 : struct.success) { _iter177.write(oprot); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class getRowWithColumns_resultTupleSchemeFactory implements SchemeFactory { public getRowWithColumns_resultTupleScheme getScheme() { return new getRowWithColumns_resultTupleScheme(); } } private static class getRowWithColumns_resultTupleScheme extends TupleScheme<getRowWithColumns_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, getRowWithColumns_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetSuccess()) { optionals.set(0); } if (struct.isSetIo()) { optionals.set(1); } oprot.writeBitSet(optionals, 2); if (struct.isSetSuccess()) { { oprot.writeI32(struct.success.size()); for (TRowResult _iter178 : struct.success) { _iter178.write(oprot); } } } if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, getRowWithColumns_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { { org.apache.thrift.protocol.TList _list179 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32()); struct.success = new ArrayList<TRowResult>(_list179.size); TRowResult _elem180; for (int _i181 = 0; _i181 < _list179.size; ++_i181) { _elem180 = new TRowResult(); _elem180.read(iprot); struct.success.add(_elem180); } } struct.setSuccessIsSet(true); } if (incoming.get(1)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class getRowTs_args implements org.apache.thrift.TBase<getRowTs_args, getRowTs_args._Fields>, java.io.Serializable, Cloneable, Comparable<getRowTs_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getRowTs_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final org.apache.thrift.protocol.TField ROW_FIELD_DESC = new org.apache.thrift.protocol.TField("row", org.apache.thrift.protocol.TType.STRING, (short)2); private static final org.apache.thrift.protocol.TField TIMESTAMP_FIELD_DESC = new org.apache.thrift.protocol.TField("timestamp", org.apache.thrift.protocol.TType.I64, (short)3); private static final org.apache.thrift.protocol.TField ATTRIBUTES_FIELD_DESC = new org.apache.thrift.protocol.TField("attributes", org.apache.thrift.protocol.TType.MAP, (short)4); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new getRowTs_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new getRowTs_argsTupleSchemeFactory()); } /** * name of the table */ public ByteBuffer tableName; // required /** * row key */ public ByteBuffer row; // required /** * timestamp */ public long timestamp; // required /** * Get attributes */ public Map<ByteBuffer,ByteBuffer> attributes; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * name of the table */ TABLE_NAME((short)1, "tableName"), /** * row key */ ROW((short)2, "row"), /** * timestamp */ TIMESTAMP((short)3, "timestamp"), /** * Get attributes */ ATTRIBUTES((short)4, "attributes"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; case 2: // ROW return ROW; case 3: // TIMESTAMP return TIMESTAMP; case 4: // ATTRIBUTES return ATTRIBUTES; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments private static final int __TIMESTAMP_ISSET_ID = 0; private byte __isset_bitfield = 0; public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.ROW, new org.apache.thrift.meta_data.FieldMetaData("row", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.TIMESTAMP, new org.apache.thrift.meta_data.FieldMetaData("timestamp", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.I64))); tmpMap.put(_Fields.ATTRIBUTES, new org.apache.thrift.meta_data.FieldMetaData("attributes", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.MapMetaData(org.apache.thrift.protocol.TType.MAP, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"), new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(getRowTs_args.class, metaDataMap); } public getRowTs_args() { } public getRowTs_args( ByteBuffer tableName, ByteBuffer row, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); this.row = org.apache.thrift.TBaseHelper.copyBinary(row); this.timestamp = timestamp; setTimestampIsSet(true); this.attributes = attributes; } /** * Performs a deep copy on <i>other</i>. */ public getRowTs_args(getRowTs_args other) { __isset_bitfield = other.__isset_bitfield; if (other.isSetTableName()) { this.tableName = other.tableName; } if (other.isSetRow()) { this.row = other.row; } this.timestamp = other.timestamp; if (other.isSetAttributes()) { Map<ByteBuffer,ByteBuffer> __this__attributes = new HashMap<ByteBuffer,ByteBuffer>(other.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> other_element : other.attributes.entrySet()) { ByteBuffer other_element_key = other_element.getKey(); ByteBuffer other_element_value = other_element.getValue(); ByteBuffer __this__attributes_copy_key = other_element_key; ByteBuffer __this__attributes_copy_value = other_element_value; __this__attributes.put(__this__attributes_copy_key, __this__attributes_copy_value); } this.attributes = __this__attributes; } } public getRowTs_args deepCopy() { return new getRowTs_args(this); } @Override public void clear() { this.tableName = null; this.row = null; setTimestampIsSet(false); this.timestamp = 0; this.attributes = null; } /** * name of the table */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * name of the table */ public getRowTs_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public getRowTs_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } /** * row key */ public byte[] getRow() { setRow(org.apache.thrift.TBaseHelper.rightSize(row)); return row == null ? null : row.array(); } public ByteBuffer bufferForRow() { return org.apache.thrift.TBaseHelper.copyBinary(row); } /** * row key */ public getRowTs_args setRow(byte[] row) { this.row = row == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(row, row.length)); return this; } public getRowTs_args setRow(ByteBuffer row) { this.row = org.apache.thrift.TBaseHelper.copyBinary(row); return this; } public void unsetRow() { this.row = null; } /** Returns true if field row is set (has been assigned a value) and false otherwise */ public boolean isSetRow() { return this.row != null; } public void setRowIsSet(boolean value) { if (!value) { this.row = null; } } /** * timestamp */ public long getTimestamp() { return this.timestamp; } /** * timestamp */ public getRowTs_args setTimestamp(long timestamp) { this.timestamp = timestamp; setTimestampIsSet(true); return this; } public void unsetTimestamp() { __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __TIMESTAMP_ISSET_ID); } /** Returns true if field timestamp is set (has been assigned a value) and false otherwise */ public boolean isSetTimestamp() { return EncodingUtils.testBit(__isset_bitfield, __TIMESTAMP_ISSET_ID); } public void setTimestampIsSet(boolean value) { __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __TIMESTAMP_ISSET_ID, value); } public int getAttributesSize() { return (this.attributes == null) ? 0 : this.attributes.size(); } public void putToAttributes(ByteBuffer key, ByteBuffer val) { if (this.attributes == null) { this.attributes = new HashMap<ByteBuffer,ByteBuffer>(); } this.attributes.put(key, val); } /** * Get attributes */ public Map<ByteBuffer,ByteBuffer> getAttributes() { return this.attributes; } /** * Get attributes */ public getRowTs_args setAttributes(Map<ByteBuffer,ByteBuffer> attributes) { this.attributes = attributes; return this; } public void unsetAttributes() { this.attributes = null; } /** Returns true if field attributes is set (has been assigned a value) and false otherwise */ public boolean isSetAttributes() { return this.attributes != null; } public void setAttributesIsSet(boolean value) { if (!value) { this.attributes = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; case ROW: if (value == null) { unsetRow(); } else { setRow((ByteBuffer)value); } break; case TIMESTAMP: if (value == null) { unsetTimestamp(); } else { setTimestamp((Long)value); } break; case ATTRIBUTES: if (value == null) { unsetAttributes(); } else { setAttributes((Map<ByteBuffer,ByteBuffer>)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); case ROW: return getRow(); case TIMESTAMP: return getTimestamp(); case ATTRIBUTES: return getAttributes(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); case ROW: return isSetRow(); case TIMESTAMP: return isSetTimestamp(); case ATTRIBUTES: return isSetAttributes(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof getRowTs_args) return this.equals((getRowTs_args)that); return false; } public boolean equals(getRowTs_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } boolean this_present_row = true && this.isSetRow(); boolean that_present_row = true && that.isSetRow(); if (this_present_row || that_present_row) { if (!(this_present_row && that_present_row)) return false; if (!this.row.equals(that.row)) return false; } boolean this_present_timestamp = true; boolean that_present_timestamp = true; if (this_present_timestamp || that_present_timestamp) { if (!(this_present_timestamp && that_present_timestamp)) return false; if (this.timestamp != that.timestamp) return false; } boolean this_present_attributes = true && this.isSetAttributes(); boolean that_present_attributes = true && that.isSetAttributes(); if (this_present_attributes || that_present_attributes) { if (!(this_present_attributes && that_present_attributes)) return false; if (!this.attributes.equals(that.attributes)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); boolean present_row = true && (isSetRow()); list.add(present_row); if (present_row) list.add(row); boolean present_timestamp = true; list.add(present_timestamp); if (present_timestamp) list.add(timestamp); boolean present_attributes = true && (isSetAttributes()); list.add(present_attributes); if (present_attributes) list.add(attributes); return list.hashCode(); } @Override public int compareTo(getRowTs_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetRow()).compareTo(other.isSetRow()); if (lastComparison != 0) { return lastComparison; } if (isSetRow()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.row, other.row); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetTimestamp()).compareTo(other.isSetTimestamp()); if (lastComparison != 0) { return lastComparison; } if (isSetTimestamp()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.timestamp, other.timestamp); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetAttributes()).compareTo(other.isSetAttributes()); if (lastComparison != 0) { return lastComparison; } if (isSetAttributes()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.attributes, other.attributes); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("getRowTs_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; if (!first) sb.append(", "); sb.append("row:"); if (this.row == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.row, sb); } first = false; if (!first) sb.append(", "); sb.append("timestamp:"); sb.append(this.timestamp); first = false; if (!first) sb.append(", "); sb.append("attributes:"); if (this.attributes == null) { sb.append("null"); } else { sb.append(this.attributes); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { // it doesn't seem like you should have to do this, but java serialization is wacky, and doesn't call the default constructor. __isset_bitfield = 0; read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class getRowTs_argsStandardSchemeFactory implements SchemeFactory { public getRowTs_argsStandardScheme getScheme() { return new getRowTs_argsStandardScheme(); } } private static class getRowTs_argsStandardScheme extends StandardScheme<getRowTs_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, getRowTs_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // ROW if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.row = iprot.readBinary(); struct.setRowIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 3: // TIMESTAMP if (schemeField.type == org.apache.thrift.protocol.TType.I64) { struct.timestamp = iprot.readI64(); struct.setTimestampIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 4: // ATTRIBUTES if (schemeField.type == org.apache.thrift.protocol.TType.MAP) { { org.apache.thrift.protocol.TMap _map182 = iprot.readMapBegin(); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map182.size); ByteBuffer _key183; ByteBuffer _val184; for (int _i185 = 0; _i185 < _map182.size; ++_i185) { _key183 = iprot.readBinary(); _val184 = iprot.readBinary(); struct.attributes.put(_key183, _val184); } iprot.readMapEnd(); } struct.setAttributesIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, getRowTs_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } if (struct.row != null) { oprot.writeFieldBegin(ROW_FIELD_DESC); oprot.writeBinary(struct.row); oprot.writeFieldEnd(); } oprot.writeFieldBegin(TIMESTAMP_FIELD_DESC); oprot.writeI64(struct.timestamp); oprot.writeFieldEnd(); if (struct.attributes != null) { oprot.writeFieldBegin(ATTRIBUTES_FIELD_DESC); { oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, struct.attributes.size())); for (Map.Entry<ByteBuffer, ByteBuffer> _iter186 : struct.attributes.entrySet()) { oprot.writeBinary(_iter186.getKey()); oprot.writeBinary(_iter186.getValue()); } oprot.writeMapEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class getRowTs_argsTupleSchemeFactory implements SchemeFactory { public getRowTs_argsTupleScheme getScheme() { return new getRowTs_argsTupleScheme(); } } private static class getRowTs_argsTupleScheme extends TupleScheme<getRowTs_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, getRowTs_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } if (struct.isSetRow()) { optionals.set(1); } if (struct.isSetTimestamp()) { optionals.set(2); } if (struct.isSetAttributes()) { optionals.set(3); } oprot.writeBitSet(optionals, 4); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } if (struct.isSetRow()) { oprot.writeBinary(struct.row); } if (struct.isSetTimestamp()) { oprot.writeI64(struct.timestamp); } if (struct.isSetAttributes()) { { oprot.writeI32(struct.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> _iter187 : struct.attributes.entrySet()) { oprot.writeBinary(_iter187.getKey()); oprot.writeBinary(_iter187.getValue()); } } } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, getRowTs_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(4); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } if (incoming.get(1)) { struct.row = iprot.readBinary(); struct.setRowIsSet(true); } if (incoming.get(2)) { struct.timestamp = iprot.readI64(); struct.setTimestampIsSet(true); } if (incoming.get(3)) { { org.apache.thrift.protocol.TMap _map188 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map188.size); ByteBuffer _key189; ByteBuffer _val190; for (int _i191 = 0; _i191 < _map188.size; ++_i191) { _key189 = iprot.readBinary(); _val190 = iprot.readBinary(); struct.attributes.put(_key189, _val190); } } struct.setAttributesIsSet(true); } } } } public static class getRowTs_result implements org.apache.thrift.TBase<getRowTs_result, getRowTs_result._Fields>, java.io.Serializable, Cloneable, Comparable<getRowTs_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getRowTs_result"); private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.LIST, (short)0); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new getRowTs_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new getRowTs_resultTupleSchemeFactory()); } public List<TRowResult> success; // required public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { SUCCESS((short)0, "success"), IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 0: // SUCCESS return SUCCESS; case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.SUCCESS, new org.apache.thrift.meta_data.FieldMetaData("success", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, TRowResult.class)))); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(getRowTs_result.class, metaDataMap); } public getRowTs_result() { } public getRowTs_result( List<TRowResult> success, IOError io) { this(); this.success = success; this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public getRowTs_result(getRowTs_result other) { if (other.isSetSuccess()) { List<TRowResult> __this__success = new ArrayList<TRowResult>(other.success.size()); for (TRowResult other_element : other.success) { __this__success.add(new TRowResult(other_element)); } this.success = __this__success; } if (other.isSetIo()) { this.io = new IOError(other.io); } } public getRowTs_result deepCopy() { return new getRowTs_result(this); } @Override public void clear() { this.success = null; this.io = null; } public int getSuccessSize() { return (this.success == null) ? 0 : this.success.size(); } public java.util.Iterator<TRowResult> getSuccessIterator() { return (this.success == null) ? null : this.success.iterator(); } public void addToSuccess(TRowResult elem) { if (this.success == null) { this.success = new ArrayList<TRowResult>(); } this.success.add(elem); } public List<TRowResult> getSuccess() { return this.success; } public getRowTs_result setSuccess(List<TRowResult> success) { this.success = success; return this; } public void unsetSuccess() { this.success = null; } /** Returns true if field success is set (has been assigned a value) and false otherwise */ public boolean isSetSuccess() { return this.success != null; } public void setSuccessIsSet(boolean value) { if (!value) { this.success = null; } } public IOError getIo() { return this.io; } public getRowTs_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case SUCCESS: if (value == null) { unsetSuccess(); } else { setSuccess((List<TRowResult>)value); } break; case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case SUCCESS: return getSuccess(); case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case SUCCESS: return isSetSuccess(); case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof getRowTs_result) return this.equals((getRowTs_result)that); return false; } public boolean equals(getRowTs_result that) { if (that == null) return false; boolean this_present_success = true && this.isSetSuccess(); boolean that_present_success = true && that.isSetSuccess(); if (this_present_success || that_present_success) { if (!(this_present_success && that_present_success)) return false; if (!this.success.equals(that.success)) return false; } boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_success = true && (isSetSuccess()); list.add(present_success); if (present_success) list.add(success); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(getRowTs_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess()); if (lastComparison != 0) { return lastComparison; } if (isSetSuccess()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("getRowTs_result("); boolean first = true; sb.append("success:"); if (this.success == null) { sb.append("null"); } else { sb.append(this.success); } first = false; if (!first) sb.append(", "); sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class getRowTs_resultStandardSchemeFactory implements SchemeFactory { public getRowTs_resultStandardScheme getScheme() { return new getRowTs_resultStandardScheme(); } } private static class getRowTs_resultStandardScheme extends StandardScheme<getRowTs_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, getRowTs_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list192 = iprot.readListBegin(); struct.success = new ArrayList<TRowResult>(_list192.size); TRowResult _elem193; for (int _i194 = 0; _i194 < _list192.size; ++_i194) { _elem193 = new TRowResult(); _elem193.read(iprot); struct.success.add(_elem193); } iprot.readListEnd(); } struct.setSuccessIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, getRowTs_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.success != null) { oprot.writeFieldBegin(SUCCESS_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size())); for (TRowResult _iter195 : struct.success) { _iter195.write(oprot); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class getRowTs_resultTupleSchemeFactory implements SchemeFactory { public getRowTs_resultTupleScheme getScheme() { return new getRowTs_resultTupleScheme(); } } private static class getRowTs_resultTupleScheme extends TupleScheme<getRowTs_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, getRowTs_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetSuccess()) { optionals.set(0); } if (struct.isSetIo()) { optionals.set(1); } oprot.writeBitSet(optionals, 2); if (struct.isSetSuccess()) { { oprot.writeI32(struct.success.size()); for (TRowResult _iter196 : struct.success) { _iter196.write(oprot); } } } if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, getRowTs_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { { org.apache.thrift.protocol.TList _list197 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32()); struct.success = new ArrayList<TRowResult>(_list197.size); TRowResult _elem198; for (int _i199 = 0; _i199 < _list197.size; ++_i199) { _elem198 = new TRowResult(); _elem198.read(iprot); struct.success.add(_elem198); } } struct.setSuccessIsSet(true); } if (incoming.get(1)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class getRowWithColumnsTs_args implements org.apache.thrift.TBase<getRowWithColumnsTs_args, getRowWithColumnsTs_args._Fields>, java.io.Serializable, Cloneable, Comparable<getRowWithColumnsTs_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getRowWithColumnsTs_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final org.apache.thrift.protocol.TField ROW_FIELD_DESC = new org.apache.thrift.protocol.TField("row", org.apache.thrift.protocol.TType.STRING, (short)2); private static final org.apache.thrift.protocol.TField COLUMNS_FIELD_DESC = new org.apache.thrift.protocol.TField("columns", org.apache.thrift.protocol.TType.LIST, (short)3); private static final org.apache.thrift.protocol.TField TIMESTAMP_FIELD_DESC = new org.apache.thrift.protocol.TField("timestamp", org.apache.thrift.protocol.TType.I64, (short)4); private static final org.apache.thrift.protocol.TField ATTRIBUTES_FIELD_DESC = new org.apache.thrift.protocol.TField("attributes", org.apache.thrift.protocol.TType.MAP, (short)5); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new getRowWithColumnsTs_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new getRowWithColumnsTs_argsTupleSchemeFactory()); } /** * name of table */ public ByteBuffer tableName; // required /** * row key */ public ByteBuffer row; // required /** * List of columns to return, null for all columns */ public List<ByteBuffer> columns; // required public long timestamp; // required /** * Get attributes */ public Map<ByteBuffer,ByteBuffer> attributes; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * name of table */ TABLE_NAME((short)1, "tableName"), /** * row key */ ROW((short)2, "row"), /** * List of columns to return, null for all columns */ COLUMNS((short)3, "columns"), TIMESTAMP((short)4, "timestamp"), /** * Get attributes */ ATTRIBUTES((short)5, "attributes"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; case 2: // ROW return ROW; case 3: // COLUMNS return COLUMNS; case 4: // TIMESTAMP return TIMESTAMP; case 5: // ATTRIBUTES return ATTRIBUTES; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments private static final int __TIMESTAMP_ISSET_ID = 0; private byte __isset_bitfield = 0; public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.ROW, new org.apache.thrift.meta_data.FieldMetaData("row", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.COLUMNS, new org.apache.thrift.meta_data.FieldMetaData("columns", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); tmpMap.put(_Fields.TIMESTAMP, new org.apache.thrift.meta_data.FieldMetaData("timestamp", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.I64))); tmpMap.put(_Fields.ATTRIBUTES, new org.apache.thrift.meta_data.FieldMetaData("attributes", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.MapMetaData(org.apache.thrift.protocol.TType.MAP, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"), new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(getRowWithColumnsTs_args.class, metaDataMap); } public getRowWithColumnsTs_args() { } public getRowWithColumnsTs_args( ByteBuffer tableName, ByteBuffer row, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); this.row = org.apache.thrift.TBaseHelper.copyBinary(row); this.columns = columns; this.timestamp = timestamp; setTimestampIsSet(true); this.attributes = attributes; } /** * Performs a deep copy on <i>other</i>. */ public getRowWithColumnsTs_args(getRowWithColumnsTs_args other) { __isset_bitfield = other.__isset_bitfield; if (other.isSetTableName()) { this.tableName = other.tableName; } if (other.isSetRow()) { this.row = other.row; } if (other.isSetColumns()) { List<ByteBuffer> __this__columns = new ArrayList<ByteBuffer>(other.columns.size()); for (ByteBuffer other_element : other.columns) { __this__columns.add(other_element); } this.columns = __this__columns; } this.timestamp = other.timestamp; if (other.isSetAttributes()) { Map<ByteBuffer,ByteBuffer> __this__attributes = new HashMap<ByteBuffer,ByteBuffer>(other.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> other_element : other.attributes.entrySet()) { ByteBuffer other_element_key = other_element.getKey(); ByteBuffer other_element_value = other_element.getValue(); ByteBuffer __this__attributes_copy_key = other_element_key; ByteBuffer __this__attributes_copy_value = other_element_value; __this__attributes.put(__this__attributes_copy_key, __this__attributes_copy_value); } this.attributes = __this__attributes; } } public getRowWithColumnsTs_args deepCopy() { return new getRowWithColumnsTs_args(this); } @Override public void clear() { this.tableName = null; this.row = null; this.columns = null; setTimestampIsSet(false); this.timestamp = 0; this.attributes = null; } /** * name of table */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * name of table */ public getRowWithColumnsTs_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public getRowWithColumnsTs_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } /** * row key */ public byte[] getRow() { setRow(org.apache.thrift.TBaseHelper.rightSize(row)); return row == null ? null : row.array(); } public ByteBuffer bufferForRow() { return org.apache.thrift.TBaseHelper.copyBinary(row); } /** * row key */ public getRowWithColumnsTs_args setRow(byte[] row) { this.row = row == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(row, row.length)); return this; } public getRowWithColumnsTs_args setRow(ByteBuffer row) { this.row = org.apache.thrift.TBaseHelper.copyBinary(row); return this; } public void unsetRow() { this.row = null; } /** Returns true if field row is set (has been assigned a value) and false otherwise */ public boolean isSetRow() { return this.row != null; } public void setRowIsSet(boolean value) { if (!value) { this.row = null; } } public int getColumnsSize() { return (this.columns == null) ? 0 : this.columns.size(); } public java.util.Iterator<ByteBuffer> getColumnsIterator() { return (this.columns == null) ? null : this.columns.iterator(); } public void addToColumns(ByteBuffer elem) { if (this.columns == null) { this.columns = new ArrayList<ByteBuffer>(); } this.columns.add(elem); } /** * List of columns to return, null for all columns */ public List<ByteBuffer> getColumns() { return this.columns; } /** * List of columns to return, null for all columns */ public getRowWithColumnsTs_args setColumns(List<ByteBuffer> columns) { this.columns = columns; return this; } public void unsetColumns() { this.columns = null; } /** Returns true if field columns is set (has been assigned a value) and false otherwise */ public boolean isSetColumns() { return this.columns != null; } public void setColumnsIsSet(boolean value) { if (!value) { this.columns = null; } } public long getTimestamp() { return this.timestamp; } public getRowWithColumnsTs_args setTimestamp(long timestamp) { this.timestamp = timestamp; setTimestampIsSet(true); return this; } public void unsetTimestamp() { __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __TIMESTAMP_ISSET_ID); } /** Returns true if field timestamp is set (has been assigned a value) and false otherwise */ public boolean isSetTimestamp() { return EncodingUtils.testBit(__isset_bitfield, __TIMESTAMP_ISSET_ID); } public void setTimestampIsSet(boolean value) { __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __TIMESTAMP_ISSET_ID, value); } public int getAttributesSize() { return (this.attributes == null) ? 0 : this.attributes.size(); } public void putToAttributes(ByteBuffer key, ByteBuffer val) { if (this.attributes == null) { this.attributes = new HashMap<ByteBuffer,ByteBuffer>(); } this.attributes.put(key, val); } /** * Get attributes */ public Map<ByteBuffer,ByteBuffer> getAttributes() { return this.attributes; } /** * Get attributes */ public getRowWithColumnsTs_args setAttributes(Map<ByteBuffer,ByteBuffer> attributes) { this.attributes = attributes; return this; } public void unsetAttributes() { this.attributes = null; } /** Returns true if field attributes is set (has been assigned a value) and false otherwise */ public boolean isSetAttributes() { return this.attributes != null; } public void setAttributesIsSet(boolean value) { if (!value) { this.attributes = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; case ROW: if (value == null) { unsetRow(); } else { setRow((ByteBuffer)value); } break; case COLUMNS: if (value == null) { unsetColumns(); } else { setColumns((List<ByteBuffer>)value); } break; case TIMESTAMP: if (value == null) { unsetTimestamp(); } else { setTimestamp((Long)value); } break; case ATTRIBUTES: if (value == null) { unsetAttributes(); } else { setAttributes((Map<ByteBuffer,ByteBuffer>)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); case ROW: return getRow(); case COLUMNS: return getColumns(); case TIMESTAMP: return getTimestamp(); case ATTRIBUTES: return getAttributes(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); case ROW: return isSetRow(); case COLUMNS: return isSetColumns(); case TIMESTAMP: return isSetTimestamp(); case ATTRIBUTES: return isSetAttributes(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof getRowWithColumnsTs_args) return this.equals((getRowWithColumnsTs_args)that); return false; } public boolean equals(getRowWithColumnsTs_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } boolean this_present_row = true && this.isSetRow(); boolean that_present_row = true && that.isSetRow(); if (this_present_row || that_present_row) { if (!(this_present_row && that_present_row)) return false; if (!this.row.equals(that.row)) return false; } boolean this_present_columns = true && this.isSetColumns(); boolean that_present_columns = true && that.isSetColumns(); if (this_present_columns || that_present_columns) { if (!(this_present_columns && that_present_columns)) return false; if (!this.columns.equals(that.columns)) return false; } boolean this_present_timestamp = true; boolean that_present_timestamp = true; if (this_present_timestamp || that_present_timestamp) { if (!(this_present_timestamp && that_present_timestamp)) return false; if (this.timestamp != that.timestamp) return false; } boolean this_present_attributes = true && this.isSetAttributes(); boolean that_present_attributes = true && that.isSetAttributes(); if (this_present_attributes || that_present_attributes) { if (!(this_present_attributes && that_present_attributes)) return false; if (!this.attributes.equals(that.attributes)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); boolean present_row = true && (isSetRow()); list.add(present_row); if (present_row) list.add(row); boolean present_columns = true && (isSetColumns()); list.add(present_columns); if (present_columns) list.add(columns); boolean present_timestamp = true; list.add(present_timestamp); if (present_timestamp) list.add(timestamp); boolean present_attributes = true && (isSetAttributes()); list.add(present_attributes); if (present_attributes) list.add(attributes); return list.hashCode(); } @Override public int compareTo(getRowWithColumnsTs_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetRow()).compareTo(other.isSetRow()); if (lastComparison != 0) { return lastComparison; } if (isSetRow()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.row, other.row); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetColumns()).compareTo(other.isSetColumns()); if (lastComparison != 0) { return lastComparison; } if (isSetColumns()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.columns, other.columns); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetTimestamp()).compareTo(other.isSetTimestamp()); if (lastComparison != 0) { return lastComparison; } if (isSetTimestamp()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.timestamp, other.timestamp); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetAttributes()).compareTo(other.isSetAttributes()); if (lastComparison != 0) { return lastComparison; } if (isSetAttributes()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.attributes, other.attributes); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("getRowWithColumnsTs_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; if (!first) sb.append(", "); sb.append("row:"); if (this.row == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.row, sb); } first = false; if (!first) sb.append(", "); sb.append("columns:"); if (this.columns == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.columns, sb); } first = false; if (!first) sb.append(", "); sb.append("timestamp:"); sb.append(this.timestamp); first = false; if (!first) sb.append(", "); sb.append("attributes:"); if (this.attributes == null) { sb.append("null"); } else { sb.append(this.attributes); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { // it doesn't seem like you should have to do this, but java serialization is wacky, and doesn't call the default constructor. __isset_bitfield = 0; read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class getRowWithColumnsTs_argsStandardSchemeFactory implements SchemeFactory { public getRowWithColumnsTs_argsStandardScheme getScheme() { return new getRowWithColumnsTs_argsStandardScheme(); } } private static class getRowWithColumnsTs_argsStandardScheme extends StandardScheme<getRowWithColumnsTs_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, getRowWithColumnsTs_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // ROW if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.row = iprot.readBinary(); struct.setRowIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 3: // COLUMNS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list200 = iprot.readListBegin(); struct.columns = new ArrayList<ByteBuffer>(_list200.size); ByteBuffer _elem201; for (int _i202 = 0; _i202 < _list200.size; ++_i202) { _elem201 = iprot.readBinary(); struct.columns.add(_elem201); } iprot.readListEnd(); } struct.setColumnsIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 4: // TIMESTAMP if (schemeField.type == org.apache.thrift.protocol.TType.I64) { struct.timestamp = iprot.readI64(); struct.setTimestampIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 5: // ATTRIBUTES if (schemeField.type == org.apache.thrift.protocol.TType.MAP) { { org.apache.thrift.protocol.TMap _map203 = iprot.readMapBegin(); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map203.size); ByteBuffer _key204; ByteBuffer _val205; for (int _i206 = 0; _i206 < _map203.size; ++_i206) { _key204 = iprot.readBinary(); _val205 = iprot.readBinary(); struct.attributes.put(_key204, _val205); } iprot.readMapEnd(); } struct.setAttributesIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, getRowWithColumnsTs_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } if (struct.row != null) { oprot.writeFieldBegin(ROW_FIELD_DESC); oprot.writeBinary(struct.row); oprot.writeFieldEnd(); } if (struct.columns != null) { oprot.writeFieldBegin(COLUMNS_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.columns.size())); for (ByteBuffer _iter207 : struct.columns) { oprot.writeBinary(_iter207); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldBegin(TIMESTAMP_FIELD_DESC); oprot.writeI64(struct.timestamp); oprot.writeFieldEnd(); if (struct.attributes != null) { oprot.writeFieldBegin(ATTRIBUTES_FIELD_DESC); { oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, struct.attributes.size())); for (Map.Entry<ByteBuffer, ByteBuffer> _iter208 : struct.attributes.entrySet()) { oprot.writeBinary(_iter208.getKey()); oprot.writeBinary(_iter208.getValue()); } oprot.writeMapEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class getRowWithColumnsTs_argsTupleSchemeFactory implements SchemeFactory { public getRowWithColumnsTs_argsTupleScheme getScheme() { return new getRowWithColumnsTs_argsTupleScheme(); } } private static class getRowWithColumnsTs_argsTupleScheme extends TupleScheme<getRowWithColumnsTs_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, getRowWithColumnsTs_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } if (struct.isSetRow()) { optionals.set(1); } if (struct.isSetColumns()) { optionals.set(2); } if (struct.isSetTimestamp()) { optionals.set(3); } if (struct.isSetAttributes()) { optionals.set(4); } oprot.writeBitSet(optionals, 5); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } if (struct.isSetRow()) { oprot.writeBinary(struct.row); } if (struct.isSetColumns()) { { oprot.writeI32(struct.columns.size()); for (ByteBuffer _iter209 : struct.columns) { oprot.writeBinary(_iter209); } } } if (struct.isSetTimestamp()) { oprot.writeI64(struct.timestamp); } if (struct.isSetAttributes()) { { oprot.writeI32(struct.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> _iter210 : struct.attributes.entrySet()) { oprot.writeBinary(_iter210.getKey()); oprot.writeBinary(_iter210.getValue()); } } } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, getRowWithColumnsTs_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(5); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } if (incoming.get(1)) { struct.row = iprot.readBinary(); struct.setRowIsSet(true); } if (incoming.get(2)) { { org.apache.thrift.protocol.TList _list211 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.columns = new ArrayList<ByteBuffer>(_list211.size); ByteBuffer _elem212; for (int _i213 = 0; _i213 < _list211.size; ++_i213) { _elem212 = iprot.readBinary(); struct.columns.add(_elem212); } } struct.setColumnsIsSet(true); } if (incoming.get(3)) { struct.timestamp = iprot.readI64(); struct.setTimestampIsSet(true); } if (incoming.get(4)) { { org.apache.thrift.protocol.TMap _map214 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map214.size); ByteBuffer _key215; ByteBuffer _val216; for (int _i217 = 0; _i217 < _map214.size; ++_i217) { _key215 = iprot.readBinary(); _val216 = iprot.readBinary(); struct.attributes.put(_key215, _val216); } } struct.setAttributesIsSet(true); } } } } public static class getRowWithColumnsTs_result implements org.apache.thrift.TBase<getRowWithColumnsTs_result, getRowWithColumnsTs_result._Fields>, java.io.Serializable, Cloneable, Comparable<getRowWithColumnsTs_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getRowWithColumnsTs_result"); private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.LIST, (short)0); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new getRowWithColumnsTs_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new getRowWithColumnsTs_resultTupleSchemeFactory()); } public List<TRowResult> success; // required public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { SUCCESS((short)0, "success"), IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 0: // SUCCESS return SUCCESS; case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.SUCCESS, new org.apache.thrift.meta_data.FieldMetaData("success", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, TRowResult.class)))); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(getRowWithColumnsTs_result.class, metaDataMap); } public getRowWithColumnsTs_result() { } public getRowWithColumnsTs_result( List<TRowResult> success, IOError io) { this(); this.success = success; this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public getRowWithColumnsTs_result(getRowWithColumnsTs_result other) { if (other.isSetSuccess()) { List<TRowResult> __this__success = new ArrayList<TRowResult>(other.success.size()); for (TRowResult other_element : other.success) { __this__success.add(new TRowResult(other_element)); } this.success = __this__success; } if (other.isSetIo()) { this.io = new IOError(other.io); } } public getRowWithColumnsTs_result deepCopy() { return new getRowWithColumnsTs_result(this); } @Override public void clear() { this.success = null; this.io = null; } public int getSuccessSize() { return (this.success == null) ? 0 : this.success.size(); } public java.util.Iterator<TRowResult> getSuccessIterator() { return (this.success == null) ? null : this.success.iterator(); } public void addToSuccess(TRowResult elem) { if (this.success == null) { this.success = new ArrayList<TRowResult>(); } this.success.add(elem); } public List<TRowResult> getSuccess() { return this.success; } public getRowWithColumnsTs_result setSuccess(List<TRowResult> success) { this.success = success; return this; } public void unsetSuccess() { this.success = null; } /** Returns true if field success is set (has been assigned a value) and false otherwise */ public boolean isSetSuccess() { return this.success != null; } public void setSuccessIsSet(boolean value) { if (!value) { this.success = null; } } public IOError getIo() { return this.io; } public getRowWithColumnsTs_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case SUCCESS: if (value == null) { unsetSuccess(); } else { setSuccess((List<TRowResult>)value); } break; case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case SUCCESS: return getSuccess(); case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case SUCCESS: return isSetSuccess(); case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof getRowWithColumnsTs_result) return this.equals((getRowWithColumnsTs_result)that); return false; } public boolean equals(getRowWithColumnsTs_result that) { if (that == null) return false; boolean this_present_success = true && this.isSetSuccess(); boolean that_present_success = true && that.isSetSuccess(); if (this_present_success || that_present_success) { if (!(this_present_success && that_present_success)) return false; if (!this.success.equals(that.success)) return false; } boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_success = true && (isSetSuccess()); list.add(present_success); if (present_success) list.add(success); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(getRowWithColumnsTs_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess()); if (lastComparison != 0) { return lastComparison; } if (isSetSuccess()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("getRowWithColumnsTs_result("); boolean first = true; sb.append("success:"); if (this.success == null) { sb.append("null"); } else { sb.append(this.success); } first = false; if (!first) sb.append(", "); sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class getRowWithColumnsTs_resultStandardSchemeFactory implements SchemeFactory { public getRowWithColumnsTs_resultStandardScheme getScheme() { return new getRowWithColumnsTs_resultStandardScheme(); } } private static class getRowWithColumnsTs_resultStandardScheme extends StandardScheme<getRowWithColumnsTs_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, getRowWithColumnsTs_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list218 = iprot.readListBegin(); struct.success = new ArrayList<TRowResult>(_list218.size); TRowResult _elem219; for (int _i220 = 0; _i220 < _list218.size; ++_i220) { _elem219 = new TRowResult(); _elem219.read(iprot); struct.success.add(_elem219); } iprot.readListEnd(); } struct.setSuccessIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, getRowWithColumnsTs_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.success != null) { oprot.writeFieldBegin(SUCCESS_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size())); for (TRowResult _iter221 : struct.success) { _iter221.write(oprot); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class getRowWithColumnsTs_resultTupleSchemeFactory implements SchemeFactory { public getRowWithColumnsTs_resultTupleScheme getScheme() { return new getRowWithColumnsTs_resultTupleScheme(); } } private static class getRowWithColumnsTs_resultTupleScheme extends TupleScheme<getRowWithColumnsTs_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, getRowWithColumnsTs_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetSuccess()) { optionals.set(0); } if (struct.isSetIo()) { optionals.set(1); } oprot.writeBitSet(optionals, 2); if (struct.isSetSuccess()) { { oprot.writeI32(struct.success.size()); for (TRowResult _iter222 : struct.success) { _iter222.write(oprot); } } } if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, getRowWithColumnsTs_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { { org.apache.thrift.protocol.TList _list223 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32()); struct.success = new ArrayList<TRowResult>(_list223.size); TRowResult _elem224; for (int _i225 = 0; _i225 < _list223.size; ++_i225) { _elem224 = new TRowResult(); _elem224.read(iprot); struct.success.add(_elem224); } } struct.setSuccessIsSet(true); } if (incoming.get(1)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class getRows_args implements org.apache.thrift.TBase<getRows_args, getRows_args._Fields>, java.io.Serializable, Cloneable, Comparable<getRows_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getRows_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final org.apache.thrift.protocol.TField ROWS_FIELD_DESC = new org.apache.thrift.protocol.TField("rows", org.apache.thrift.protocol.TType.LIST, (short)2); private static final org.apache.thrift.protocol.TField ATTRIBUTES_FIELD_DESC = new org.apache.thrift.protocol.TField("attributes", org.apache.thrift.protocol.TType.MAP, (short)3); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new getRows_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new getRows_argsTupleSchemeFactory()); } /** * name of table */ public ByteBuffer tableName; // required /** * row keys */ public List<ByteBuffer> rows; // required /** * Get attributes */ public Map<ByteBuffer,ByteBuffer> attributes; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * name of table */ TABLE_NAME((short)1, "tableName"), /** * row keys */ ROWS((short)2, "rows"), /** * Get attributes */ ATTRIBUTES((short)3, "attributes"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; case 2: // ROWS return ROWS; case 3: // ATTRIBUTES return ATTRIBUTES; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.ROWS, new org.apache.thrift.meta_data.FieldMetaData("rows", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); tmpMap.put(_Fields.ATTRIBUTES, new org.apache.thrift.meta_data.FieldMetaData("attributes", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.MapMetaData(org.apache.thrift.protocol.TType.MAP, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"), new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(getRows_args.class, metaDataMap); } public getRows_args() { } public getRows_args( ByteBuffer tableName, List<ByteBuffer> rows, Map<ByteBuffer,ByteBuffer> attributes) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); this.rows = rows; this.attributes = attributes; } /** * Performs a deep copy on <i>other</i>. */ public getRows_args(getRows_args other) { if (other.isSetTableName()) { this.tableName = other.tableName; } if (other.isSetRows()) { List<ByteBuffer> __this__rows = new ArrayList<ByteBuffer>(other.rows.size()); for (ByteBuffer other_element : other.rows) { __this__rows.add(other_element); } this.rows = __this__rows; } if (other.isSetAttributes()) { Map<ByteBuffer,ByteBuffer> __this__attributes = new HashMap<ByteBuffer,ByteBuffer>(other.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> other_element : other.attributes.entrySet()) { ByteBuffer other_element_key = other_element.getKey(); ByteBuffer other_element_value = other_element.getValue(); ByteBuffer __this__attributes_copy_key = other_element_key; ByteBuffer __this__attributes_copy_value = other_element_value; __this__attributes.put(__this__attributes_copy_key, __this__attributes_copy_value); } this.attributes = __this__attributes; } } public getRows_args deepCopy() { return new getRows_args(this); } @Override public void clear() { this.tableName = null; this.rows = null; this.attributes = null; } /** * name of table */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * name of table */ public getRows_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public getRows_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } public int getRowsSize() { return (this.rows == null) ? 0 : this.rows.size(); } public java.util.Iterator<ByteBuffer> getRowsIterator() { return (this.rows == null) ? null : this.rows.iterator(); } public void addToRows(ByteBuffer elem) { if (this.rows == null) { this.rows = new ArrayList<ByteBuffer>(); } this.rows.add(elem); } /** * row keys */ public List<ByteBuffer> getRows() { return this.rows; } /** * row keys */ public getRows_args setRows(List<ByteBuffer> rows) { this.rows = rows; return this; } public void unsetRows() { this.rows = null; } /** Returns true if field rows is set (has been assigned a value) and false otherwise */ public boolean isSetRows() { return this.rows != null; } public void setRowsIsSet(boolean value) { if (!value) { this.rows = null; } } public int getAttributesSize() { return (this.attributes == null) ? 0 : this.attributes.size(); } public void putToAttributes(ByteBuffer key, ByteBuffer val) { if (this.attributes == null) { this.attributes = new HashMap<ByteBuffer,ByteBuffer>(); } this.attributes.put(key, val); } /** * Get attributes */ public Map<ByteBuffer,ByteBuffer> getAttributes() { return this.attributes; } /** * Get attributes */ public getRows_args setAttributes(Map<ByteBuffer,ByteBuffer> attributes) { this.attributes = attributes; return this; } public void unsetAttributes() { this.attributes = null; } /** Returns true if field attributes is set (has been assigned a value) and false otherwise */ public boolean isSetAttributes() { return this.attributes != null; } public void setAttributesIsSet(boolean value) { if (!value) { this.attributes = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; case ROWS: if (value == null) { unsetRows(); } else { setRows((List<ByteBuffer>)value); } break; case ATTRIBUTES: if (value == null) { unsetAttributes(); } else { setAttributes((Map<ByteBuffer,ByteBuffer>)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); case ROWS: return getRows(); case ATTRIBUTES: return getAttributes(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); case ROWS: return isSetRows(); case ATTRIBUTES: return isSetAttributes(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof getRows_args) return this.equals((getRows_args)that); return false; } public boolean equals(getRows_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } boolean this_present_rows = true && this.isSetRows(); boolean that_present_rows = true && that.isSetRows(); if (this_present_rows || that_present_rows) { if (!(this_present_rows && that_present_rows)) return false; if (!this.rows.equals(that.rows)) return false; } boolean this_present_attributes = true && this.isSetAttributes(); boolean that_present_attributes = true && that.isSetAttributes(); if (this_present_attributes || that_present_attributes) { if (!(this_present_attributes && that_present_attributes)) return false; if (!this.attributes.equals(that.attributes)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); boolean present_rows = true && (isSetRows()); list.add(present_rows); if (present_rows) list.add(rows); boolean present_attributes = true && (isSetAttributes()); list.add(present_attributes); if (present_attributes) list.add(attributes); return list.hashCode(); } @Override public int compareTo(getRows_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetRows()).compareTo(other.isSetRows()); if (lastComparison != 0) { return lastComparison; } if (isSetRows()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.rows, other.rows); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetAttributes()).compareTo(other.isSetAttributes()); if (lastComparison != 0) { return lastComparison; } if (isSetAttributes()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.attributes, other.attributes); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("getRows_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; if (!first) sb.append(", "); sb.append("rows:"); if (this.rows == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.rows, sb); } first = false; if (!first) sb.append(", "); sb.append("attributes:"); if (this.attributes == null) { sb.append("null"); } else { sb.append(this.attributes); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class getRows_argsStandardSchemeFactory implements SchemeFactory { public getRows_argsStandardScheme getScheme() { return new getRows_argsStandardScheme(); } } private static class getRows_argsStandardScheme extends StandardScheme<getRows_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, getRows_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // ROWS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list226 = iprot.readListBegin(); struct.rows = new ArrayList<ByteBuffer>(_list226.size); ByteBuffer _elem227; for (int _i228 = 0; _i228 < _list226.size; ++_i228) { _elem227 = iprot.readBinary(); struct.rows.add(_elem227); } iprot.readListEnd(); } struct.setRowsIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 3: // ATTRIBUTES if (schemeField.type == org.apache.thrift.protocol.TType.MAP) { { org.apache.thrift.protocol.TMap _map229 = iprot.readMapBegin(); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map229.size); ByteBuffer _key230; ByteBuffer _val231; for (int _i232 = 0; _i232 < _map229.size; ++_i232) { _key230 = iprot.readBinary(); _val231 = iprot.readBinary(); struct.attributes.put(_key230, _val231); } iprot.readMapEnd(); } struct.setAttributesIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, getRows_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } if (struct.rows != null) { oprot.writeFieldBegin(ROWS_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.rows.size())); for (ByteBuffer _iter233 : struct.rows) { oprot.writeBinary(_iter233); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } if (struct.attributes != null) { oprot.writeFieldBegin(ATTRIBUTES_FIELD_DESC); { oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, struct.attributes.size())); for (Map.Entry<ByteBuffer, ByteBuffer> _iter234 : struct.attributes.entrySet()) { oprot.writeBinary(_iter234.getKey()); oprot.writeBinary(_iter234.getValue()); } oprot.writeMapEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class getRows_argsTupleSchemeFactory implements SchemeFactory { public getRows_argsTupleScheme getScheme() { return new getRows_argsTupleScheme(); } } private static class getRows_argsTupleScheme extends TupleScheme<getRows_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, getRows_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } if (struct.isSetRows()) { optionals.set(1); } if (struct.isSetAttributes()) { optionals.set(2); } oprot.writeBitSet(optionals, 3); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } if (struct.isSetRows()) { { oprot.writeI32(struct.rows.size()); for (ByteBuffer _iter235 : struct.rows) { oprot.writeBinary(_iter235); } } } if (struct.isSetAttributes()) { { oprot.writeI32(struct.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> _iter236 : struct.attributes.entrySet()) { oprot.writeBinary(_iter236.getKey()); oprot.writeBinary(_iter236.getValue()); } } } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, getRows_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(3); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } if (incoming.get(1)) { { org.apache.thrift.protocol.TList _list237 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.rows = new ArrayList<ByteBuffer>(_list237.size); ByteBuffer _elem238; for (int _i239 = 0; _i239 < _list237.size; ++_i239) { _elem238 = iprot.readBinary(); struct.rows.add(_elem238); } } struct.setRowsIsSet(true); } if (incoming.get(2)) { { org.apache.thrift.protocol.TMap _map240 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map240.size); ByteBuffer _key241; ByteBuffer _val242; for (int _i243 = 0; _i243 < _map240.size; ++_i243) { _key241 = iprot.readBinary(); _val242 = iprot.readBinary(); struct.attributes.put(_key241, _val242); } } struct.setAttributesIsSet(true); } } } } public static class getRows_result implements org.apache.thrift.TBase<getRows_result, getRows_result._Fields>, java.io.Serializable, Cloneable, Comparable<getRows_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getRows_result"); private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.LIST, (short)0); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new getRows_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new getRows_resultTupleSchemeFactory()); } public List<TRowResult> success; // required public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { SUCCESS((short)0, "success"), IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 0: // SUCCESS return SUCCESS; case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.SUCCESS, new org.apache.thrift.meta_data.FieldMetaData("success", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, TRowResult.class)))); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(getRows_result.class, metaDataMap); } public getRows_result() { } public getRows_result( List<TRowResult> success, IOError io) { this(); this.success = success; this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public getRows_result(getRows_result other) { if (other.isSetSuccess()) { List<TRowResult> __this__success = new ArrayList<TRowResult>(other.success.size()); for (TRowResult other_element : other.success) { __this__success.add(new TRowResult(other_element)); } this.success = __this__success; } if (other.isSetIo()) { this.io = new IOError(other.io); } } public getRows_result deepCopy() { return new getRows_result(this); } @Override public void clear() { this.success = null; this.io = null; } public int getSuccessSize() { return (this.success == null) ? 0 : this.success.size(); } public java.util.Iterator<TRowResult> getSuccessIterator() { return (this.success == null) ? null : this.success.iterator(); } public void addToSuccess(TRowResult elem) { if (this.success == null) { this.success = new ArrayList<TRowResult>(); } this.success.add(elem); } public List<TRowResult> getSuccess() { return this.success; } public getRows_result setSuccess(List<TRowResult> success) { this.success = success; return this; } public void unsetSuccess() { this.success = null; } /** Returns true if field success is set (has been assigned a value) and false otherwise */ public boolean isSetSuccess() { return this.success != null; } public void setSuccessIsSet(boolean value) { if (!value) { this.success = null; } } public IOError getIo() { return this.io; } public getRows_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case SUCCESS: if (value == null) { unsetSuccess(); } else { setSuccess((List<TRowResult>)value); } break; case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case SUCCESS: return getSuccess(); case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case SUCCESS: return isSetSuccess(); case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof getRows_result) return this.equals((getRows_result)that); return false; } public boolean equals(getRows_result that) { if (that == null) return false; boolean this_present_success = true && this.isSetSuccess(); boolean that_present_success = true && that.isSetSuccess(); if (this_present_success || that_present_success) { if (!(this_present_success && that_present_success)) return false; if (!this.success.equals(that.success)) return false; } boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_success = true && (isSetSuccess()); list.add(present_success); if (present_success) list.add(success); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(getRows_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess()); if (lastComparison != 0) { return lastComparison; } if (isSetSuccess()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("getRows_result("); boolean first = true; sb.append("success:"); if (this.success == null) { sb.append("null"); } else { sb.append(this.success); } first = false; if (!first) sb.append(", "); sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class getRows_resultStandardSchemeFactory implements SchemeFactory { public getRows_resultStandardScheme getScheme() { return new getRows_resultStandardScheme(); } } private static class getRows_resultStandardScheme extends StandardScheme<getRows_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, getRows_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list244 = iprot.readListBegin(); struct.success = new ArrayList<TRowResult>(_list244.size); TRowResult _elem245; for (int _i246 = 0; _i246 < _list244.size; ++_i246) { _elem245 = new TRowResult(); _elem245.read(iprot); struct.success.add(_elem245); } iprot.readListEnd(); } struct.setSuccessIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, getRows_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.success != null) { oprot.writeFieldBegin(SUCCESS_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size())); for (TRowResult _iter247 : struct.success) { _iter247.write(oprot); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class getRows_resultTupleSchemeFactory implements SchemeFactory { public getRows_resultTupleScheme getScheme() { return new getRows_resultTupleScheme(); } } private static class getRows_resultTupleScheme extends TupleScheme<getRows_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, getRows_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetSuccess()) { optionals.set(0); } if (struct.isSetIo()) { optionals.set(1); } oprot.writeBitSet(optionals, 2); if (struct.isSetSuccess()) { { oprot.writeI32(struct.success.size()); for (TRowResult _iter248 : struct.success) { _iter248.write(oprot); } } } if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, getRows_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { { org.apache.thrift.protocol.TList _list249 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32()); struct.success = new ArrayList<TRowResult>(_list249.size); TRowResult _elem250; for (int _i251 = 0; _i251 < _list249.size; ++_i251) { _elem250 = new TRowResult(); _elem250.read(iprot); struct.success.add(_elem250); } } struct.setSuccessIsSet(true); } if (incoming.get(1)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class getRowsWithColumns_args implements org.apache.thrift.TBase<getRowsWithColumns_args, getRowsWithColumns_args._Fields>, java.io.Serializable, Cloneable, Comparable<getRowsWithColumns_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getRowsWithColumns_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final org.apache.thrift.protocol.TField ROWS_FIELD_DESC = new org.apache.thrift.protocol.TField("rows", org.apache.thrift.protocol.TType.LIST, (short)2); private static final org.apache.thrift.protocol.TField COLUMNS_FIELD_DESC = new org.apache.thrift.protocol.TField("columns", org.apache.thrift.protocol.TType.LIST, (short)3); private static final org.apache.thrift.protocol.TField ATTRIBUTES_FIELD_DESC = new org.apache.thrift.protocol.TField("attributes", org.apache.thrift.protocol.TType.MAP, (short)4); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new getRowsWithColumns_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new getRowsWithColumns_argsTupleSchemeFactory()); } /** * name of table */ public ByteBuffer tableName; // required /** * row keys */ public List<ByteBuffer> rows; // required /** * List of columns to return, null for all columns */ public List<ByteBuffer> columns; // required /** * Get attributes */ public Map<ByteBuffer,ByteBuffer> attributes; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * name of table */ TABLE_NAME((short)1, "tableName"), /** * row keys */ ROWS((short)2, "rows"), /** * List of columns to return, null for all columns */ COLUMNS((short)3, "columns"), /** * Get attributes */ ATTRIBUTES((short)4, "attributes"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; case 2: // ROWS return ROWS; case 3: // COLUMNS return COLUMNS; case 4: // ATTRIBUTES return ATTRIBUTES; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.ROWS, new org.apache.thrift.meta_data.FieldMetaData("rows", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); tmpMap.put(_Fields.COLUMNS, new org.apache.thrift.meta_data.FieldMetaData("columns", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); tmpMap.put(_Fields.ATTRIBUTES, new org.apache.thrift.meta_data.FieldMetaData("attributes", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.MapMetaData(org.apache.thrift.protocol.TType.MAP, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"), new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(getRowsWithColumns_args.class, metaDataMap); } public getRowsWithColumns_args() { } public getRowsWithColumns_args( ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); this.rows = rows; this.columns = columns; this.attributes = attributes; } /** * Performs a deep copy on <i>other</i>. */ public getRowsWithColumns_args(getRowsWithColumns_args other) { if (other.isSetTableName()) { this.tableName = other.tableName; } if (other.isSetRows()) { List<ByteBuffer> __this__rows = new ArrayList<ByteBuffer>(other.rows.size()); for (ByteBuffer other_element : other.rows) { __this__rows.add(other_element); } this.rows = __this__rows; } if (other.isSetColumns()) { List<ByteBuffer> __this__columns = new ArrayList<ByteBuffer>(other.columns.size()); for (ByteBuffer other_element : other.columns) { __this__columns.add(other_element); } this.columns = __this__columns; } if (other.isSetAttributes()) { Map<ByteBuffer,ByteBuffer> __this__attributes = new HashMap<ByteBuffer,ByteBuffer>(other.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> other_element : other.attributes.entrySet()) { ByteBuffer other_element_key = other_element.getKey(); ByteBuffer other_element_value = other_element.getValue(); ByteBuffer __this__attributes_copy_key = other_element_key; ByteBuffer __this__attributes_copy_value = other_element_value; __this__attributes.put(__this__attributes_copy_key, __this__attributes_copy_value); } this.attributes = __this__attributes; } } public getRowsWithColumns_args deepCopy() { return new getRowsWithColumns_args(this); } @Override public void clear() { this.tableName = null; this.rows = null; this.columns = null; this.attributes = null; } /** * name of table */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * name of table */ public getRowsWithColumns_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public getRowsWithColumns_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } public int getRowsSize() { return (this.rows == null) ? 0 : this.rows.size(); } public java.util.Iterator<ByteBuffer> getRowsIterator() { return (this.rows == null) ? null : this.rows.iterator(); } public void addToRows(ByteBuffer elem) { if (this.rows == null) { this.rows = new ArrayList<ByteBuffer>(); } this.rows.add(elem); } /** * row keys */ public List<ByteBuffer> getRows() { return this.rows; } /** * row keys */ public getRowsWithColumns_args setRows(List<ByteBuffer> rows) { this.rows = rows; return this; } public void unsetRows() { this.rows = null; } /** Returns true if field rows is set (has been assigned a value) and false otherwise */ public boolean isSetRows() { return this.rows != null; } public void setRowsIsSet(boolean value) { if (!value) { this.rows = null; } } public int getColumnsSize() { return (this.columns == null) ? 0 : this.columns.size(); } public java.util.Iterator<ByteBuffer> getColumnsIterator() { return (this.columns == null) ? null : this.columns.iterator(); } public void addToColumns(ByteBuffer elem) { if (this.columns == null) { this.columns = new ArrayList<ByteBuffer>(); } this.columns.add(elem); } /** * List of columns to return, null for all columns */ public List<ByteBuffer> getColumns() { return this.columns; } /** * List of columns to return, null for all columns */ public getRowsWithColumns_args setColumns(List<ByteBuffer> columns) { this.columns = columns; return this; } public void unsetColumns() { this.columns = null; } /** Returns true if field columns is set (has been assigned a value) and false otherwise */ public boolean isSetColumns() { return this.columns != null; } public void setColumnsIsSet(boolean value) { if (!value) { this.columns = null; } } public int getAttributesSize() { return (this.attributes == null) ? 0 : this.attributes.size(); } public void putToAttributes(ByteBuffer key, ByteBuffer val) { if (this.attributes == null) { this.attributes = new HashMap<ByteBuffer,ByteBuffer>(); } this.attributes.put(key, val); } /** * Get attributes */ public Map<ByteBuffer,ByteBuffer> getAttributes() { return this.attributes; } /** * Get attributes */ public getRowsWithColumns_args setAttributes(Map<ByteBuffer,ByteBuffer> attributes) { this.attributes = attributes; return this; } public void unsetAttributes() { this.attributes = null; } /** Returns true if field attributes is set (has been assigned a value) and false otherwise */ public boolean isSetAttributes() { return this.attributes != null; } public void setAttributesIsSet(boolean value) { if (!value) { this.attributes = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; case ROWS: if (value == null) { unsetRows(); } else { setRows((List<ByteBuffer>)value); } break; case COLUMNS: if (value == null) { unsetColumns(); } else { setColumns((List<ByteBuffer>)value); } break; case ATTRIBUTES: if (value == null) { unsetAttributes(); } else { setAttributes((Map<ByteBuffer,ByteBuffer>)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); case ROWS: return getRows(); case COLUMNS: return getColumns(); case ATTRIBUTES: return getAttributes(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); case ROWS: return isSetRows(); case COLUMNS: return isSetColumns(); case ATTRIBUTES: return isSetAttributes(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof getRowsWithColumns_args) return this.equals((getRowsWithColumns_args)that); return false; } public boolean equals(getRowsWithColumns_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } boolean this_present_rows = true && this.isSetRows(); boolean that_present_rows = true && that.isSetRows(); if (this_present_rows || that_present_rows) { if (!(this_present_rows && that_present_rows)) return false; if (!this.rows.equals(that.rows)) return false; } boolean this_present_columns = true && this.isSetColumns(); boolean that_present_columns = true && that.isSetColumns(); if (this_present_columns || that_present_columns) { if (!(this_present_columns && that_present_columns)) return false; if (!this.columns.equals(that.columns)) return false; } boolean this_present_attributes = true && this.isSetAttributes(); boolean that_present_attributes = true && that.isSetAttributes(); if (this_present_attributes || that_present_attributes) { if (!(this_present_attributes && that_present_attributes)) return false; if (!this.attributes.equals(that.attributes)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); boolean present_rows = true && (isSetRows()); list.add(present_rows); if (present_rows) list.add(rows); boolean present_columns = true && (isSetColumns()); list.add(present_columns); if (present_columns) list.add(columns); boolean present_attributes = true && (isSetAttributes()); list.add(present_attributes); if (present_attributes) list.add(attributes); return list.hashCode(); } @Override public int compareTo(getRowsWithColumns_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetRows()).compareTo(other.isSetRows()); if (lastComparison != 0) { return lastComparison; } if (isSetRows()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.rows, other.rows); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetColumns()).compareTo(other.isSetColumns()); if (lastComparison != 0) { return lastComparison; } if (isSetColumns()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.columns, other.columns); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetAttributes()).compareTo(other.isSetAttributes()); if (lastComparison != 0) { return lastComparison; } if (isSetAttributes()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.attributes, other.attributes); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("getRowsWithColumns_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; if (!first) sb.append(", "); sb.append("rows:"); if (this.rows == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.rows, sb); } first = false; if (!first) sb.append(", "); sb.append("columns:"); if (this.columns == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.columns, sb); } first = false; if (!first) sb.append(", "); sb.append("attributes:"); if (this.attributes == null) { sb.append("null"); } else { sb.append(this.attributes); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class getRowsWithColumns_argsStandardSchemeFactory implements SchemeFactory { public getRowsWithColumns_argsStandardScheme getScheme() { return new getRowsWithColumns_argsStandardScheme(); } } private static class getRowsWithColumns_argsStandardScheme extends StandardScheme<getRowsWithColumns_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, getRowsWithColumns_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // ROWS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list252 = iprot.readListBegin(); struct.rows = new ArrayList<ByteBuffer>(_list252.size); ByteBuffer _elem253; for (int _i254 = 0; _i254 < _list252.size; ++_i254) { _elem253 = iprot.readBinary(); struct.rows.add(_elem253); } iprot.readListEnd(); } struct.setRowsIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 3: // COLUMNS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list255 = iprot.readListBegin(); struct.columns = new ArrayList<ByteBuffer>(_list255.size); ByteBuffer _elem256; for (int _i257 = 0; _i257 < _list255.size; ++_i257) { _elem256 = iprot.readBinary(); struct.columns.add(_elem256); } iprot.readListEnd(); } struct.setColumnsIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 4: // ATTRIBUTES if (schemeField.type == org.apache.thrift.protocol.TType.MAP) { { org.apache.thrift.protocol.TMap _map258 = iprot.readMapBegin(); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map258.size); ByteBuffer _key259; ByteBuffer _val260; for (int _i261 = 0; _i261 < _map258.size; ++_i261) { _key259 = iprot.readBinary(); _val260 = iprot.readBinary(); struct.attributes.put(_key259, _val260); } iprot.readMapEnd(); } struct.setAttributesIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, getRowsWithColumns_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } if (struct.rows != null) { oprot.writeFieldBegin(ROWS_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.rows.size())); for (ByteBuffer _iter262 : struct.rows) { oprot.writeBinary(_iter262); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } if (struct.columns != null) { oprot.writeFieldBegin(COLUMNS_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.columns.size())); for (ByteBuffer _iter263 : struct.columns) { oprot.writeBinary(_iter263); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } if (struct.attributes != null) { oprot.writeFieldBegin(ATTRIBUTES_FIELD_DESC); { oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, struct.attributes.size())); for (Map.Entry<ByteBuffer, ByteBuffer> _iter264 : struct.attributes.entrySet()) { oprot.writeBinary(_iter264.getKey()); oprot.writeBinary(_iter264.getValue()); } oprot.writeMapEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class getRowsWithColumns_argsTupleSchemeFactory implements SchemeFactory { public getRowsWithColumns_argsTupleScheme getScheme() { return new getRowsWithColumns_argsTupleScheme(); } } private static class getRowsWithColumns_argsTupleScheme extends TupleScheme<getRowsWithColumns_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, getRowsWithColumns_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } if (struct.isSetRows()) { optionals.set(1); } if (struct.isSetColumns()) { optionals.set(2); } if (struct.isSetAttributes()) { optionals.set(3); } oprot.writeBitSet(optionals, 4); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } if (struct.isSetRows()) { { oprot.writeI32(struct.rows.size()); for (ByteBuffer _iter265 : struct.rows) { oprot.writeBinary(_iter265); } } } if (struct.isSetColumns()) { { oprot.writeI32(struct.columns.size()); for (ByteBuffer _iter266 : struct.columns) { oprot.writeBinary(_iter266); } } } if (struct.isSetAttributes()) { { oprot.writeI32(struct.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> _iter267 : struct.attributes.entrySet()) { oprot.writeBinary(_iter267.getKey()); oprot.writeBinary(_iter267.getValue()); } } } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, getRowsWithColumns_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(4); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } if (incoming.get(1)) { { org.apache.thrift.protocol.TList _list268 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.rows = new ArrayList<ByteBuffer>(_list268.size); ByteBuffer _elem269; for (int _i270 = 0; _i270 < _list268.size; ++_i270) { _elem269 = iprot.readBinary(); struct.rows.add(_elem269); } } struct.setRowsIsSet(true); } if (incoming.get(2)) { { org.apache.thrift.protocol.TList _list271 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.columns = new ArrayList<ByteBuffer>(_list271.size); ByteBuffer _elem272; for (int _i273 = 0; _i273 < _list271.size; ++_i273) { _elem272 = iprot.readBinary(); struct.columns.add(_elem272); } } struct.setColumnsIsSet(true); } if (incoming.get(3)) { { org.apache.thrift.protocol.TMap _map274 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map274.size); ByteBuffer _key275; ByteBuffer _val276; for (int _i277 = 0; _i277 < _map274.size; ++_i277) { _key275 = iprot.readBinary(); _val276 = iprot.readBinary(); struct.attributes.put(_key275, _val276); } } struct.setAttributesIsSet(true); } } } } public static class getRowsWithColumns_result implements org.apache.thrift.TBase<getRowsWithColumns_result, getRowsWithColumns_result._Fields>, java.io.Serializable, Cloneable, Comparable<getRowsWithColumns_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getRowsWithColumns_result"); private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.LIST, (short)0); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new getRowsWithColumns_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new getRowsWithColumns_resultTupleSchemeFactory()); } public List<TRowResult> success; // required public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { SUCCESS((short)0, "success"), IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 0: // SUCCESS return SUCCESS; case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.SUCCESS, new org.apache.thrift.meta_data.FieldMetaData("success", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, TRowResult.class)))); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(getRowsWithColumns_result.class, metaDataMap); } public getRowsWithColumns_result() { } public getRowsWithColumns_result( List<TRowResult> success, IOError io) { this(); this.success = success; this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public getRowsWithColumns_result(getRowsWithColumns_result other) { if (other.isSetSuccess()) { List<TRowResult> __this__success = new ArrayList<TRowResult>(other.success.size()); for (TRowResult other_element : other.success) { __this__success.add(new TRowResult(other_element)); } this.success = __this__success; } if (other.isSetIo()) { this.io = new IOError(other.io); } } public getRowsWithColumns_result deepCopy() { return new getRowsWithColumns_result(this); } @Override public void clear() { this.success = null; this.io = null; } public int getSuccessSize() { return (this.success == null) ? 0 : this.success.size(); } public java.util.Iterator<TRowResult> getSuccessIterator() { return (this.success == null) ? null : this.success.iterator(); } public void addToSuccess(TRowResult elem) { if (this.success == null) { this.success = new ArrayList<TRowResult>(); } this.success.add(elem); } public List<TRowResult> getSuccess() { return this.success; } public getRowsWithColumns_result setSuccess(List<TRowResult> success) { this.success = success; return this; } public void unsetSuccess() { this.success = null; } /** Returns true if field success is set (has been assigned a value) and false otherwise */ public boolean isSetSuccess() { return this.success != null; } public void setSuccessIsSet(boolean value) { if (!value) { this.success = null; } } public IOError getIo() { return this.io; } public getRowsWithColumns_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case SUCCESS: if (value == null) { unsetSuccess(); } else { setSuccess((List<TRowResult>)value); } break; case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case SUCCESS: return getSuccess(); case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case SUCCESS: return isSetSuccess(); case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof getRowsWithColumns_result) return this.equals((getRowsWithColumns_result)that); return false; } public boolean equals(getRowsWithColumns_result that) { if (that == null) return false; boolean this_present_success = true && this.isSetSuccess(); boolean that_present_success = true && that.isSetSuccess(); if (this_present_success || that_present_success) { if (!(this_present_success && that_present_success)) return false; if (!this.success.equals(that.success)) return false; } boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_success = true && (isSetSuccess()); list.add(present_success); if (present_success) list.add(success); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(getRowsWithColumns_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess()); if (lastComparison != 0) { return lastComparison; } if (isSetSuccess()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("getRowsWithColumns_result("); boolean first = true; sb.append("success:"); if (this.success == null) { sb.append("null"); } else { sb.append(this.success); } first = false; if (!first) sb.append(", "); sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class getRowsWithColumns_resultStandardSchemeFactory implements SchemeFactory { public getRowsWithColumns_resultStandardScheme getScheme() { return new getRowsWithColumns_resultStandardScheme(); } } private static class getRowsWithColumns_resultStandardScheme extends StandardScheme<getRowsWithColumns_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, getRowsWithColumns_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list278 = iprot.readListBegin(); struct.success = new ArrayList<TRowResult>(_list278.size); TRowResult _elem279; for (int _i280 = 0; _i280 < _list278.size; ++_i280) { _elem279 = new TRowResult(); _elem279.read(iprot); struct.success.add(_elem279); } iprot.readListEnd(); } struct.setSuccessIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, getRowsWithColumns_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.success != null) { oprot.writeFieldBegin(SUCCESS_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size())); for (TRowResult _iter281 : struct.success) { _iter281.write(oprot); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class getRowsWithColumns_resultTupleSchemeFactory implements SchemeFactory { public getRowsWithColumns_resultTupleScheme getScheme() { return new getRowsWithColumns_resultTupleScheme(); } } private static class getRowsWithColumns_resultTupleScheme extends TupleScheme<getRowsWithColumns_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, getRowsWithColumns_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetSuccess()) { optionals.set(0); } if (struct.isSetIo()) { optionals.set(1); } oprot.writeBitSet(optionals, 2); if (struct.isSetSuccess()) { { oprot.writeI32(struct.success.size()); for (TRowResult _iter282 : struct.success) { _iter282.write(oprot); } } } if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, getRowsWithColumns_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { { org.apache.thrift.protocol.TList _list283 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32()); struct.success = new ArrayList<TRowResult>(_list283.size); TRowResult _elem284; for (int _i285 = 0; _i285 < _list283.size; ++_i285) { _elem284 = new TRowResult(); _elem284.read(iprot); struct.success.add(_elem284); } } struct.setSuccessIsSet(true); } if (incoming.get(1)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class getRowsTs_args implements org.apache.thrift.TBase<getRowsTs_args, getRowsTs_args._Fields>, java.io.Serializable, Cloneable, Comparable<getRowsTs_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getRowsTs_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final org.apache.thrift.protocol.TField ROWS_FIELD_DESC = new org.apache.thrift.protocol.TField("rows", org.apache.thrift.protocol.TType.LIST, (short)2); private static final org.apache.thrift.protocol.TField TIMESTAMP_FIELD_DESC = new org.apache.thrift.protocol.TField("timestamp", org.apache.thrift.protocol.TType.I64, (short)3); private static final org.apache.thrift.protocol.TField ATTRIBUTES_FIELD_DESC = new org.apache.thrift.protocol.TField("attributes", org.apache.thrift.protocol.TType.MAP, (short)4); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new getRowsTs_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new getRowsTs_argsTupleSchemeFactory()); } /** * name of the table */ public ByteBuffer tableName; // required /** * row keys */ public List<ByteBuffer> rows; // required /** * timestamp */ public long timestamp; // required /** * Get attributes */ public Map<ByteBuffer,ByteBuffer> attributes; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * name of the table */ TABLE_NAME((short)1, "tableName"), /** * row keys */ ROWS((short)2, "rows"), /** * timestamp */ TIMESTAMP((short)3, "timestamp"), /** * Get attributes */ ATTRIBUTES((short)4, "attributes"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; case 2: // ROWS return ROWS; case 3: // TIMESTAMP return TIMESTAMP; case 4: // ATTRIBUTES return ATTRIBUTES; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments private static final int __TIMESTAMP_ISSET_ID = 0; private byte __isset_bitfield = 0; public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.ROWS, new org.apache.thrift.meta_data.FieldMetaData("rows", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); tmpMap.put(_Fields.TIMESTAMP, new org.apache.thrift.meta_data.FieldMetaData("timestamp", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.I64))); tmpMap.put(_Fields.ATTRIBUTES, new org.apache.thrift.meta_data.FieldMetaData("attributes", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.MapMetaData(org.apache.thrift.protocol.TType.MAP, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"), new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(getRowsTs_args.class, metaDataMap); } public getRowsTs_args() { } public getRowsTs_args( ByteBuffer tableName, List<ByteBuffer> rows, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); this.rows = rows; this.timestamp = timestamp; setTimestampIsSet(true); this.attributes = attributes; } /** * Performs a deep copy on <i>other</i>. */ public getRowsTs_args(getRowsTs_args other) { __isset_bitfield = other.__isset_bitfield; if (other.isSetTableName()) { this.tableName = other.tableName; } if (other.isSetRows()) { List<ByteBuffer> __this__rows = new ArrayList<ByteBuffer>(other.rows.size()); for (ByteBuffer other_element : other.rows) { __this__rows.add(other_element); } this.rows = __this__rows; } this.timestamp = other.timestamp; if (other.isSetAttributes()) { Map<ByteBuffer,ByteBuffer> __this__attributes = new HashMap<ByteBuffer,ByteBuffer>(other.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> other_element : other.attributes.entrySet()) { ByteBuffer other_element_key = other_element.getKey(); ByteBuffer other_element_value = other_element.getValue(); ByteBuffer __this__attributes_copy_key = other_element_key; ByteBuffer __this__attributes_copy_value = other_element_value; __this__attributes.put(__this__attributes_copy_key, __this__attributes_copy_value); } this.attributes = __this__attributes; } } public getRowsTs_args deepCopy() { return new getRowsTs_args(this); } @Override public void clear() { this.tableName = null; this.rows = null; setTimestampIsSet(false); this.timestamp = 0; this.attributes = null; } /** * name of the table */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * name of the table */ public getRowsTs_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public getRowsTs_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } public int getRowsSize() { return (this.rows == null) ? 0 : this.rows.size(); } public java.util.Iterator<ByteBuffer> getRowsIterator() { return (this.rows == null) ? null : this.rows.iterator(); } public void addToRows(ByteBuffer elem) { if (this.rows == null) { this.rows = new ArrayList<ByteBuffer>(); } this.rows.add(elem); } /** * row keys */ public List<ByteBuffer> getRows() { return this.rows; } /** * row keys */ public getRowsTs_args setRows(List<ByteBuffer> rows) { this.rows = rows; return this; } public void unsetRows() { this.rows = null; } /** Returns true if field rows is set (has been assigned a value) and false otherwise */ public boolean isSetRows() { return this.rows != null; } public void setRowsIsSet(boolean value) { if (!value) { this.rows = null; } } /** * timestamp */ public long getTimestamp() { return this.timestamp; } /** * timestamp */ public getRowsTs_args setTimestamp(long timestamp) { this.timestamp = timestamp; setTimestampIsSet(true); return this; } public void unsetTimestamp() { __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __TIMESTAMP_ISSET_ID); } /** Returns true if field timestamp is set (has been assigned a value) and false otherwise */ public boolean isSetTimestamp() { return EncodingUtils.testBit(__isset_bitfield, __TIMESTAMP_ISSET_ID); } public void setTimestampIsSet(boolean value) { __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __TIMESTAMP_ISSET_ID, value); } public int getAttributesSize() { return (this.attributes == null) ? 0 : this.attributes.size(); } public void putToAttributes(ByteBuffer key, ByteBuffer val) { if (this.attributes == null) { this.attributes = new HashMap<ByteBuffer,ByteBuffer>(); } this.attributes.put(key, val); } /** * Get attributes */ public Map<ByteBuffer,ByteBuffer> getAttributes() { return this.attributes; } /** * Get attributes */ public getRowsTs_args setAttributes(Map<ByteBuffer,ByteBuffer> attributes) { this.attributes = attributes; return this; } public void unsetAttributes() { this.attributes = null; } /** Returns true if field attributes is set (has been assigned a value) and false otherwise */ public boolean isSetAttributes() { return this.attributes != null; } public void setAttributesIsSet(boolean value) { if (!value) { this.attributes = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; case ROWS: if (value == null) { unsetRows(); } else { setRows((List<ByteBuffer>)value); } break; case TIMESTAMP: if (value == null) { unsetTimestamp(); } else { setTimestamp((Long)value); } break; case ATTRIBUTES: if (value == null) { unsetAttributes(); } else { setAttributes((Map<ByteBuffer,ByteBuffer>)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); case ROWS: return getRows(); case TIMESTAMP: return getTimestamp(); case ATTRIBUTES: return getAttributes(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); case ROWS: return isSetRows(); case TIMESTAMP: return isSetTimestamp(); case ATTRIBUTES: return isSetAttributes(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof getRowsTs_args) return this.equals((getRowsTs_args)that); return false; } public boolean equals(getRowsTs_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } boolean this_present_rows = true && this.isSetRows(); boolean that_present_rows = true && that.isSetRows(); if (this_present_rows || that_present_rows) { if (!(this_present_rows && that_present_rows)) return false; if (!this.rows.equals(that.rows)) return false; } boolean this_present_timestamp = true; boolean that_present_timestamp = true; if (this_present_timestamp || that_present_timestamp) { if (!(this_present_timestamp && that_present_timestamp)) return false; if (this.timestamp != that.timestamp) return false; } boolean this_present_attributes = true && this.isSetAttributes(); boolean that_present_attributes = true && that.isSetAttributes(); if (this_present_attributes || that_present_attributes) { if (!(this_present_attributes && that_present_attributes)) return false; if (!this.attributes.equals(that.attributes)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); boolean present_rows = true && (isSetRows()); list.add(present_rows); if (present_rows) list.add(rows); boolean present_timestamp = true; list.add(present_timestamp); if (present_timestamp) list.add(timestamp); boolean present_attributes = true && (isSetAttributes()); list.add(present_attributes); if (present_attributes) list.add(attributes); return list.hashCode(); } @Override public int compareTo(getRowsTs_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetRows()).compareTo(other.isSetRows()); if (lastComparison != 0) { return lastComparison; } if (isSetRows()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.rows, other.rows); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetTimestamp()).compareTo(other.isSetTimestamp()); if (lastComparison != 0) { return lastComparison; } if (isSetTimestamp()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.timestamp, other.timestamp); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetAttributes()).compareTo(other.isSetAttributes()); if (lastComparison != 0) { return lastComparison; } if (isSetAttributes()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.attributes, other.attributes); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("getRowsTs_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; if (!first) sb.append(", "); sb.append("rows:"); if (this.rows == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.rows, sb); } first = false; if (!first) sb.append(", "); sb.append("timestamp:"); sb.append(this.timestamp); first = false; if (!first) sb.append(", "); sb.append("attributes:"); if (this.attributes == null) { sb.append("null"); } else { sb.append(this.attributes); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { // it doesn't seem like you should have to do this, but java serialization is wacky, and doesn't call the default constructor. __isset_bitfield = 0; read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class getRowsTs_argsStandardSchemeFactory implements SchemeFactory { public getRowsTs_argsStandardScheme getScheme() { return new getRowsTs_argsStandardScheme(); } } private static class getRowsTs_argsStandardScheme extends StandardScheme<getRowsTs_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, getRowsTs_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // ROWS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list286 = iprot.readListBegin(); struct.rows = new ArrayList<ByteBuffer>(_list286.size); ByteBuffer _elem287; for (int _i288 = 0; _i288 < _list286.size; ++_i288) { _elem287 = iprot.readBinary(); struct.rows.add(_elem287); } iprot.readListEnd(); } struct.setRowsIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 3: // TIMESTAMP if (schemeField.type == org.apache.thrift.protocol.TType.I64) { struct.timestamp = iprot.readI64(); struct.setTimestampIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 4: // ATTRIBUTES if (schemeField.type == org.apache.thrift.protocol.TType.MAP) { { org.apache.thrift.protocol.TMap _map289 = iprot.readMapBegin(); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map289.size); ByteBuffer _key290; ByteBuffer _val291; for (int _i292 = 0; _i292 < _map289.size; ++_i292) { _key290 = iprot.readBinary(); _val291 = iprot.readBinary(); struct.attributes.put(_key290, _val291); } iprot.readMapEnd(); } struct.setAttributesIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, getRowsTs_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } if (struct.rows != null) { oprot.writeFieldBegin(ROWS_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.rows.size())); for (ByteBuffer _iter293 : struct.rows) { oprot.writeBinary(_iter293); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldBegin(TIMESTAMP_FIELD_DESC); oprot.writeI64(struct.timestamp); oprot.writeFieldEnd(); if (struct.attributes != null) { oprot.writeFieldBegin(ATTRIBUTES_FIELD_DESC); { oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, struct.attributes.size())); for (Map.Entry<ByteBuffer, ByteBuffer> _iter294 : struct.attributes.entrySet()) { oprot.writeBinary(_iter294.getKey()); oprot.writeBinary(_iter294.getValue()); } oprot.writeMapEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class getRowsTs_argsTupleSchemeFactory implements SchemeFactory { public getRowsTs_argsTupleScheme getScheme() { return new getRowsTs_argsTupleScheme(); } } private static class getRowsTs_argsTupleScheme extends TupleScheme<getRowsTs_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, getRowsTs_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } if (struct.isSetRows()) { optionals.set(1); } if (struct.isSetTimestamp()) { optionals.set(2); } if (struct.isSetAttributes()) { optionals.set(3); } oprot.writeBitSet(optionals, 4); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } if (struct.isSetRows()) { { oprot.writeI32(struct.rows.size()); for (ByteBuffer _iter295 : struct.rows) { oprot.writeBinary(_iter295); } } } if (struct.isSetTimestamp()) { oprot.writeI64(struct.timestamp); } if (struct.isSetAttributes()) { { oprot.writeI32(struct.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> _iter296 : struct.attributes.entrySet()) { oprot.writeBinary(_iter296.getKey()); oprot.writeBinary(_iter296.getValue()); } } } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, getRowsTs_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(4); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } if (incoming.get(1)) { { org.apache.thrift.protocol.TList _list297 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.rows = new ArrayList<ByteBuffer>(_list297.size); ByteBuffer _elem298; for (int _i299 = 0; _i299 < _list297.size; ++_i299) { _elem298 = iprot.readBinary(); struct.rows.add(_elem298); } } struct.setRowsIsSet(true); } if (incoming.get(2)) { struct.timestamp = iprot.readI64(); struct.setTimestampIsSet(true); } if (incoming.get(3)) { { org.apache.thrift.protocol.TMap _map300 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map300.size); ByteBuffer _key301; ByteBuffer _val302; for (int _i303 = 0; _i303 < _map300.size; ++_i303) { _key301 = iprot.readBinary(); _val302 = iprot.readBinary(); struct.attributes.put(_key301, _val302); } } struct.setAttributesIsSet(true); } } } } public static class getRowsTs_result implements org.apache.thrift.TBase<getRowsTs_result, getRowsTs_result._Fields>, java.io.Serializable, Cloneable, Comparable<getRowsTs_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getRowsTs_result"); private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.LIST, (short)0); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new getRowsTs_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new getRowsTs_resultTupleSchemeFactory()); } public List<TRowResult> success; // required public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { SUCCESS((short)0, "success"), IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 0: // SUCCESS return SUCCESS; case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.SUCCESS, new org.apache.thrift.meta_data.FieldMetaData("success", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, TRowResult.class)))); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(getRowsTs_result.class, metaDataMap); } public getRowsTs_result() { } public getRowsTs_result( List<TRowResult> success, IOError io) { this(); this.success = success; this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public getRowsTs_result(getRowsTs_result other) { if (other.isSetSuccess()) { List<TRowResult> __this__success = new ArrayList<TRowResult>(other.success.size()); for (TRowResult other_element : other.success) { __this__success.add(new TRowResult(other_element)); } this.success = __this__success; } if (other.isSetIo()) { this.io = new IOError(other.io); } } public getRowsTs_result deepCopy() { return new getRowsTs_result(this); } @Override public void clear() { this.success = null; this.io = null; } public int getSuccessSize() { return (this.success == null) ? 0 : this.success.size(); } public java.util.Iterator<TRowResult> getSuccessIterator() { return (this.success == null) ? null : this.success.iterator(); } public void addToSuccess(TRowResult elem) { if (this.success == null) { this.success = new ArrayList<TRowResult>(); } this.success.add(elem); } public List<TRowResult> getSuccess() { return this.success; } public getRowsTs_result setSuccess(List<TRowResult> success) { this.success = success; return this; } public void unsetSuccess() { this.success = null; } /** Returns true if field success is set (has been assigned a value) and false otherwise */ public boolean isSetSuccess() { return this.success != null; } public void setSuccessIsSet(boolean value) { if (!value) { this.success = null; } } public IOError getIo() { return this.io; } public getRowsTs_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case SUCCESS: if (value == null) { unsetSuccess(); } else { setSuccess((List<TRowResult>)value); } break; case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case SUCCESS: return getSuccess(); case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case SUCCESS: return isSetSuccess(); case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof getRowsTs_result) return this.equals((getRowsTs_result)that); return false; } public boolean equals(getRowsTs_result that) { if (that == null) return false; boolean this_present_success = true && this.isSetSuccess(); boolean that_present_success = true && that.isSetSuccess(); if (this_present_success || that_present_success) { if (!(this_present_success && that_present_success)) return false; if (!this.success.equals(that.success)) return false; } boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_success = true && (isSetSuccess()); list.add(present_success); if (present_success) list.add(success); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(getRowsTs_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess()); if (lastComparison != 0) { return lastComparison; } if (isSetSuccess()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("getRowsTs_result("); boolean first = true; sb.append("success:"); if (this.success == null) { sb.append("null"); } else { sb.append(this.success); } first = false; if (!first) sb.append(", "); sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class getRowsTs_resultStandardSchemeFactory implements SchemeFactory { public getRowsTs_resultStandardScheme getScheme() { return new getRowsTs_resultStandardScheme(); } } private static class getRowsTs_resultStandardScheme extends StandardScheme<getRowsTs_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, getRowsTs_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list304 = iprot.readListBegin(); struct.success = new ArrayList<TRowResult>(_list304.size); TRowResult _elem305; for (int _i306 = 0; _i306 < _list304.size; ++_i306) { _elem305 = new TRowResult(); _elem305.read(iprot); struct.success.add(_elem305); } iprot.readListEnd(); } struct.setSuccessIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, getRowsTs_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.success != null) { oprot.writeFieldBegin(SUCCESS_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size())); for (TRowResult _iter307 : struct.success) { _iter307.write(oprot); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class getRowsTs_resultTupleSchemeFactory implements SchemeFactory { public getRowsTs_resultTupleScheme getScheme() { return new getRowsTs_resultTupleScheme(); } } private static class getRowsTs_resultTupleScheme extends TupleScheme<getRowsTs_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, getRowsTs_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetSuccess()) { optionals.set(0); } if (struct.isSetIo()) { optionals.set(1); } oprot.writeBitSet(optionals, 2); if (struct.isSetSuccess()) { { oprot.writeI32(struct.success.size()); for (TRowResult _iter308 : struct.success) { _iter308.write(oprot); } } } if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, getRowsTs_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { { org.apache.thrift.protocol.TList _list309 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32()); struct.success = new ArrayList<TRowResult>(_list309.size); TRowResult _elem310; for (int _i311 = 0; _i311 < _list309.size; ++_i311) { _elem310 = new TRowResult(); _elem310.read(iprot); struct.success.add(_elem310); } } struct.setSuccessIsSet(true); } if (incoming.get(1)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class getRowsWithColumnsTs_args implements org.apache.thrift.TBase<getRowsWithColumnsTs_args, getRowsWithColumnsTs_args._Fields>, java.io.Serializable, Cloneable, Comparable<getRowsWithColumnsTs_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getRowsWithColumnsTs_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final org.apache.thrift.protocol.TField ROWS_FIELD_DESC = new org.apache.thrift.protocol.TField("rows", org.apache.thrift.protocol.TType.LIST, (short)2); private static final org.apache.thrift.protocol.TField COLUMNS_FIELD_DESC = new org.apache.thrift.protocol.TField("columns", org.apache.thrift.protocol.TType.LIST, (short)3); private static final org.apache.thrift.protocol.TField TIMESTAMP_FIELD_DESC = new org.apache.thrift.protocol.TField("timestamp", org.apache.thrift.protocol.TType.I64, (short)4); private static final org.apache.thrift.protocol.TField ATTRIBUTES_FIELD_DESC = new org.apache.thrift.protocol.TField("attributes", org.apache.thrift.protocol.TType.MAP, (short)5); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new getRowsWithColumnsTs_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new getRowsWithColumnsTs_argsTupleSchemeFactory()); } /** * name of table */ public ByteBuffer tableName; // required /** * row keys */ public List<ByteBuffer> rows; // required /** * List of columns to return, null for all columns */ public List<ByteBuffer> columns; // required public long timestamp; // required /** * Get attributes */ public Map<ByteBuffer,ByteBuffer> attributes; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * name of table */ TABLE_NAME((short)1, "tableName"), /** * row keys */ ROWS((short)2, "rows"), /** * List of columns to return, null for all columns */ COLUMNS((short)3, "columns"), TIMESTAMP((short)4, "timestamp"), /** * Get attributes */ ATTRIBUTES((short)5, "attributes"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; case 2: // ROWS return ROWS; case 3: // COLUMNS return COLUMNS; case 4: // TIMESTAMP return TIMESTAMP; case 5: // ATTRIBUTES return ATTRIBUTES; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments private static final int __TIMESTAMP_ISSET_ID = 0; private byte __isset_bitfield = 0; public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.ROWS, new org.apache.thrift.meta_data.FieldMetaData("rows", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); tmpMap.put(_Fields.COLUMNS, new org.apache.thrift.meta_data.FieldMetaData("columns", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); tmpMap.put(_Fields.TIMESTAMP, new org.apache.thrift.meta_data.FieldMetaData("timestamp", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.I64))); tmpMap.put(_Fields.ATTRIBUTES, new org.apache.thrift.meta_data.FieldMetaData("attributes", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.MapMetaData(org.apache.thrift.protocol.TType.MAP, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"), new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(getRowsWithColumnsTs_args.class, metaDataMap); } public getRowsWithColumnsTs_args() { } public getRowsWithColumnsTs_args( ByteBuffer tableName, List<ByteBuffer> rows, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); this.rows = rows; this.columns = columns; this.timestamp = timestamp; setTimestampIsSet(true); this.attributes = attributes; } /** * Performs a deep copy on <i>other</i>. */ public getRowsWithColumnsTs_args(getRowsWithColumnsTs_args other) { __isset_bitfield = other.__isset_bitfield; if (other.isSetTableName()) { this.tableName = other.tableName; } if (other.isSetRows()) { List<ByteBuffer> __this__rows = new ArrayList<ByteBuffer>(other.rows.size()); for (ByteBuffer other_element : other.rows) { __this__rows.add(other_element); } this.rows = __this__rows; } if (other.isSetColumns()) { List<ByteBuffer> __this__columns = new ArrayList<ByteBuffer>(other.columns.size()); for (ByteBuffer other_element : other.columns) { __this__columns.add(other_element); } this.columns = __this__columns; } this.timestamp = other.timestamp; if (other.isSetAttributes()) { Map<ByteBuffer,ByteBuffer> __this__attributes = new HashMap<ByteBuffer,ByteBuffer>(other.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> other_element : other.attributes.entrySet()) { ByteBuffer other_element_key = other_element.getKey(); ByteBuffer other_element_value = other_element.getValue(); ByteBuffer __this__attributes_copy_key = other_element_key; ByteBuffer __this__attributes_copy_value = other_element_value; __this__attributes.put(__this__attributes_copy_key, __this__attributes_copy_value); } this.attributes = __this__attributes; } } public getRowsWithColumnsTs_args deepCopy() { return new getRowsWithColumnsTs_args(this); } @Override public void clear() { this.tableName = null; this.rows = null; this.columns = null; setTimestampIsSet(false); this.timestamp = 0; this.attributes = null; } /** * name of table */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * name of table */ public getRowsWithColumnsTs_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public getRowsWithColumnsTs_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } public int getRowsSize() { return (this.rows == null) ? 0 : this.rows.size(); } public java.util.Iterator<ByteBuffer> getRowsIterator() { return (this.rows == null) ? null : this.rows.iterator(); } public void addToRows(ByteBuffer elem) { if (this.rows == null) { this.rows = new ArrayList<ByteBuffer>(); } this.rows.add(elem); } /** * row keys */ public List<ByteBuffer> getRows() { return this.rows; } /** * row keys */ public getRowsWithColumnsTs_args setRows(List<ByteBuffer> rows) { this.rows = rows; return this; } public void unsetRows() { this.rows = null; } /** Returns true if field rows is set (has been assigned a value) and false otherwise */ public boolean isSetRows() { return this.rows != null; } public void setRowsIsSet(boolean value) { if (!value) { this.rows = null; } } public int getColumnsSize() { return (this.columns == null) ? 0 : this.columns.size(); } public java.util.Iterator<ByteBuffer> getColumnsIterator() { return (this.columns == null) ? null : this.columns.iterator(); } public void addToColumns(ByteBuffer elem) { if (this.columns == null) { this.columns = new ArrayList<ByteBuffer>(); } this.columns.add(elem); } /** * List of columns to return, null for all columns */ public List<ByteBuffer> getColumns() { return this.columns; } /** * List of columns to return, null for all columns */ public getRowsWithColumnsTs_args setColumns(List<ByteBuffer> columns) { this.columns = columns; return this; } public void unsetColumns() { this.columns = null; } /** Returns true if field columns is set (has been assigned a value) and false otherwise */ public boolean isSetColumns() { return this.columns != null; } public void setColumnsIsSet(boolean value) { if (!value) { this.columns = null; } } public long getTimestamp() { return this.timestamp; } public getRowsWithColumnsTs_args setTimestamp(long timestamp) { this.timestamp = timestamp; setTimestampIsSet(true); return this; } public void unsetTimestamp() { __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __TIMESTAMP_ISSET_ID); } /** Returns true if field timestamp is set (has been assigned a value) and false otherwise */ public boolean isSetTimestamp() { return EncodingUtils.testBit(__isset_bitfield, __TIMESTAMP_ISSET_ID); } public void setTimestampIsSet(boolean value) { __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __TIMESTAMP_ISSET_ID, value); } public int getAttributesSize() { return (this.attributes == null) ? 0 : this.attributes.size(); } public void putToAttributes(ByteBuffer key, ByteBuffer val) { if (this.attributes == null) { this.attributes = new HashMap<ByteBuffer,ByteBuffer>(); } this.attributes.put(key, val); } /** * Get attributes */ public Map<ByteBuffer,ByteBuffer> getAttributes() { return this.attributes; } /** * Get attributes */ public getRowsWithColumnsTs_args setAttributes(Map<ByteBuffer,ByteBuffer> attributes) { this.attributes = attributes; return this; } public void unsetAttributes() { this.attributes = null; } /** Returns true if field attributes is set (has been assigned a value) and false otherwise */ public boolean isSetAttributes() { return this.attributes != null; } public void setAttributesIsSet(boolean value) { if (!value) { this.attributes = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; case ROWS: if (value == null) { unsetRows(); } else { setRows((List<ByteBuffer>)value); } break; case COLUMNS: if (value == null) { unsetColumns(); } else { setColumns((List<ByteBuffer>)value); } break; case TIMESTAMP: if (value == null) { unsetTimestamp(); } else { setTimestamp((Long)value); } break; case ATTRIBUTES: if (value == null) { unsetAttributes(); } else { setAttributes((Map<ByteBuffer,ByteBuffer>)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); case ROWS: return getRows(); case COLUMNS: return getColumns(); case TIMESTAMP: return getTimestamp(); case ATTRIBUTES: return getAttributes(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); case ROWS: return isSetRows(); case COLUMNS: return isSetColumns(); case TIMESTAMP: return isSetTimestamp(); case ATTRIBUTES: return isSetAttributes(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof getRowsWithColumnsTs_args) return this.equals((getRowsWithColumnsTs_args)that); return false; } public boolean equals(getRowsWithColumnsTs_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } boolean this_present_rows = true && this.isSetRows(); boolean that_present_rows = true && that.isSetRows(); if (this_present_rows || that_present_rows) { if (!(this_present_rows && that_present_rows)) return false; if (!this.rows.equals(that.rows)) return false; } boolean this_present_columns = true && this.isSetColumns(); boolean that_present_columns = true && that.isSetColumns(); if (this_present_columns || that_present_columns) { if (!(this_present_columns && that_present_columns)) return false; if (!this.columns.equals(that.columns)) return false; } boolean this_present_timestamp = true; boolean that_present_timestamp = true; if (this_present_timestamp || that_present_timestamp) { if (!(this_present_timestamp && that_present_timestamp)) return false; if (this.timestamp != that.timestamp) return false; } boolean this_present_attributes = true && this.isSetAttributes(); boolean that_present_attributes = true && that.isSetAttributes(); if (this_present_attributes || that_present_attributes) { if (!(this_present_attributes && that_present_attributes)) return false; if (!this.attributes.equals(that.attributes)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); boolean present_rows = true && (isSetRows()); list.add(present_rows); if (present_rows) list.add(rows); boolean present_columns = true && (isSetColumns()); list.add(present_columns); if (present_columns) list.add(columns); boolean present_timestamp = true; list.add(present_timestamp); if (present_timestamp) list.add(timestamp); boolean present_attributes = true && (isSetAttributes()); list.add(present_attributes); if (present_attributes) list.add(attributes); return list.hashCode(); } @Override public int compareTo(getRowsWithColumnsTs_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetRows()).compareTo(other.isSetRows()); if (lastComparison != 0) { return lastComparison; } if (isSetRows()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.rows, other.rows); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetColumns()).compareTo(other.isSetColumns()); if (lastComparison != 0) { return lastComparison; } if (isSetColumns()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.columns, other.columns); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetTimestamp()).compareTo(other.isSetTimestamp()); if (lastComparison != 0) { return lastComparison; } if (isSetTimestamp()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.timestamp, other.timestamp); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetAttributes()).compareTo(other.isSetAttributes()); if (lastComparison != 0) { return lastComparison; } if (isSetAttributes()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.attributes, other.attributes); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("getRowsWithColumnsTs_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; if (!first) sb.append(", "); sb.append("rows:"); if (this.rows == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.rows, sb); } first = false; if (!first) sb.append(", "); sb.append("columns:"); if (this.columns == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.columns, sb); } first = false; if (!first) sb.append(", "); sb.append("timestamp:"); sb.append(this.timestamp); first = false; if (!first) sb.append(", "); sb.append("attributes:"); if (this.attributes == null) { sb.append("null"); } else { sb.append(this.attributes); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { // it doesn't seem like you should have to do this, but java serialization is wacky, and doesn't call the default constructor. __isset_bitfield = 0; read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class getRowsWithColumnsTs_argsStandardSchemeFactory implements SchemeFactory { public getRowsWithColumnsTs_argsStandardScheme getScheme() { return new getRowsWithColumnsTs_argsStandardScheme(); } } private static class getRowsWithColumnsTs_argsStandardScheme extends StandardScheme<getRowsWithColumnsTs_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, getRowsWithColumnsTs_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // ROWS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list312 = iprot.readListBegin(); struct.rows = new ArrayList<ByteBuffer>(_list312.size); ByteBuffer _elem313; for (int _i314 = 0; _i314 < _list312.size; ++_i314) { _elem313 = iprot.readBinary(); struct.rows.add(_elem313); } iprot.readListEnd(); } struct.setRowsIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 3: // COLUMNS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list315 = iprot.readListBegin(); struct.columns = new ArrayList<ByteBuffer>(_list315.size); ByteBuffer _elem316; for (int _i317 = 0; _i317 < _list315.size; ++_i317) { _elem316 = iprot.readBinary(); struct.columns.add(_elem316); } iprot.readListEnd(); } struct.setColumnsIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 4: // TIMESTAMP if (schemeField.type == org.apache.thrift.protocol.TType.I64) { struct.timestamp = iprot.readI64(); struct.setTimestampIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 5: // ATTRIBUTES if (schemeField.type == org.apache.thrift.protocol.TType.MAP) { { org.apache.thrift.protocol.TMap _map318 = iprot.readMapBegin(); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map318.size); ByteBuffer _key319; ByteBuffer _val320; for (int _i321 = 0; _i321 < _map318.size; ++_i321) { _key319 = iprot.readBinary(); _val320 = iprot.readBinary(); struct.attributes.put(_key319, _val320); } iprot.readMapEnd(); } struct.setAttributesIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, getRowsWithColumnsTs_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } if (struct.rows != null) { oprot.writeFieldBegin(ROWS_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.rows.size())); for (ByteBuffer _iter322 : struct.rows) { oprot.writeBinary(_iter322); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } if (struct.columns != null) { oprot.writeFieldBegin(COLUMNS_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.columns.size())); for (ByteBuffer _iter323 : struct.columns) { oprot.writeBinary(_iter323); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldBegin(TIMESTAMP_FIELD_DESC); oprot.writeI64(struct.timestamp); oprot.writeFieldEnd(); if (struct.attributes != null) { oprot.writeFieldBegin(ATTRIBUTES_FIELD_DESC); { oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, struct.attributes.size())); for (Map.Entry<ByteBuffer, ByteBuffer> _iter324 : struct.attributes.entrySet()) { oprot.writeBinary(_iter324.getKey()); oprot.writeBinary(_iter324.getValue()); } oprot.writeMapEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class getRowsWithColumnsTs_argsTupleSchemeFactory implements SchemeFactory { public getRowsWithColumnsTs_argsTupleScheme getScheme() { return new getRowsWithColumnsTs_argsTupleScheme(); } } private static class getRowsWithColumnsTs_argsTupleScheme extends TupleScheme<getRowsWithColumnsTs_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, getRowsWithColumnsTs_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } if (struct.isSetRows()) { optionals.set(1); } if (struct.isSetColumns()) { optionals.set(2); } if (struct.isSetTimestamp()) { optionals.set(3); } if (struct.isSetAttributes()) { optionals.set(4); } oprot.writeBitSet(optionals, 5); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } if (struct.isSetRows()) { { oprot.writeI32(struct.rows.size()); for (ByteBuffer _iter325 : struct.rows) { oprot.writeBinary(_iter325); } } } if (struct.isSetColumns()) { { oprot.writeI32(struct.columns.size()); for (ByteBuffer _iter326 : struct.columns) { oprot.writeBinary(_iter326); } } } if (struct.isSetTimestamp()) { oprot.writeI64(struct.timestamp); } if (struct.isSetAttributes()) { { oprot.writeI32(struct.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> _iter327 : struct.attributes.entrySet()) { oprot.writeBinary(_iter327.getKey()); oprot.writeBinary(_iter327.getValue()); } } } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, getRowsWithColumnsTs_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(5); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } if (incoming.get(1)) { { org.apache.thrift.protocol.TList _list328 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.rows = new ArrayList<ByteBuffer>(_list328.size); ByteBuffer _elem329; for (int _i330 = 0; _i330 < _list328.size; ++_i330) { _elem329 = iprot.readBinary(); struct.rows.add(_elem329); } } struct.setRowsIsSet(true); } if (incoming.get(2)) { { org.apache.thrift.protocol.TList _list331 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.columns = new ArrayList<ByteBuffer>(_list331.size); ByteBuffer _elem332; for (int _i333 = 0; _i333 < _list331.size; ++_i333) { _elem332 = iprot.readBinary(); struct.columns.add(_elem332); } } struct.setColumnsIsSet(true); } if (incoming.get(3)) { struct.timestamp = iprot.readI64(); struct.setTimestampIsSet(true); } if (incoming.get(4)) { { org.apache.thrift.protocol.TMap _map334 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map334.size); ByteBuffer _key335; ByteBuffer _val336; for (int _i337 = 0; _i337 < _map334.size; ++_i337) { _key335 = iprot.readBinary(); _val336 = iprot.readBinary(); struct.attributes.put(_key335, _val336); } } struct.setAttributesIsSet(true); } } } } public static class getRowsWithColumnsTs_result implements org.apache.thrift.TBase<getRowsWithColumnsTs_result, getRowsWithColumnsTs_result._Fields>, java.io.Serializable, Cloneable, Comparable<getRowsWithColumnsTs_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getRowsWithColumnsTs_result"); private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.LIST, (short)0); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new getRowsWithColumnsTs_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new getRowsWithColumnsTs_resultTupleSchemeFactory()); } public List<TRowResult> success; // required public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { SUCCESS((short)0, "success"), IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 0: // SUCCESS return SUCCESS; case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.SUCCESS, new org.apache.thrift.meta_data.FieldMetaData("success", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, TRowResult.class)))); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(getRowsWithColumnsTs_result.class, metaDataMap); } public getRowsWithColumnsTs_result() { } public getRowsWithColumnsTs_result( List<TRowResult> success, IOError io) { this(); this.success = success; this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public getRowsWithColumnsTs_result(getRowsWithColumnsTs_result other) { if (other.isSetSuccess()) { List<TRowResult> __this__success = new ArrayList<TRowResult>(other.success.size()); for (TRowResult other_element : other.success) { __this__success.add(new TRowResult(other_element)); } this.success = __this__success; } if (other.isSetIo()) { this.io = new IOError(other.io); } } public getRowsWithColumnsTs_result deepCopy() { return new getRowsWithColumnsTs_result(this); } @Override public void clear() { this.success = null; this.io = null; } public int getSuccessSize() { return (this.success == null) ? 0 : this.success.size(); } public java.util.Iterator<TRowResult> getSuccessIterator() { return (this.success == null) ? null : this.success.iterator(); } public void addToSuccess(TRowResult elem) { if (this.success == null) { this.success = new ArrayList<TRowResult>(); } this.success.add(elem); } public List<TRowResult> getSuccess() { return this.success; } public getRowsWithColumnsTs_result setSuccess(List<TRowResult> success) { this.success = success; return this; } public void unsetSuccess() { this.success = null; } /** Returns true if field success is set (has been assigned a value) and false otherwise */ public boolean isSetSuccess() { return this.success != null; } public void setSuccessIsSet(boolean value) { if (!value) { this.success = null; } } public IOError getIo() { return this.io; } public getRowsWithColumnsTs_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case SUCCESS: if (value == null) { unsetSuccess(); } else { setSuccess((List<TRowResult>)value); } break; case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case SUCCESS: return getSuccess(); case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case SUCCESS: return isSetSuccess(); case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof getRowsWithColumnsTs_result) return this.equals((getRowsWithColumnsTs_result)that); return false; } public boolean equals(getRowsWithColumnsTs_result that) { if (that == null) return false; boolean this_present_success = true && this.isSetSuccess(); boolean that_present_success = true && that.isSetSuccess(); if (this_present_success || that_present_success) { if (!(this_present_success && that_present_success)) return false; if (!this.success.equals(that.success)) return false; } boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_success = true && (isSetSuccess()); list.add(present_success); if (present_success) list.add(success); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(getRowsWithColumnsTs_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess()); if (lastComparison != 0) { return lastComparison; } if (isSetSuccess()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("getRowsWithColumnsTs_result("); boolean first = true; sb.append("success:"); if (this.success == null) { sb.append("null"); } else { sb.append(this.success); } first = false; if (!first) sb.append(", "); sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class getRowsWithColumnsTs_resultStandardSchemeFactory implements SchemeFactory { public getRowsWithColumnsTs_resultStandardScheme getScheme() { return new getRowsWithColumnsTs_resultStandardScheme(); } } private static class getRowsWithColumnsTs_resultStandardScheme extends StandardScheme<getRowsWithColumnsTs_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, getRowsWithColumnsTs_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list338 = iprot.readListBegin(); struct.success = new ArrayList<TRowResult>(_list338.size); TRowResult _elem339; for (int _i340 = 0; _i340 < _list338.size; ++_i340) { _elem339 = new TRowResult(); _elem339.read(iprot); struct.success.add(_elem339); } iprot.readListEnd(); } struct.setSuccessIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, getRowsWithColumnsTs_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.success != null) { oprot.writeFieldBegin(SUCCESS_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size())); for (TRowResult _iter341 : struct.success) { _iter341.write(oprot); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class getRowsWithColumnsTs_resultTupleSchemeFactory implements SchemeFactory { public getRowsWithColumnsTs_resultTupleScheme getScheme() { return new getRowsWithColumnsTs_resultTupleScheme(); } } private static class getRowsWithColumnsTs_resultTupleScheme extends TupleScheme<getRowsWithColumnsTs_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, getRowsWithColumnsTs_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetSuccess()) { optionals.set(0); } if (struct.isSetIo()) { optionals.set(1); } oprot.writeBitSet(optionals, 2); if (struct.isSetSuccess()) { { oprot.writeI32(struct.success.size()); for (TRowResult _iter342 : struct.success) { _iter342.write(oprot); } } } if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, getRowsWithColumnsTs_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { { org.apache.thrift.protocol.TList _list343 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32()); struct.success = new ArrayList<TRowResult>(_list343.size); TRowResult _elem344; for (int _i345 = 0; _i345 < _list343.size; ++_i345) { _elem344 = new TRowResult(); _elem344.read(iprot); struct.success.add(_elem344); } } struct.setSuccessIsSet(true); } if (incoming.get(1)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class mutateRow_args implements org.apache.thrift.TBase<mutateRow_args, mutateRow_args._Fields>, java.io.Serializable, Cloneable, Comparable<mutateRow_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("mutateRow_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final org.apache.thrift.protocol.TField ROW_FIELD_DESC = new org.apache.thrift.protocol.TField("row", org.apache.thrift.protocol.TType.STRING, (short)2); private static final org.apache.thrift.protocol.TField MUTATIONS_FIELD_DESC = new org.apache.thrift.protocol.TField("mutations", org.apache.thrift.protocol.TType.LIST, (short)3); private static final org.apache.thrift.protocol.TField ATTRIBUTES_FIELD_DESC = new org.apache.thrift.protocol.TField("attributes", org.apache.thrift.protocol.TType.MAP, (short)4); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new mutateRow_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new mutateRow_argsTupleSchemeFactory()); } /** * name of table */ public ByteBuffer tableName; // required /** * row key */ public ByteBuffer row; // required /** * list of mutation commands */ public List<Mutation> mutations; // required /** * Mutation attributes */ public Map<ByteBuffer,ByteBuffer> attributes; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * name of table */ TABLE_NAME((short)1, "tableName"), /** * row key */ ROW((short)2, "row"), /** * list of mutation commands */ MUTATIONS((short)3, "mutations"), /** * Mutation attributes */ ATTRIBUTES((short)4, "attributes"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; case 2: // ROW return ROW; case 3: // MUTATIONS return MUTATIONS; case 4: // ATTRIBUTES return ATTRIBUTES; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.ROW, new org.apache.thrift.meta_data.FieldMetaData("row", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.MUTATIONS, new org.apache.thrift.meta_data.FieldMetaData("mutations", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, Mutation.class)))); tmpMap.put(_Fields.ATTRIBUTES, new org.apache.thrift.meta_data.FieldMetaData("attributes", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.MapMetaData(org.apache.thrift.protocol.TType.MAP, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"), new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(mutateRow_args.class, metaDataMap); } public mutateRow_args() { } public mutateRow_args( ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, Map<ByteBuffer,ByteBuffer> attributes) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); this.row = org.apache.thrift.TBaseHelper.copyBinary(row); this.mutations = mutations; this.attributes = attributes; } /** * Performs a deep copy on <i>other</i>. */ public mutateRow_args(mutateRow_args other) { if (other.isSetTableName()) { this.tableName = other.tableName; } if (other.isSetRow()) { this.row = other.row; } if (other.isSetMutations()) { List<Mutation> __this__mutations = new ArrayList<Mutation>(other.mutations.size()); for (Mutation other_element : other.mutations) { __this__mutations.add(new Mutation(other_element)); } this.mutations = __this__mutations; } if (other.isSetAttributes()) { Map<ByteBuffer,ByteBuffer> __this__attributes = new HashMap<ByteBuffer,ByteBuffer>(other.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> other_element : other.attributes.entrySet()) { ByteBuffer other_element_key = other_element.getKey(); ByteBuffer other_element_value = other_element.getValue(); ByteBuffer __this__attributes_copy_key = other_element_key; ByteBuffer __this__attributes_copy_value = other_element_value; __this__attributes.put(__this__attributes_copy_key, __this__attributes_copy_value); } this.attributes = __this__attributes; } } public mutateRow_args deepCopy() { return new mutateRow_args(this); } @Override public void clear() { this.tableName = null; this.row = null; this.mutations = null; this.attributes = null; } /** * name of table */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * name of table */ public mutateRow_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public mutateRow_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } /** * row key */ public byte[] getRow() { setRow(org.apache.thrift.TBaseHelper.rightSize(row)); return row == null ? null : row.array(); } public ByteBuffer bufferForRow() { return org.apache.thrift.TBaseHelper.copyBinary(row); } /** * row key */ public mutateRow_args setRow(byte[] row) { this.row = row == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(row, row.length)); return this; } public mutateRow_args setRow(ByteBuffer row) { this.row = org.apache.thrift.TBaseHelper.copyBinary(row); return this; } public void unsetRow() { this.row = null; } /** Returns true if field row is set (has been assigned a value) and false otherwise */ public boolean isSetRow() { return this.row != null; } public void setRowIsSet(boolean value) { if (!value) { this.row = null; } } public int getMutationsSize() { return (this.mutations == null) ? 0 : this.mutations.size(); } public java.util.Iterator<Mutation> getMutationsIterator() { return (this.mutations == null) ? null : this.mutations.iterator(); } public void addToMutations(Mutation elem) { if (this.mutations == null) { this.mutations = new ArrayList<Mutation>(); } this.mutations.add(elem); } /** * list of mutation commands */ public List<Mutation> getMutations() { return this.mutations; } /** * list of mutation commands */ public mutateRow_args setMutations(List<Mutation> mutations) { this.mutations = mutations; return this; } public void unsetMutations() { this.mutations = null; } /** Returns true if field mutations is set (has been assigned a value) and false otherwise */ public boolean isSetMutations() { return this.mutations != null; } public void setMutationsIsSet(boolean value) { if (!value) { this.mutations = null; } } public int getAttributesSize() { return (this.attributes == null) ? 0 : this.attributes.size(); } public void putToAttributes(ByteBuffer key, ByteBuffer val) { if (this.attributes == null) { this.attributes = new HashMap<ByteBuffer,ByteBuffer>(); } this.attributes.put(key, val); } /** * Mutation attributes */ public Map<ByteBuffer,ByteBuffer> getAttributes() { return this.attributes; } /** * Mutation attributes */ public mutateRow_args setAttributes(Map<ByteBuffer,ByteBuffer> attributes) { this.attributes = attributes; return this; } public void unsetAttributes() { this.attributes = null; } /** Returns true if field attributes is set (has been assigned a value) and false otherwise */ public boolean isSetAttributes() { return this.attributes != null; } public void setAttributesIsSet(boolean value) { if (!value) { this.attributes = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; case ROW: if (value == null) { unsetRow(); } else { setRow((ByteBuffer)value); } break; case MUTATIONS: if (value == null) { unsetMutations(); } else { setMutations((List<Mutation>)value); } break; case ATTRIBUTES: if (value == null) { unsetAttributes(); } else { setAttributes((Map<ByteBuffer,ByteBuffer>)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); case ROW: return getRow(); case MUTATIONS: return getMutations(); case ATTRIBUTES: return getAttributes(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); case ROW: return isSetRow(); case MUTATIONS: return isSetMutations(); case ATTRIBUTES: return isSetAttributes(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof mutateRow_args) return this.equals((mutateRow_args)that); return false; } public boolean equals(mutateRow_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } boolean this_present_row = true && this.isSetRow(); boolean that_present_row = true && that.isSetRow(); if (this_present_row || that_present_row) { if (!(this_present_row && that_present_row)) return false; if (!this.row.equals(that.row)) return false; } boolean this_present_mutations = true && this.isSetMutations(); boolean that_present_mutations = true && that.isSetMutations(); if (this_present_mutations || that_present_mutations) { if (!(this_present_mutations && that_present_mutations)) return false; if (!this.mutations.equals(that.mutations)) return false; } boolean this_present_attributes = true && this.isSetAttributes(); boolean that_present_attributes = true && that.isSetAttributes(); if (this_present_attributes || that_present_attributes) { if (!(this_present_attributes && that_present_attributes)) return false; if (!this.attributes.equals(that.attributes)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); boolean present_row = true && (isSetRow()); list.add(present_row); if (present_row) list.add(row); boolean present_mutations = true && (isSetMutations()); list.add(present_mutations); if (present_mutations) list.add(mutations); boolean present_attributes = true && (isSetAttributes()); list.add(present_attributes); if (present_attributes) list.add(attributes); return list.hashCode(); } @Override public int compareTo(mutateRow_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetRow()).compareTo(other.isSetRow()); if (lastComparison != 0) { return lastComparison; } if (isSetRow()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.row, other.row); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetMutations()).compareTo(other.isSetMutations()); if (lastComparison != 0) { return lastComparison; } if (isSetMutations()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.mutations, other.mutations); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetAttributes()).compareTo(other.isSetAttributes()); if (lastComparison != 0) { return lastComparison; } if (isSetAttributes()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.attributes, other.attributes); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("mutateRow_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; if (!first) sb.append(", "); sb.append("row:"); if (this.row == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.row, sb); } first = false; if (!first) sb.append(", "); sb.append("mutations:"); if (this.mutations == null) { sb.append("null"); } else { sb.append(this.mutations); } first = false; if (!first) sb.append(", "); sb.append("attributes:"); if (this.attributes == null) { sb.append("null"); } else { sb.append(this.attributes); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class mutateRow_argsStandardSchemeFactory implements SchemeFactory { public mutateRow_argsStandardScheme getScheme() { return new mutateRow_argsStandardScheme(); } } private static class mutateRow_argsStandardScheme extends StandardScheme<mutateRow_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, mutateRow_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // ROW if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.row = iprot.readBinary(); struct.setRowIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 3: // MUTATIONS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list346 = iprot.readListBegin(); struct.mutations = new ArrayList<Mutation>(_list346.size); Mutation _elem347; for (int _i348 = 0; _i348 < _list346.size; ++_i348) { _elem347 = new Mutation(); _elem347.read(iprot); struct.mutations.add(_elem347); } iprot.readListEnd(); } struct.setMutationsIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 4: // ATTRIBUTES if (schemeField.type == org.apache.thrift.protocol.TType.MAP) { { org.apache.thrift.protocol.TMap _map349 = iprot.readMapBegin(); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map349.size); ByteBuffer _key350; ByteBuffer _val351; for (int _i352 = 0; _i352 < _map349.size; ++_i352) { _key350 = iprot.readBinary(); _val351 = iprot.readBinary(); struct.attributes.put(_key350, _val351); } iprot.readMapEnd(); } struct.setAttributesIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, mutateRow_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } if (struct.row != null) { oprot.writeFieldBegin(ROW_FIELD_DESC); oprot.writeBinary(struct.row); oprot.writeFieldEnd(); } if (struct.mutations != null) { oprot.writeFieldBegin(MUTATIONS_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.mutations.size())); for (Mutation _iter353 : struct.mutations) { _iter353.write(oprot); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } if (struct.attributes != null) { oprot.writeFieldBegin(ATTRIBUTES_FIELD_DESC); { oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, struct.attributes.size())); for (Map.Entry<ByteBuffer, ByteBuffer> _iter354 : struct.attributes.entrySet()) { oprot.writeBinary(_iter354.getKey()); oprot.writeBinary(_iter354.getValue()); } oprot.writeMapEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class mutateRow_argsTupleSchemeFactory implements SchemeFactory { public mutateRow_argsTupleScheme getScheme() { return new mutateRow_argsTupleScheme(); } } private static class mutateRow_argsTupleScheme extends TupleScheme<mutateRow_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, mutateRow_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } if (struct.isSetRow()) { optionals.set(1); } if (struct.isSetMutations()) { optionals.set(2); } if (struct.isSetAttributes()) { optionals.set(3); } oprot.writeBitSet(optionals, 4); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } if (struct.isSetRow()) { oprot.writeBinary(struct.row); } if (struct.isSetMutations()) { { oprot.writeI32(struct.mutations.size()); for (Mutation _iter355 : struct.mutations) { _iter355.write(oprot); } } } if (struct.isSetAttributes()) { { oprot.writeI32(struct.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> _iter356 : struct.attributes.entrySet()) { oprot.writeBinary(_iter356.getKey()); oprot.writeBinary(_iter356.getValue()); } } } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, mutateRow_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(4); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } if (incoming.get(1)) { struct.row = iprot.readBinary(); struct.setRowIsSet(true); } if (incoming.get(2)) { { org.apache.thrift.protocol.TList _list357 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32()); struct.mutations = new ArrayList<Mutation>(_list357.size); Mutation _elem358; for (int _i359 = 0; _i359 < _list357.size; ++_i359) { _elem358 = new Mutation(); _elem358.read(iprot); struct.mutations.add(_elem358); } } struct.setMutationsIsSet(true); } if (incoming.get(3)) { { org.apache.thrift.protocol.TMap _map360 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map360.size); ByteBuffer _key361; ByteBuffer _val362; for (int _i363 = 0; _i363 < _map360.size; ++_i363) { _key361 = iprot.readBinary(); _val362 = iprot.readBinary(); struct.attributes.put(_key361, _val362); } } struct.setAttributesIsSet(true); } } } } public static class mutateRow_result implements org.apache.thrift.TBase<mutateRow_result, mutateRow_result._Fields>, java.io.Serializable, Cloneable, Comparable<mutateRow_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("mutateRow_result"); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final org.apache.thrift.protocol.TField IA_FIELD_DESC = new org.apache.thrift.protocol.TField("ia", org.apache.thrift.protocol.TType.STRUCT, (short)2); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new mutateRow_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new mutateRow_resultTupleSchemeFactory()); } public IOError io; // required public IllegalArgument ia; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { IO((short)1, "io"), IA((short)2, "ia"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // IO return IO; case 2: // IA return IA; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); tmpMap.put(_Fields.IA, new org.apache.thrift.meta_data.FieldMetaData("ia", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(mutateRow_result.class, metaDataMap); } public mutateRow_result() { } public mutateRow_result( IOError io, IllegalArgument ia) { this(); this.io = io; this.ia = ia; } /** * Performs a deep copy on <i>other</i>. */ public mutateRow_result(mutateRow_result other) { if (other.isSetIo()) { this.io = new IOError(other.io); } if (other.isSetIa()) { this.ia = new IllegalArgument(other.ia); } } public mutateRow_result deepCopy() { return new mutateRow_result(this); } @Override public void clear() { this.io = null; this.ia = null; } public IOError getIo() { return this.io; } public mutateRow_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public IllegalArgument getIa() { return this.ia; } public mutateRow_result setIa(IllegalArgument ia) { this.ia = ia; return this; } public void unsetIa() { this.ia = null; } /** Returns true if field ia is set (has been assigned a value) and false otherwise */ public boolean isSetIa() { return this.ia != null; } public void setIaIsSet(boolean value) { if (!value) { this.ia = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; case IA: if (value == null) { unsetIa(); } else { setIa((IllegalArgument)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case IO: return getIo(); case IA: return getIa(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case IO: return isSetIo(); case IA: return isSetIa(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof mutateRow_result) return this.equals((mutateRow_result)that); return false; } public boolean equals(mutateRow_result that) { if (that == null) return false; boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } boolean this_present_ia = true && this.isSetIa(); boolean that_present_ia = true && that.isSetIa(); if (this_present_ia || that_present_ia) { if (!(this_present_ia && that_present_ia)) return false; if (!this.ia.equals(that.ia)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); boolean present_ia = true && (isSetIa()); list.add(present_ia); if (present_ia) list.add(ia); return list.hashCode(); } @Override public int compareTo(mutateRow_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIa()).compareTo(other.isSetIa()); if (lastComparison != 0) { return lastComparison; } if (isSetIa()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ia, other.ia); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("mutateRow_result("); boolean first = true; sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; if (!first) sb.append(", "); sb.append("ia:"); if (this.ia == null) { sb.append("null"); } else { sb.append(this.ia); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class mutateRow_resultStandardSchemeFactory implements SchemeFactory { public mutateRow_resultStandardScheme getScheme() { return new mutateRow_resultStandardScheme(); } } private static class mutateRow_resultStandardScheme extends StandardScheme<mutateRow_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, mutateRow_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // IA if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.ia = new IllegalArgument(); struct.ia.read(iprot); struct.setIaIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, mutateRow_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } if (struct.ia != null) { oprot.writeFieldBegin(IA_FIELD_DESC); struct.ia.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class mutateRow_resultTupleSchemeFactory implements SchemeFactory { public mutateRow_resultTupleScheme getScheme() { return new mutateRow_resultTupleScheme(); } } private static class mutateRow_resultTupleScheme extends TupleScheme<mutateRow_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, mutateRow_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetIo()) { optionals.set(0); } if (struct.isSetIa()) { optionals.set(1); } oprot.writeBitSet(optionals, 2); if (struct.isSetIo()) { struct.io.write(oprot); } if (struct.isSetIa()) { struct.ia.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, mutateRow_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } if (incoming.get(1)) { struct.ia = new IllegalArgument(); struct.ia.read(iprot); struct.setIaIsSet(true); } } } } public static class mutateRowTs_args implements org.apache.thrift.TBase<mutateRowTs_args, mutateRowTs_args._Fields>, java.io.Serializable, Cloneable, Comparable<mutateRowTs_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("mutateRowTs_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final org.apache.thrift.protocol.TField ROW_FIELD_DESC = new org.apache.thrift.protocol.TField("row", org.apache.thrift.protocol.TType.STRING, (short)2); private static final org.apache.thrift.protocol.TField MUTATIONS_FIELD_DESC = new org.apache.thrift.protocol.TField("mutations", org.apache.thrift.protocol.TType.LIST, (short)3); private static final org.apache.thrift.protocol.TField TIMESTAMP_FIELD_DESC = new org.apache.thrift.protocol.TField("timestamp", org.apache.thrift.protocol.TType.I64, (short)4); private static final org.apache.thrift.protocol.TField ATTRIBUTES_FIELD_DESC = new org.apache.thrift.protocol.TField("attributes", org.apache.thrift.protocol.TType.MAP, (short)5); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new mutateRowTs_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new mutateRowTs_argsTupleSchemeFactory()); } /** * name of table */ public ByteBuffer tableName; // required /** * row key */ public ByteBuffer row; // required /** * list of mutation commands */ public List<Mutation> mutations; // required /** * timestamp */ public long timestamp; // required /** * Mutation attributes */ public Map<ByteBuffer,ByteBuffer> attributes; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * name of table */ TABLE_NAME((short)1, "tableName"), /** * row key */ ROW((short)2, "row"), /** * list of mutation commands */ MUTATIONS((short)3, "mutations"), /** * timestamp */ TIMESTAMP((short)4, "timestamp"), /** * Mutation attributes */ ATTRIBUTES((short)5, "attributes"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; case 2: // ROW return ROW; case 3: // MUTATIONS return MUTATIONS; case 4: // TIMESTAMP return TIMESTAMP; case 5: // ATTRIBUTES return ATTRIBUTES; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments private static final int __TIMESTAMP_ISSET_ID = 0; private byte __isset_bitfield = 0; public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.ROW, new org.apache.thrift.meta_data.FieldMetaData("row", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.MUTATIONS, new org.apache.thrift.meta_data.FieldMetaData("mutations", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, Mutation.class)))); tmpMap.put(_Fields.TIMESTAMP, new org.apache.thrift.meta_data.FieldMetaData("timestamp", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.I64))); tmpMap.put(_Fields.ATTRIBUTES, new org.apache.thrift.meta_data.FieldMetaData("attributes", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.MapMetaData(org.apache.thrift.protocol.TType.MAP, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"), new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(mutateRowTs_args.class, metaDataMap); } public mutateRowTs_args() { } public mutateRowTs_args( ByteBuffer tableName, ByteBuffer row, List<Mutation> mutations, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); this.row = org.apache.thrift.TBaseHelper.copyBinary(row); this.mutations = mutations; this.timestamp = timestamp; setTimestampIsSet(true); this.attributes = attributes; } /** * Performs a deep copy on <i>other</i>. */ public mutateRowTs_args(mutateRowTs_args other) { __isset_bitfield = other.__isset_bitfield; if (other.isSetTableName()) { this.tableName = other.tableName; } if (other.isSetRow()) { this.row = other.row; } if (other.isSetMutations()) { List<Mutation> __this__mutations = new ArrayList<Mutation>(other.mutations.size()); for (Mutation other_element : other.mutations) { __this__mutations.add(new Mutation(other_element)); } this.mutations = __this__mutations; } this.timestamp = other.timestamp; if (other.isSetAttributes()) { Map<ByteBuffer,ByteBuffer> __this__attributes = new HashMap<ByteBuffer,ByteBuffer>(other.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> other_element : other.attributes.entrySet()) { ByteBuffer other_element_key = other_element.getKey(); ByteBuffer other_element_value = other_element.getValue(); ByteBuffer __this__attributes_copy_key = other_element_key; ByteBuffer __this__attributes_copy_value = other_element_value; __this__attributes.put(__this__attributes_copy_key, __this__attributes_copy_value); } this.attributes = __this__attributes; } } public mutateRowTs_args deepCopy() { return new mutateRowTs_args(this); } @Override public void clear() { this.tableName = null; this.row = null; this.mutations = null; setTimestampIsSet(false); this.timestamp = 0; this.attributes = null; } /** * name of table */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * name of table */ public mutateRowTs_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public mutateRowTs_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } /** * row key */ public byte[] getRow() { setRow(org.apache.thrift.TBaseHelper.rightSize(row)); return row == null ? null : row.array(); } public ByteBuffer bufferForRow() { return org.apache.thrift.TBaseHelper.copyBinary(row); } /** * row key */ public mutateRowTs_args setRow(byte[] row) { this.row = row == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(row, row.length)); return this; } public mutateRowTs_args setRow(ByteBuffer row) { this.row = org.apache.thrift.TBaseHelper.copyBinary(row); return this; } public void unsetRow() { this.row = null; } /** Returns true if field row is set (has been assigned a value) and false otherwise */ public boolean isSetRow() { return this.row != null; } public void setRowIsSet(boolean value) { if (!value) { this.row = null; } } public int getMutationsSize() { return (this.mutations == null) ? 0 : this.mutations.size(); } public java.util.Iterator<Mutation> getMutationsIterator() { return (this.mutations == null) ? null : this.mutations.iterator(); } public void addToMutations(Mutation elem) { if (this.mutations == null) { this.mutations = new ArrayList<Mutation>(); } this.mutations.add(elem); } /** * list of mutation commands */ public List<Mutation> getMutations() { return this.mutations; } /** * list of mutation commands */ public mutateRowTs_args setMutations(List<Mutation> mutations) { this.mutations = mutations; return this; } public void unsetMutations() { this.mutations = null; } /** Returns true if field mutations is set (has been assigned a value) and false otherwise */ public boolean isSetMutations() { return this.mutations != null; } public void setMutationsIsSet(boolean value) { if (!value) { this.mutations = null; } } /** * timestamp */ public long getTimestamp() { return this.timestamp; } /** * timestamp */ public mutateRowTs_args setTimestamp(long timestamp) { this.timestamp = timestamp; setTimestampIsSet(true); return this; } public void unsetTimestamp() { __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __TIMESTAMP_ISSET_ID); } /** Returns true if field timestamp is set (has been assigned a value) and false otherwise */ public boolean isSetTimestamp() { return EncodingUtils.testBit(__isset_bitfield, __TIMESTAMP_ISSET_ID); } public void setTimestampIsSet(boolean value) { __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __TIMESTAMP_ISSET_ID, value); } public int getAttributesSize() { return (this.attributes == null) ? 0 : this.attributes.size(); } public void putToAttributes(ByteBuffer key, ByteBuffer val) { if (this.attributes == null) { this.attributes = new HashMap<ByteBuffer,ByteBuffer>(); } this.attributes.put(key, val); } /** * Mutation attributes */ public Map<ByteBuffer,ByteBuffer> getAttributes() { return this.attributes; } /** * Mutation attributes */ public mutateRowTs_args setAttributes(Map<ByteBuffer,ByteBuffer> attributes) { this.attributes = attributes; return this; } public void unsetAttributes() { this.attributes = null; } /** Returns true if field attributes is set (has been assigned a value) and false otherwise */ public boolean isSetAttributes() { return this.attributes != null; } public void setAttributesIsSet(boolean value) { if (!value) { this.attributes = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; case ROW: if (value == null) { unsetRow(); } else { setRow((ByteBuffer)value); } break; case MUTATIONS: if (value == null) { unsetMutations(); } else { setMutations((List<Mutation>)value); } break; case TIMESTAMP: if (value == null) { unsetTimestamp(); } else { setTimestamp((Long)value); } break; case ATTRIBUTES: if (value == null) { unsetAttributes(); } else { setAttributes((Map<ByteBuffer,ByteBuffer>)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); case ROW: return getRow(); case MUTATIONS: return getMutations(); case TIMESTAMP: return getTimestamp(); case ATTRIBUTES: return getAttributes(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); case ROW: return isSetRow(); case MUTATIONS: return isSetMutations(); case TIMESTAMP: return isSetTimestamp(); case ATTRIBUTES: return isSetAttributes(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof mutateRowTs_args) return this.equals((mutateRowTs_args)that); return false; } public boolean equals(mutateRowTs_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } boolean this_present_row = true && this.isSetRow(); boolean that_present_row = true && that.isSetRow(); if (this_present_row || that_present_row) { if (!(this_present_row && that_present_row)) return false; if (!this.row.equals(that.row)) return false; } boolean this_present_mutations = true && this.isSetMutations(); boolean that_present_mutations = true && that.isSetMutations(); if (this_present_mutations || that_present_mutations) { if (!(this_present_mutations && that_present_mutations)) return false; if (!this.mutations.equals(that.mutations)) return false; } boolean this_present_timestamp = true; boolean that_present_timestamp = true; if (this_present_timestamp || that_present_timestamp) { if (!(this_present_timestamp && that_present_timestamp)) return false; if (this.timestamp != that.timestamp) return false; } boolean this_present_attributes = true && this.isSetAttributes(); boolean that_present_attributes = true && that.isSetAttributes(); if (this_present_attributes || that_present_attributes) { if (!(this_present_attributes && that_present_attributes)) return false; if (!this.attributes.equals(that.attributes)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); boolean present_row = true && (isSetRow()); list.add(present_row); if (present_row) list.add(row); boolean present_mutations = true && (isSetMutations()); list.add(present_mutations); if (present_mutations) list.add(mutations); boolean present_timestamp = true; list.add(present_timestamp); if (present_timestamp) list.add(timestamp); boolean present_attributes = true && (isSetAttributes()); list.add(present_attributes); if (present_attributes) list.add(attributes); return list.hashCode(); } @Override public int compareTo(mutateRowTs_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetRow()).compareTo(other.isSetRow()); if (lastComparison != 0) { return lastComparison; } if (isSetRow()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.row, other.row); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetMutations()).compareTo(other.isSetMutations()); if (lastComparison != 0) { return lastComparison; } if (isSetMutations()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.mutations, other.mutations); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetTimestamp()).compareTo(other.isSetTimestamp()); if (lastComparison != 0) { return lastComparison; } if (isSetTimestamp()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.timestamp, other.timestamp); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetAttributes()).compareTo(other.isSetAttributes()); if (lastComparison != 0) { return lastComparison; } if (isSetAttributes()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.attributes, other.attributes); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("mutateRowTs_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; if (!first) sb.append(", "); sb.append("row:"); if (this.row == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.row, sb); } first = false; if (!first) sb.append(", "); sb.append("mutations:"); if (this.mutations == null) { sb.append("null"); } else { sb.append(this.mutations); } first = false; if (!first) sb.append(", "); sb.append("timestamp:"); sb.append(this.timestamp); first = false; if (!first) sb.append(", "); sb.append("attributes:"); if (this.attributes == null) { sb.append("null"); } else { sb.append(this.attributes); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { // it doesn't seem like you should have to do this, but java serialization is wacky, and doesn't call the default constructor. __isset_bitfield = 0; read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class mutateRowTs_argsStandardSchemeFactory implements SchemeFactory { public mutateRowTs_argsStandardScheme getScheme() { return new mutateRowTs_argsStandardScheme(); } } private static class mutateRowTs_argsStandardScheme extends StandardScheme<mutateRowTs_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, mutateRowTs_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // ROW if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.row = iprot.readBinary(); struct.setRowIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 3: // MUTATIONS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list364 = iprot.readListBegin(); struct.mutations = new ArrayList<Mutation>(_list364.size); Mutation _elem365; for (int _i366 = 0; _i366 < _list364.size; ++_i366) { _elem365 = new Mutation(); _elem365.read(iprot); struct.mutations.add(_elem365); } iprot.readListEnd(); } struct.setMutationsIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 4: // TIMESTAMP if (schemeField.type == org.apache.thrift.protocol.TType.I64) { struct.timestamp = iprot.readI64(); struct.setTimestampIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 5: // ATTRIBUTES if (schemeField.type == org.apache.thrift.protocol.TType.MAP) { { org.apache.thrift.protocol.TMap _map367 = iprot.readMapBegin(); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map367.size); ByteBuffer _key368; ByteBuffer _val369; for (int _i370 = 0; _i370 < _map367.size; ++_i370) { _key368 = iprot.readBinary(); _val369 = iprot.readBinary(); struct.attributes.put(_key368, _val369); } iprot.readMapEnd(); } struct.setAttributesIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, mutateRowTs_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } if (struct.row != null) { oprot.writeFieldBegin(ROW_FIELD_DESC); oprot.writeBinary(struct.row); oprot.writeFieldEnd(); } if (struct.mutations != null) { oprot.writeFieldBegin(MUTATIONS_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.mutations.size())); for (Mutation _iter371 : struct.mutations) { _iter371.write(oprot); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldBegin(TIMESTAMP_FIELD_DESC); oprot.writeI64(struct.timestamp); oprot.writeFieldEnd(); if (struct.attributes != null) { oprot.writeFieldBegin(ATTRIBUTES_FIELD_DESC); { oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, struct.attributes.size())); for (Map.Entry<ByteBuffer, ByteBuffer> _iter372 : struct.attributes.entrySet()) { oprot.writeBinary(_iter372.getKey()); oprot.writeBinary(_iter372.getValue()); } oprot.writeMapEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class mutateRowTs_argsTupleSchemeFactory implements SchemeFactory { public mutateRowTs_argsTupleScheme getScheme() { return new mutateRowTs_argsTupleScheme(); } } private static class mutateRowTs_argsTupleScheme extends TupleScheme<mutateRowTs_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, mutateRowTs_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } if (struct.isSetRow()) { optionals.set(1); } if (struct.isSetMutations()) { optionals.set(2); } if (struct.isSetTimestamp()) { optionals.set(3); } if (struct.isSetAttributes()) { optionals.set(4); } oprot.writeBitSet(optionals, 5); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } if (struct.isSetRow()) { oprot.writeBinary(struct.row); } if (struct.isSetMutations()) { { oprot.writeI32(struct.mutations.size()); for (Mutation _iter373 : struct.mutations) { _iter373.write(oprot); } } } if (struct.isSetTimestamp()) { oprot.writeI64(struct.timestamp); } if (struct.isSetAttributes()) { { oprot.writeI32(struct.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> _iter374 : struct.attributes.entrySet()) { oprot.writeBinary(_iter374.getKey()); oprot.writeBinary(_iter374.getValue()); } } } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, mutateRowTs_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(5); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } if (incoming.get(1)) { struct.row = iprot.readBinary(); struct.setRowIsSet(true); } if (incoming.get(2)) { { org.apache.thrift.protocol.TList _list375 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32()); struct.mutations = new ArrayList<Mutation>(_list375.size); Mutation _elem376; for (int _i377 = 0; _i377 < _list375.size; ++_i377) { _elem376 = new Mutation(); _elem376.read(iprot); struct.mutations.add(_elem376); } } struct.setMutationsIsSet(true); } if (incoming.get(3)) { struct.timestamp = iprot.readI64(); struct.setTimestampIsSet(true); } if (incoming.get(4)) { { org.apache.thrift.protocol.TMap _map378 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map378.size); ByteBuffer _key379; ByteBuffer _val380; for (int _i381 = 0; _i381 < _map378.size; ++_i381) { _key379 = iprot.readBinary(); _val380 = iprot.readBinary(); struct.attributes.put(_key379, _val380); } } struct.setAttributesIsSet(true); } } } } public static class mutateRowTs_result implements org.apache.thrift.TBase<mutateRowTs_result, mutateRowTs_result._Fields>, java.io.Serializable, Cloneable, Comparable<mutateRowTs_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("mutateRowTs_result"); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final org.apache.thrift.protocol.TField IA_FIELD_DESC = new org.apache.thrift.protocol.TField("ia", org.apache.thrift.protocol.TType.STRUCT, (short)2); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new mutateRowTs_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new mutateRowTs_resultTupleSchemeFactory()); } public IOError io; // required public IllegalArgument ia; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { IO((short)1, "io"), IA((short)2, "ia"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // IO return IO; case 2: // IA return IA; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); tmpMap.put(_Fields.IA, new org.apache.thrift.meta_data.FieldMetaData("ia", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(mutateRowTs_result.class, metaDataMap); } public mutateRowTs_result() { } public mutateRowTs_result( IOError io, IllegalArgument ia) { this(); this.io = io; this.ia = ia; } /** * Performs a deep copy on <i>other</i>. */ public mutateRowTs_result(mutateRowTs_result other) { if (other.isSetIo()) { this.io = new IOError(other.io); } if (other.isSetIa()) { this.ia = new IllegalArgument(other.ia); } } public mutateRowTs_result deepCopy() { return new mutateRowTs_result(this); } @Override public void clear() { this.io = null; this.ia = null; } public IOError getIo() { return this.io; } public mutateRowTs_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public IllegalArgument getIa() { return this.ia; } public mutateRowTs_result setIa(IllegalArgument ia) { this.ia = ia; return this; } public void unsetIa() { this.ia = null; } /** Returns true if field ia is set (has been assigned a value) and false otherwise */ public boolean isSetIa() { return this.ia != null; } public void setIaIsSet(boolean value) { if (!value) { this.ia = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; case IA: if (value == null) { unsetIa(); } else { setIa((IllegalArgument)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case IO: return getIo(); case IA: return getIa(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case IO: return isSetIo(); case IA: return isSetIa(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof mutateRowTs_result) return this.equals((mutateRowTs_result)that); return false; } public boolean equals(mutateRowTs_result that) { if (that == null) return false; boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } boolean this_present_ia = true && this.isSetIa(); boolean that_present_ia = true && that.isSetIa(); if (this_present_ia || that_present_ia) { if (!(this_present_ia && that_present_ia)) return false; if (!this.ia.equals(that.ia)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); boolean present_ia = true && (isSetIa()); list.add(present_ia); if (present_ia) list.add(ia); return list.hashCode(); } @Override public int compareTo(mutateRowTs_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIa()).compareTo(other.isSetIa()); if (lastComparison != 0) { return lastComparison; } if (isSetIa()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ia, other.ia); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("mutateRowTs_result("); boolean first = true; sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; if (!first) sb.append(", "); sb.append("ia:"); if (this.ia == null) { sb.append("null"); } else { sb.append(this.ia); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class mutateRowTs_resultStandardSchemeFactory implements SchemeFactory { public mutateRowTs_resultStandardScheme getScheme() { return new mutateRowTs_resultStandardScheme(); } } private static class mutateRowTs_resultStandardScheme extends StandardScheme<mutateRowTs_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, mutateRowTs_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // IA if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.ia = new IllegalArgument(); struct.ia.read(iprot); struct.setIaIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, mutateRowTs_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } if (struct.ia != null) { oprot.writeFieldBegin(IA_FIELD_DESC); struct.ia.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class mutateRowTs_resultTupleSchemeFactory implements SchemeFactory { public mutateRowTs_resultTupleScheme getScheme() { return new mutateRowTs_resultTupleScheme(); } } private static class mutateRowTs_resultTupleScheme extends TupleScheme<mutateRowTs_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, mutateRowTs_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetIo()) { optionals.set(0); } if (struct.isSetIa()) { optionals.set(1); } oprot.writeBitSet(optionals, 2); if (struct.isSetIo()) { struct.io.write(oprot); } if (struct.isSetIa()) { struct.ia.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, mutateRowTs_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } if (incoming.get(1)) { struct.ia = new IllegalArgument(); struct.ia.read(iprot); struct.setIaIsSet(true); } } } } public static class mutateRows_args implements org.apache.thrift.TBase<mutateRows_args, mutateRows_args._Fields>, java.io.Serializable, Cloneable, Comparable<mutateRows_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("mutateRows_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final org.apache.thrift.protocol.TField ROW_BATCHES_FIELD_DESC = new org.apache.thrift.protocol.TField("rowBatches", org.apache.thrift.protocol.TType.LIST, (short)2); private static final org.apache.thrift.protocol.TField ATTRIBUTES_FIELD_DESC = new org.apache.thrift.protocol.TField("attributes", org.apache.thrift.protocol.TType.MAP, (short)3); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new mutateRows_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new mutateRows_argsTupleSchemeFactory()); } /** * name of table */ public ByteBuffer tableName; // required /** * list of row batches */ public List<BatchMutation> rowBatches; // required /** * Mutation attributes */ public Map<ByteBuffer,ByteBuffer> attributes; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * name of table */ TABLE_NAME((short)1, "tableName"), /** * list of row batches */ ROW_BATCHES((short)2, "rowBatches"), /** * Mutation attributes */ ATTRIBUTES((short)3, "attributes"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; case 2: // ROW_BATCHES return ROW_BATCHES; case 3: // ATTRIBUTES return ATTRIBUTES; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.ROW_BATCHES, new org.apache.thrift.meta_data.FieldMetaData("rowBatches", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, BatchMutation.class)))); tmpMap.put(_Fields.ATTRIBUTES, new org.apache.thrift.meta_data.FieldMetaData("attributes", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.MapMetaData(org.apache.thrift.protocol.TType.MAP, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"), new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(mutateRows_args.class, metaDataMap); } public mutateRows_args() { } public mutateRows_args( ByteBuffer tableName, List<BatchMutation> rowBatches, Map<ByteBuffer,ByteBuffer> attributes) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); this.rowBatches = rowBatches; this.attributes = attributes; } /** * Performs a deep copy on <i>other</i>. */ public mutateRows_args(mutateRows_args other) { if (other.isSetTableName()) { this.tableName = other.tableName; } if (other.isSetRowBatches()) { List<BatchMutation> __this__rowBatches = new ArrayList<BatchMutation>(other.rowBatches.size()); for (BatchMutation other_element : other.rowBatches) { __this__rowBatches.add(new BatchMutation(other_element)); } this.rowBatches = __this__rowBatches; } if (other.isSetAttributes()) { Map<ByteBuffer,ByteBuffer> __this__attributes = new HashMap<ByteBuffer,ByteBuffer>(other.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> other_element : other.attributes.entrySet()) { ByteBuffer other_element_key = other_element.getKey(); ByteBuffer other_element_value = other_element.getValue(); ByteBuffer __this__attributes_copy_key = other_element_key; ByteBuffer __this__attributes_copy_value = other_element_value; __this__attributes.put(__this__attributes_copy_key, __this__attributes_copy_value); } this.attributes = __this__attributes; } } public mutateRows_args deepCopy() { return new mutateRows_args(this); } @Override public void clear() { this.tableName = null; this.rowBatches = null; this.attributes = null; } /** * name of table */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * name of table */ public mutateRows_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public mutateRows_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } public int getRowBatchesSize() { return (this.rowBatches == null) ? 0 : this.rowBatches.size(); } public java.util.Iterator<BatchMutation> getRowBatchesIterator() { return (this.rowBatches == null) ? null : this.rowBatches.iterator(); } public void addToRowBatches(BatchMutation elem) { if (this.rowBatches == null) { this.rowBatches = new ArrayList<BatchMutation>(); } this.rowBatches.add(elem); } /** * list of row batches */ public List<BatchMutation> getRowBatches() { return this.rowBatches; } /** * list of row batches */ public mutateRows_args setRowBatches(List<BatchMutation> rowBatches) { this.rowBatches = rowBatches; return this; } public void unsetRowBatches() { this.rowBatches = null; } /** Returns true if field rowBatches is set (has been assigned a value) and false otherwise */ public boolean isSetRowBatches() { return this.rowBatches != null; } public void setRowBatchesIsSet(boolean value) { if (!value) { this.rowBatches = null; } } public int getAttributesSize() { return (this.attributes == null) ? 0 : this.attributes.size(); } public void putToAttributes(ByteBuffer key, ByteBuffer val) { if (this.attributes == null) { this.attributes = new HashMap<ByteBuffer,ByteBuffer>(); } this.attributes.put(key, val); } /** * Mutation attributes */ public Map<ByteBuffer,ByteBuffer> getAttributes() { return this.attributes; } /** * Mutation attributes */ public mutateRows_args setAttributes(Map<ByteBuffer,ByteBuffer> attributes) { this.attributes = attributes; return this; } public void unsetAttributes() { this.attributes = null; } /** Returns true if field attributes is set (has been assigned a value) and false otherwise */ public boolean isSetAttributes() { return this.attributes != null; } public void setAttributesIsSet(boolean value) { if (!value) { this.attributes = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; case ROW_BATCHES: if (value == null) { unsetRowBatches(); } else { setRowBatches((List<BatchMutation>)value); } break; case ATTRIBUTES: if (value == null) { unsetAttributes(); } else { setAttributes((Map<ByteBuffer,ByteBuffer>)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); case ROW_BATCHES: return getRowBatches(); case ATTRIBUTES: return getAttributes(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); case ROW_BATCHES: return isSetRowBatches(); case ATTRIBUTES: return isSetAttributes(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof mutateRows_args) return this.equals((mutateRows_args)that); return false; } public boolean equals(mutateRows_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } boolean this_present_rowBatches = true && this.isSetRowBatches(); boolean that_present_rowBatches = true && that.isSetRowBatches(); if (this_present_rowBatches || that_present_rowBatches) { if (!(this_present_rowBatches && that_present_rowBatches)) return false; if (!this.rowBatches.equals(that.rowBatches)) return false; } boolean this_present_attributes = true && this.isSetAttributes(); boolean that_present_attributes = true && that.isSetAttributes(); if (this_present_attributes || that_present_attributes) { if (!(this_present_attributes && that_present_attributes)) return false; if (!this.attributes.equals(that.attributes)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); boolean present_rowBatches = true && (isSetRowBatches()); list.add(present_rowBatches); if (present_rowBatches) list.add(rowBatches); boolean present_attributes = true && (isSetAttributes()); list.add(present_attributes); if (present_attributes) list.add(attributes); return list.hashCode(); } @Override public int compareTo(mutateRows_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetRowBatches()).compareTo(other.isSetRowBatches()); if (lastComparison != 0) { return lastComparison; } if (isSetRowBatches()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.rowBatches, other.rowBatches); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetAttributes()).compareTo(other.isSetAttributes()); if (lastComparison != 0) { return lastComparison; } if (isSetAttributes()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.attributes, other.attributes); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("mutateRows_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; if (!first) sb.append(", "); sb.append("rowBatches:"); if (this.rowBatches == null) { sb.append("null"); } else { sb.append(this.rowBatches); } first = false; if (!first) sb.append(", "); sb.append("attributes:"); if (this.attributes == null) { sb.append("null"); } else { sb.append(this.attributes); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class mutateRows_argsStandardSchemeFactory implements SchemeFactory { public mutateRows_argsStandardScheme getScheme() { return new mutateRows_argsStandardScheme(); } } private static class mutateRows_argsStandardScheme extends StandardScheme<mutateRows_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, mutateRows_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // ROW_BATCHES if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list382 = iprot.readListBegin(); struct.rowBatches = new ArrayList<BatchMutation>(_list382.size); BatchMutation _elem383; for (int _i384 = 0; _i384 < _list382.size; ++_i384) { _elem383 = new BatchMutation(); _elem383.read(iprot); struct.rowBatches.add(_elem383); } iprot.readListEnd(); } struct.setRowBatchesIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 3: // ATTRIBUTES if (schemeField.type == org.apache.thrift.protocol.TType.MAP) { { org.apache.thrift.protocol.TMap _map385 = iprot.readMapBegin(); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map385.size); ByteBuffer _key386; ByteBuffer _val387; for (int _i388 = 0; _i388 < _map385.size; ++_i388) { _key386 = iprot.readBinary(); _val387 = iprot.readBinary(); struct.attributes.put(_key386, _val387); } iprot.readMapEnd(); } struct.setAttributesIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, mutateRows_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } if (struct.rowBatches != null) { oprot.writeFieldBegin(ROW_BATCHES_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.rowBatches.size())); for (BatchMutation _iter389 : struct.rowBatches) { _iter389.write(oprot); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } if (struct.attributes != null) { oprot.writeFieldBegin(ATTRIBUTES_FIELD_DESC); { oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, struct.attributes.size())); for (Map.Entry<ByteBuffer, ByteBuffer> _iter390 : struct.attributes.entrySet()) { oprot.writeBinary(_iter390.getKey()); oprot.writeBinary(_iter390.getValue()); } oprot.writeMapEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class mutateRows_argsTupleSchemeFactory implements SchemeFactory { public mutateRows_argsTupleScheme getScheme() { return new mutateRows_argsTupleScheme(); } } private static class mutateRows_argsTupleScheme extends TupleScheme<mutateRows_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, mutateRows_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } if (struct.isSetRowBatches()) { optionals.set(1); } if (struct.isSetAttributes()) { optionals.set(2); } oprot.writeBitSet(optionals, 3); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } if (struct.isSetRowBatches()) { { oprot.writeI32(struct.rowBatches.size()); for (BatchMutation _iter391 : struct.rowBatches) { _iter391.write(oprot); } } } if (struct.isSetAttributes()) { { oprot.writeI32(struct.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> _iter392 : struct.attributes.entrySet()) { oprot.writeBinary(_iter392.getKey()); oprot.writeBinary(_iter392.getValue()); } } } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, mutateRows_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(3); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } if (incoming.get(1)) { { org.apache.thrift.protocol.TList _list393 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32()); struct.rowBatches = new ArrayList<BatchMutation>(_list393.size); BatchMutation _elem394; for (int _i395 = 0; _i395 < _list393.size; ++_i395) { _elem394 = new BatchMutation(); _elem394.read(iprot); struct.rowBatches.add(_elem394); } } struct.setRowBatchesIsSet(true); } if (incoming.get(2)) { { org.apache.thrift.protocol.TMap _map396 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map396.size); ByteBuffer _key397; ByteBuffer _val398; for (int _i399 = 0; _i399 < _map396.size; ++_i399) { _key397 = iprot.readBinary(); _val398 = iprot.readBinary(); struct.attributes.put(_key397, _val398); } } struct.setAttributesIsSet(true); } } } } public static class mutateRows_result implements org.apache.thrift.TBase<mutateRows_result, mutateRows_result._Fields>, java.io.Serializable, Cloneable, Comparable<mutateRows_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("mutateRows_result"); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final org.apache.thrift.protocol.TField IA_FIELD_DESC = new org.apache.thrift.protocol.TField("ia", org.apache.thrift.protocol.TType.STRUCT, (short)2); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new mutateRows_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new mutateRows_resultTupleSchemeFactory()); } public IOError io; // required public IllegalArgument ia; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { IO((short)1, "io"), IA((short)2, "ia"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // IO return IO; case 2: // IA return IA; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); tmpMap.put(_Fields.IA, new org.apache.thrift.meta_data.FieldMetaData("ia", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(mutateRows_result.class, metaDataMap); } public mutateRows_result() { } public mutateRows_result( IOError io, IllegalArgument ia) { this(); this.io = io; this.ia = ia; } /** * Performs a deep copy on <i>other</i>. */ public mutateRows_result(mutateRows_result other) { if (other.isSetIo()) { this.io = new IOError(other.io); } if (other.isSetIa()) { this.ia = new IllegalArgument(other.ia); } } public mutateRows_result deepCopy() { return new mutateRows_result(this); } @Override public void clear() { this.io = null; this.ia = null; } public IOError getIo() { return this.io; } public mutateRows_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public IllegalArgument getIa() { return this.ia; } public mutateRows_result setIa(IllegalArgument ia) { this.ia = ia; return this; } public void unsetIa() { this.ia = null; } /** Returns true if field ia is set (has been assigned a value) and false otherwise */ public boolean isSetIa() { return this.ia != null; } public void setIaIsSet(boolean value) { if (!value) { this.ia = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; case IA: if (value == null) { unsetIa(); } else { setIa((IllegalArgument)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case IO: return getIo(); case IA: return getIa(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case IO: return isSetIo(); case IA: return isSetIa(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof mutateRows_result) return this.equals((mutateRows_result)that); return false; } public boolean equals(mutateRows_result that) { if (that == null) return false; boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } boolean this_present_ia = true && this.isSetIa(); boolean that_present_ia = true && that.isSetIa(); if (this_present_ia || that_present_ia) { if (!(this_present_ia && that_present_ia)) return false; if (!this.ia.equals(that.ia)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); boolean present_ia = true && (isSetIa()); list.add(present_ia); if (present_ia) list.add(ia); return list.hashCode(); } @Override public int compareTo(mutateRows_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIa()).compareTo(other.isSetIa()); if (lastComparison != 0) { return lastComparison; } if (isSetIa()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ia, other.ia); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("mutateRows_result("); boolean first = true; sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; if (!first) sb.append(", "); sb.append("ia:"); if (this.ia == null) { sb.append("null"); } else { sb.append(this.ia); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class mutateRows_resultStandardSchemeFactory implements SchemeFactory { public mutateRows_resultStandardScheme getScheme() { return new mutateRows_resultStandardScheme(); } } private static class mutateRows_resultStandardScheme extends StandardScheme<mutateRows_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, mutateRows_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // IA if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.ia = new IllegalArgument(); struct.ia.read(iprot); struct.setIaIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, mutateRows_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } if (struct.ia != null) { oprot.writeFieldBegin(IA_FIELD_DESC); struct.ia.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class mutateRows_resultTupleSchemeFactory implements SchemeFactory { public mutateRows_resultTupleScheme getScheme() { return new mutateRows_resultTupleScheme(); } } private static class mutateRows_resultTupleScheme extends TupleScheme<mutateRows_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, mutateRows_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetIo()) { optionals.set(0); } if (struct.isSetIa()) { optionals.set(1); } oprot.writeBitSet(optionals, 2); if (struct.isSetIo()) { struct.io.write(oprot); } if (struct.isSetIa()) { struct.ia.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, mutateRows_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } if (incoming.get(1)) { struct.ia = new IllegalArgument(); struct.ia.read(iprot); struct.setIaIsSet(true); } } } } public static class mutateRowsTs_args implements org.apache.thrift.TBase<mutateRowsTs_args, mutateRowsTs_args._Fields>, java.io.Serializable, Cloneable, Comparable<mutateRowsTs_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("mutateRowsTs_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final org.apache.thrift.protocol.TField ROW_BATCHES_FIELD_DESC = new org.apache.thrift.protocol.TField("rowBatches", org.apache.thrift.protocol.TType.LIST, (short)2); private static final org.apache.thrift.protocol.TField TIMESTAMP_FIELD_DESC = new org.apache.thrift.protocol.TField("timestamp", org.apache.thrift.protocol.TType.I64, (short)3); private static final org.apache.thrift.protocol.TField ATTRIBUTES_FIELD_DESC = new org.apache.thrift.protocol.TField("attributes", org.apache.thrift.protocol.TType.MAP, (short)4); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new mutateRowsTs_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new mutateRowsTs_argsTupleSchemeFactory()); } /** * name of table */ public ByteBuffer tableName; // required /** * list of row batches */ public List<BatchMutation> rowBatches; // required /** * timestamp */ public long timestamp; // required /** * Mutation attributes */ public Map<ByteBuffer,ByteBuffer> attributes; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * name of table */ TABLE_NAME((short)1, "tableName"), /** * list of row batches */ ROW_BATCHES((short)2, "rowBatches"), /** * timestamp */ TIMESTAMP((short)3, "timestamp"), /** * Mutation attributes */ ATTRIBUTES((short)4, "attributes"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; case 2: // ROW_BATCHES return ROW_BATCHES; case 3: // TIMESTAMP return TIMESTAMP; case 4: // ATTRIBUTES return ATTRIBUTES; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments private static final int __TIMESTAMP_ISSET_ID = 0; private byte __isset_bitfield = 0; public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.ROW_BATCHES, new org.apache.thrift.meta_data.FieldMetaData("rowBatches", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, BatchMutation.class)))); tmpMap.put(_Fields.TIMESTAMP, new org.apache.thrift.meta_data.FieldMetaData("timestamp", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.I64))); tmpMap.put(_Fields.ATTRIBUTES, new org.apache.thrift.meta_data.FieldMetaData("attributes", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.MapMetaData(org.apache.thrift.protocol.TType.MAP, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"), new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(mutateRowsTs_args.class, metaDataMap); } public mutateRowsTs_args() { } public mutateRowsTs_args( ByteBuffer tableName, List<BatchMutation> rowBatches, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); this.rowBatches = rowBatches; this.timestamp = timestamp; setTimestampIsSet(true); this.attributes = attributes; } /** * Performs a deep copy on <i>other</i>. */ public mutateRowsTs_args(mutateRowsTs_args other) { __isset_bitfield = other.__isset_bitfield; if (other.isSetTableName()) { this.tableName = other.tableName; } if (other.isSetRowBatches()) { List<BatchMutation> __this__rowBatches = new ArrayList<BatchMutation>(other.rowBatches.size()); for (BatchMutation other_element : other.rowBatches) { __this__rowBatches.add(new BatchMutation(other_element)); } this.rowBatches = __this__rowBatches; } this.timestamp = other.timestamp; if (other.isSetAttributes()) { Map<ByteBuffer,ByteBuffer> __this__attributes = new HashMap<ByteBuffer,ByteBuffer>(other.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> other_element : other.attributes.entrySet()) { ByteBuffer other_element_key = other_element.getKey(); ByteBuffer other_element_value = other_element.getValue(); ByteBuffer __this__attributes_copy_key = other_element_key; ByteBuffer __this__attributes_copy_value = other_element_value; __this__attributes.put(__this__attributes_copy_key, __this__attributes_copy_value); } this.attributes = __this__attributes; } } public mutateRowsTs_args deepCopy() { return new mutateRowsTs_args(this); } @Override public void clear() { this.tableName = null; this.rowBatches = null; setTimestampIsSet(false); this.timestamp = 0; this.attributes = null; } /** * name of table */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * name of table */ public mutateRowsTs_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public mutateRowsTs_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } public int getRowBatchesSize() { return (this.rowBatches == null) ? 0 : this.rowBatches.size(); } public java.util.Iterator<BatchMutation> getRowBatchesIterator() { return (this.rowBatches == null) ? null : this.rowBatches.iterator(); } public void addToRowBatches(BatchMutation elem) { if (this.rowBatches == null) { this.rowBatches = new ArrayList<BatchMutation>(); } this.rowBatches.add(elem); } /** * list of row batches */ public List<BatchMutation> getRowBatches() { return this.rowBatches; } /** * list of row batches */ public mutateRowsTs_args setRowBatches(List<BatchMutation> rowBatches) { this.rowBatches = rowBatches; return this; } public void unsetRowBatches() { this.rowBatches = null; } /** Returns true if field rowBatches is set (has been assigned a value) and false otherwise */ public boolean isSetRowBatches() { return this.rowBatches != null; } public void setRowBatchesIsSet(boolean value) { if (!value) { this.rowBatches = null; } } /** * timestamp */ public long getTimestamp() { return this.timestamp; } /** * timestamp */ public mutateRowsTs_args setTimestamp(long timestamp) { this.timestamp = timestamp; setTimestampIsSet(true); return this; } public void unsetTimestamp() { __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __TIMESTAMP_ISSET_ID); } /** Returns true if field timestamp is set (has been assigned a value) and false otherwise */ public boolean isSetTimestamp() { return EncodingUtils.testBit(__isset_bitfield, __TIMESTAMP_ISSET_ID); } public void setTimestampIsSet(boolean value) { __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __TIMESTAMP_ISSET_ID, value); } public int getAttributesSize() { return (this.attributes == null) ? 0 : this.attributes.size(); } public void putToAttributes(ByteBuffer key, ByteBuffer val) { if (this.attributes == null) { this.attributes = new HashMap<ByteBuffer,ByteBuffer>(); } this.attributes.put(key, val); } /** * Mutation attributes */ public Map<ByteBuffer,ByteBuffer> getAttributes() { return this.attributes; } /** * Mutation attributes */ public mutateRowsTs_args setAttributes(Map<ByteBuffer,ByteBuffer> attributes) { this.attributes = attributes; return this; } public void unsetAttributes() { this.attributes = null; } /** Returns true if field attributes is set (has been assigned a value) and false otherwise */ public boolean isSetAttributes() { return this.attributes != null; } public void setAttributesIsSet(boolean value) { if (!value) { this.attributes = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; case ROW_BATCHES: if (value == null) { unsetRowBatches(); } else { setRowBatches((List<BatchMutation>)value); } break; case TIMESTAMP: if (value == null) { unsetTimestamp(); } else { setTimestamp((Long)value); } break; case ATTRIBUTES: if (value == null) { unsetAttributes(); } else { setAttributes((Map<ByteBuffer,ByteBuffer>)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); case ROW_BATCHES: return getRowBatches(); case TIMESTAMP: return getTimestamp(); case ATTRIBUTES: return getAttributes(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); case ROW_BATCHES: return isSetRowBatches(); case TIMESTAMP: return isSetTimestamp(); case ATTRIBUTES: return isSetAttributes(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof mutateRowsTs_args) return this.equals((mutateRowsTs_args)that); return false; } public boolean equals(mutateRowsTs_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } boolean this_present_rowBatches = true && this.isSetRowBatches(); boolean that_present_rowBatches = true && that.isSetRowBatches(); if (this_present_rowBatches || that_present_rowBatches) { if (!(this_present_rowBatches && that_present_rowBatches)) return false; if (!this.rowBatches.equals(that.rowBatches)) return false; } boolean this_present_timestamp = true; boolean that_present_timestamp = true; if (this_present_timestamp || that_present_timestamp) { if (!(this_present_timestamp && that_present_timestamp)) return false; if (this.timestamp != that.timestamp) return false; } boolean this_present_attributes = true && this.isSetAttributes(); boolean that_present_attributes = true && that.isSetAttributes(); if (this_present_attributes || that_present_attributes) { if (!(this_present_attributes && that_present_attributes)) return false; if (!this.attributes.equals(that.attributes)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); boolean present_rowBatches = true && (isSetRowBatches()); list.add(present_rowBatches); if (present_rowBatches) list.add(rowBatches); boolean present_timestamp = true; list.add(present_timestamp); if (present_timestamp) list.add(timestamp); boolean present_attributes = true && (isSetAttributes()); list.add(present_attributes); if (present_attributes) list.add(attributes); return list.hashCode(); } @Override public int compareTo(mutateRowsTs_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetRowBatches()).compareTo(other.isSetRowBatches()); if (lastComparison != 0) { return lastComparison; } if (isSetRowBatches()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.rowBatches, other.rowBatches); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetTimestamp()).compareTo(other.isSetTimestamp()); if (lastComparison != 0) { return lastComparison; } if (isSetTimestamp()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.timestamp, other.timestamp); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetAttributes()).compareTo(other.isSetAttributes()); if (lastComparison != 0) { return lastComparison; } if (isSetAttributes()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.attributes, other.attributes); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("mutateRowsTs_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; if (!first) sb.append(", "); sb.append("rowBatches:"); if (this.rowBatches == null) { sb.append("null"); } else { sb.append(this.rowBatches); } first = false; if (!first) sb.append(", "); sb.append("timestamp:"); sb.append(this.timestamp); first = false; if (!first) sb.append(", "); sb.append("attributes:"); if (this.attributes == null) { sb.append("null"); } else { sb.append(this.attributes); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { // it doesn't seem like you should have to do this, but java serialization is wacky, and doesn't call the default constructor. __isset_bitfield = 0; read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class mutateRowsTs_argsStandardSchemeFactory implements SchemeFactory { public mutateRowsTs_argsStandardScheme getScheme() { return new mutateRowsTs_argsStandardScheme(); } } private static class mutateRowsTs_argsStandardScheme extends StandardScheme<mutateRowsTs_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, mutateRowsTs_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // ROW_BATCHES if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list400 = iprot.readListBegin(); struct.rowBatches = new ArrayList<BatchMutation>(_list400.size); BatchMutation _elem401; for (int _i402 = 0; _i402 < _list400.size; ++_i402) { _elem401 = new BatchMutation(); _elem401.read(iprot); struct.rowBatches.add(_elem401); } iprot.readListEnd(); } struct.setRowBatchesIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 3: // TIMESTAMP if (schemeField.type == org.apache.thrift.protocol.TType.I64) { struct.timestamp = iprot.readI64(); struct.setTimestampIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 4: // ATTRIBUTES if (schemeField.type == org.apache.thrift.protocol.TType.MAP) { { org.apache.thrift.protocol.TMap _map403 = iprot.readMapBegin(); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map403.size); ByteBuffer _key404; ByteBuffer _val405; for (int _i406 = 0; _i406 < _map403.size; ++_i406) { _key404 = iprot.readBinary(); _val405 = iprot.readBinary(); struct.attributes.put(_key404, _val405); } iprot.readMapEnd(); } struct.setAttributesIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, mutateRowsTs_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } if (struct.rowBatches != null) { oprot.writeFieldBegin(ROW_BATCHES_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.rowBatches.size())); for (BatchMutation _iter407 : struct.rowBatches) { _iter407.write(oprot); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldBegin(TIMESTAMP_FIELD_DESC); oprot.writeI64(struct.timestamp); oprot.writeFieldEnd(); if (struct.attributes != null) { oprot.writeFieldBegin(ATTRIBUTES_FIELD_DESC); { oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, struct.attributes.size())); for (Map.Entry<ByteBuffer, ByteBuffer> _iter408 : struct.attributes.entrySet()) { oprot.writeBinary(_iter408.getKey()); oprot.writeBinary(_iter408.getValue()); } oprot.writeMapEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class mutateRowsTs_argsTupleSchemeFactory implements SchemeFactory { public mutateRowsTs_argsTupleScheme getScheme() { return new mutateRowsTs_argsTupleScheme(); } } private static class mutateRowsTs_argsTupleScheme extends TupleScheme<mutateRowsTs_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, mutateRowsTs_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } if (struct.isSetRowBatches()) { optionals.set(1); } if (struct.isSetTimestamp()) { optionals.set(2); } if (struct.isSetAttributes()) { optionals.set(3); } oprot.writeBitSet(optionals, 4); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } if (struct.isSetRowBatches()) { { oprot.writeI32(struct.rowBatches.size()); for (BatchMutation _iter409 : struct.rowBatches) { _iter409.write(oprot); } } } if (struct.isSetTimestamp()) { oprot.writeI64(struct.timestamp); } if (struct.isSetAttributes()) { { oprot.writeI32(struct.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> _iter410 : struct.attributes.entrySet()) { oprot.writeBinary(_iter410.getKey()); oprot.writeBinary(_iter410.getValue()); } } } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, mutateRowsTs_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(4); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } if (incoming.get(1)) { { org.apache.thrift.protocol.TList _list411 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32()); struct.rowBatches = new ArrayList<BatchMutation>(_list411.size); BatchMutation _elem412; for (int _i413 = 0; _i413 < _list411.size; ++_i413) { _elem412 = new BatchMutation(); _elem412.read(iprot); struct.rowBatches.add(_elem412); } } struct.setRowBatchesIsSet(true); } if (incoming.get(2)) { struct.timestamp = iprot.readI64(); struct.setTimestampIsSet(true); } if (incoming.get(3)) { { org.apache.thrift.protocol.TMap _map414 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map414.size); ByteBuffer _key415; ByteBuffer _val416; for (int _i417 = 0; _i417 < _map414.size; ++_i417) { _key415 = iprot.readBinary(); _val416 = iprot.readBinary(); struct.attributes.put(_key415, _val416); } } struct.setAttributesIsSet(true); } } } } public static class mutateRowsTs_result implements org.apache.thrift.TBase<mutateRowsTs_result, mutateRowsTs_result._Fields>, java.io.Serializable, Cloneable, Comparable<mutateRowsTs_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("mutateRowsTs_result"); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final org.apache.thrift.protocol.TField IA_FIELD_DESC = new org.apache.thrift.protocol.TField("ia", org.apache.thrift.protocol.TType.STRUCT, (short)2); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new mutateRowsTs_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new mutateRowsTs_resultTupleSchemeFactory()); } public IOError io; // required public IllegalArgument ia; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { IO((short)1, "io"), IA((short)2, "ia"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // IO return IO; case 2: // IA return IA; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); tmpMap.put(_Fields.IA, new org.apache.thrift.meta_data.FieldMetaData("ia", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(mutateRowsTs_result.class, metaDataMap); } public mutateRowsTs_result() { } public mutateRowsTs_result( IOError io, IllegalArgument ia) { this(); this.io = io; this.ia = ia; } /** * Performs a deep copy on <i>other</i>. */ public mutateRowsTs_result(mutateRowsTs_result other) { if (other.isSetIo()) { this.io = new IOError(other.io); } if (other.isSetIa()) { this.ia = new IllegalArgument(other.ia); } } public mutateRowsTs_result deepCopy() { return new mutateRowsTs_result(this); } @Override public void clear() { this.io = null; this.ia = null; } public IOError getIo() { return this.io; } public mutateRowsTs_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public IllegalArgument getIa() { return this.ia; } public mutateRowsTs_result setIa(IllegalArgument ia) { this.ia = ia; return this; } public void unsetIa() { this.ia = null; } /** Returns true if field ia is set (has been assigned a value) and false otherwise */ public boolean isSetIa() { return this.ia != null; } public void setIaIsSet(boolean value) { if (!value) { this.ia = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; case IA: if (value == null) { unsetIa(); } else { setIa((IllegalArgument)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case IO: return getIo(); case IA: return getIa(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case IO: return isSetIo(); case IA: return isSetIa(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof mutateRowsTs_result) return this.equals((mutateRowsTs_result)that); return false; } public boolean equals(mutateRowsTs_result that) { if (that == null) return false; boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } boolean this_present_ia = true && this.isSetIa(); boolean that_present_ia = true && that.isSetIa(); if (this_present_ia || that_present_ia) { if (!(this_present_ia && that_present_ia)) return false; if (!this.ia.equals(that.ia)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); boolean present_ia = true && (isSetIa()); list.add(present_ia); if (present_ia) list.add(ia); return list.hashCode(); } @Override public int compareTo(mutateRowsTs_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIa()).compareTo(other.isSetIa()); if (lastComparison != 0) { return lastComparison; } if (isSetIa()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ia, other.ia); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("mutateRowsTs_result("); boolean first = true; sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; if (!first) sb.append(", "); sb.append("ia:"); if (this.ia == null) { sb.append("null"); } else { sb.append(this.ia); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class mutateRowsTs_resultStandardSchemeFactory implements SchemeFactory { public mutateRowsTs_resultStandardScheme getScheme() { return new mutateRowsTs_resultStandardScheme(); } } private static class mutateRowsTs_resultStandardScheme extends StandardScheme<mutateRowsTs_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, mutateRowsTs_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // IA if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.ia = new IllegalArgument(); struct.ia.read(iprot); struct.setIaIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, mutateRowsTs_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } if (struct.ia != null) { oprot.writeFieldBegin(IA_FIELD_DESC); struct.ia.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class mutateRowsTs_resultTupleSchemeFactory implements SchemeFactory { public mutateRowsTs_resultTupleScheme getScheme() { return new mutateRowsTs_resultTupleScheme(); } } private static class mutateRowsTs_resultTupleScheme extends TupleScheme<mutateRowsTs_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, mutateRowsTs_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetIo()) { optionals.set(0); } if (struct.isSetIa()) { optionals.set(1); } oprot.writeBitSet(optionals, 2); if (struct.isSetIo()) { struct.io.write(oprot); } if (struct.isSetIa()) { struct.ia.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, mutateRowsTs_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } if (incoming.get(1)) { struct.ia = new IllegalArgument(); struct.ia.read(iprot); struct.setIaIsSet(true); } } } } public static class atomicIncrement_args implements org.apache.thrift.TBase<atomicIncrement_args, atomicIncrement_args._Fields>, java.io.Serializable, Cloneable, Comparable<atomicIncrement_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("atomicIncrement_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final org.apache.thrift.protocol.TField ROW_FIELD_DESC = new org.apache.thrift.protocol.TField("row", org.apache.thrift.protocol.TType.STRING, (short)2); private static final org.apache.thrift.protocol.TField COLUMN_FIELD_DESC = new org.apache.thrift.protocol.TField("column", org.apache.thrift.protocol.TType.STRING, (short)3); private static final org.apache.thrift.protocol.TField VALUE_FIELD_DESC = new org.apache.thrift.protocol.TField("value", org.apache.thrift.protocol.TType.I64, (short)4); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new atomicIncrement_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new atomicIncrement_argsTupleSchemeFactory()); } /** * name of table */ public ByteBuffer tableName; // required /** * row to increment */ public ByteBuffer row; // required /** * name of column */ public ByteBuffer column; // required /** * amount to increment by */ public long value; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * name of table */ TABLE_NAME((short)1, "tableName"), /** * row to increment */ ROW((short)2, "row"), /** * name of column */ COLUMN((short)3, "column"), /** * amount to increment by */ VALUE((short)4, "value"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; case 2: // ROW return ROW; case 3: // COLUMN return COLUMN; case 4: // VALUE return VALUE; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments private static final int __VALUE_ISSET_ID = 0; private byte __isset_bitfield = 0; public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.ROW, new org.apache.thrift.meta_data.FieldMetaData("row", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.COLUMN, new org.apache.thrift.meta_data.FieldMetaData("column", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.VALUE, new org.apache.thrift.meta_data.FieldMetaData("value", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.I64))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(atomicIncrement_args.class, metaDataMap); } public atomicIncrement_args() { } public atomicIncrement_args( ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long value) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); this.row = org.apache.thrift.TBaseHelper.copyBinary(row); this.column = org.apache.thrift.TBaseHelper.copyBinary(column); this.value = value; setValueIsSet(true); } /** * Performs a deep copy on <i>other</i>. */ public atomicIncrement_args(atomicIncrement_args other) { __isset_bitfield = other.__isset_bitfield; if (other.isSetTableName()) { this.tableName = other.tableName; } if (other.isSetRow()) { this.row = other.row; } if (other.isSetColumn()) { this.column = other.column; } this.value = other.value; } public atomicIncrement_args deepCopy() { return new atomicIncrement_args(this); } @Override public void clear() { this.tableName = null; this.row = null; this.column = null; setValueIsSet(false); this.value = 0; } /** * name of table */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * name of table */ public atomicIncrement_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public atomicIncrement_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } /** * row to increment */ public byte[] getRow() { setRow(org.apache.thrift.TBaseHelper.rightSize(row)); return row == null ? null : row.array(); } public ByteBuffer bufferForRow() { return org.apache.thrift.TBaseHelper.copyBinary(row); } /** * row to increment */ public atomicIncrement_args setRow(byte[] row) { this.row = row == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(row, row.length)); return this; } public atomicIncrement_args setRow(ByteBuffer row) { this.row = org.apache.thrift.TBaseHelper.copyBinary(row); return this; } public void unsetRow() { this.row = null; } /** Returns true if field row is set (has been assigned a value) and false otherwise */ public boolean isSetRow() { return this.row != null; } public void setRowIsSet(boolean value) { if (!value) { this.row = null; } } /** * name of column */ public byte[] getColumn() { setColumn(org.apache.thrift.TBaseHelper.rightSize(column)); return column == null ? null : column.array(); } public ByteBuffer bufferForColumn() { return org.apache.thrift.TBaseHelper.copyBinary(column); } /** * name of column */ public atomicIncrement_args setColumn(byte[] column) { this.column = column == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(column, column.length)); return this; } public atomicIncrement_args setColumn(ByteBuffer column) { this.column = org.apache.thrift.TBaseHelper.copyBinary(column); return this; } public void unsetColumn() { this.column = null; } /** Returns true if field column is set (has been assigned a value) and false otherwise */ public boolean isSetColumn() { return this.column != null; } public void setColumnIsSet(boolean value) { if (!value) { this.column = null; } } /** * amount to increment by */ public long getValue() { return this.value; } /** * amount to increment by */ public atomicIncrement_args setValue(long value) { this.value = value; setValueIsSet(true); return this; } public void unsetValue() { __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __VALUE_ISSET_ID); } /** Returns true if field value is set (has been assigned a value) and false otherwise */ public boolean isSetValue() { return EncodingUtils.testBit(__isset_bitfield, __VALUE_ISSET_ID); } public void setValueIsSet(boolean value) { __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __VALUE_ISSET_ID, value); } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; case ROW: if (value == null) { unsetRow(); } else { setRow((ByteBuffer)value); } break; case COLUMN: if (value == null) { unsetColumn(); } else { setColumn((ByteBuffer)value); } break; case VALUE: if (value == null) { unsetValue(); } else { setValue((Long)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); case ROW: return getRow(); case COLUMN: return getColumn(); case VALUE: return getValue(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); case ROW: return isSetRow(); case COLUMN: return isSetColumn(); case VALUE: return isSetValue(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof atomicIncrement_args) return this.equals((atomicIncrement_args)that); return false; } public boolean equals(atomicIncrement_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } boolean this_present_row = true && this.isSetRow(); boolean that_present_row = true && that.isSetRow(); if (this_present_row || that_present_row) { if (!(this_present_row && that_present_row)) return false; if (!this.row.equals(that.row)) return false; } boolean this_present_column = true && this.isSetColumn(); boolean that_present_column = true && that.isSetColumn(); if (this_present_column || that_present_column) { if (!(this_present_column && that_present_column)) return false; if (!this.column.equals(that.column)) return false; } boolean this_present_value = true; boolean that_present_value = true; if (this_present_value || that_present_value) { if (!(this_present_value && that_present_value)) return false; if (this.value != that.value) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); boolean present_row = true && (isSetRow()); list.add(present_row); if (present_row) list.add(row); boolean present_column = true && (isSetColumn()); list.add(present_column); if (present_column) list.add(column); boolean present_value = true; list.add(present_value); if (present_value) list.add(value); return list.hashCode(); } @Override public int compareTo(atomicIncrement_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetRow()).compareTo(other.isSetRow()); if (lastComparison != 0) { return lastComparison; } if (isSetRow()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.row, other.row); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetColumn()).compareTo(other.isSetColumn()); if (lastComparison != 0) { return lastComparison; } if (isSetColumn()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.column, other.column); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetValue()).compareTo(other.isSetValue()); if (lastComparison != 0) { return lastComparison; } if (isSetValue()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.value, other.value); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("atomicIncrement_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; if (!first) sb.append(", "); sb.append("row:"); if (this.row == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.row, sb); } first = false; if (!first) sb.append(", "); sb.append("column:"); if (this.column == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.column, sb); } first = false; if (!first) sb.append(", "); sb.append("value:"); sb.append(this.value); first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { // it doesn't seem like you should have to do this, but java serialization is wacky, and doesn't call the default constructor. __isset_bitfield = 0; read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class atomicIncrement_argsStandardSchemeFactory implements SchemeFactory { public atomicIncrement_argsStandardScheme getScheme() { return new atomicIncrement_argsStandardScheme(); } } private static class atomicIncrement_argsStandardScheme extends StandardScheme<atomicIncrement_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, atomicIncrement_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // ROW if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.row = iprot.readBinary(); struct.setRowIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 3: // COLUMN if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.column = iprot.readBinary(); struct.setColumnIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 4: // VALUE if (schemeField.type == org.apache.thrift.protocol.TType.I64) { struct.value = iprot.readI64(); struct.setValueIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, atomicIncrement_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } if (struct.row != null) { oprot.writeFieldBegin(ROW_FIELD_DESC); oprot.writeBinary(struct.row); oprot.writeFieldEnd(); } if (struct.column != null) { oprot.writeFieldBegin(COLUMN_FIELD_DESC); oprot.writeBinary(struct.column); oprot.writeFieldEnd(); } oprot.writeFieldBegin(VALUE_FIELD_DESC); oprot.writeI64(struct.value); oprot.writeFieldEnd(); oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class atomicIncrement_argsTupleSchemeFactory implements SchemeFactory { public atomicIncrement_argsTupleScheme getScheme() { return new atomicIncrement_argsTupleScheme(); } } private static class atomicIncrement_argsTupleScheme extends TupleScheme<atomicIncrement_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, atomicIncrement_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } if (struct.isSetRow()) { optionals.set(1); } if (struct.isSetColumn()) { optionals.set(2); } if (struct.isSetValue()) { optionals.set(3); } oprot.writeBitSet(optionals, 4); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } if (struct.isSetRow()) { oprot.writeBinary(struct.row); } if (struct.isSetColumn()) { oprot.writeBinary(struct.column); } if (struct.isSetValue()) { oprot.writeI64(struct.value); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, atomicIncrement_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(4); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } if (incoming.get(1)) { struct.row = iprot.readBinary(); struct.setRowIsSet(true); } if (incoming.get(2)) { struct.column = iprot.readBinary(); struct.setColumnIsSet(true); } if (incoming.get(3)) { struct.value = iprot.readI64(); struct.setValueIsSet(true); } } } } public static class atomicIncrement_result implements org.apache.thrift.TBase<atomicIncrement_result, atomicIncrement_result._Fields>, java.io.Serializable, Cloneable, Comparable<atomicIncrement_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("atomicIncrement_result"); private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.I64, (short)0); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final org.apache.thrift.protocol.TField IA_FIELD_DESC = new org.apache.thrift.protocol.TField("ia", org.apache.thrift.protocol.TType.STRUCT, (short)2); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new atomicIncrement_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new atomicIncrement_resultTupleSchemeFactory()); } public long success; // required public IOError io; // required public IllegalArgument ia; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { SUCCESS((short)0, "success"), IO((short)1, "io"), IA((short)2, "ia"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 0: // SUCCESS return SUCCESS; case 1: // IO return IO; case 2: // IA return IA; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments private static final int __SUCCESS_ISSET_ID = 0; private byte __isset_bitfield = 0; public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.SUCCESS, new org.apache.thrift.meta_data.FieldMetaData("success", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.I64))); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); tmpMap.put(_Fields.IA, new org.apache.thrift.meta_data.FieldMetaData("ia", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(atomicIncrement_result.class, metaDataMap); } public atomicIncrement_result() { } public atomicIncrement_result( long success, IOError io, IllegalArgument ia) { this(); this.success = success; setSuccessIsSet(true); this.io = io; this.ia = ia; } /** * Performs a deep copy on <i>other</i>. */ public atomicIncrement_result(atomicIncrement_result other) { __isset_bitfield = other.__isset_bitfield; this.success = other.success; if (other.isSetIo()) { this.io = new IOError(other.io); } if (other.isSetIa()) { this.ia = new IllegalArgument(other.ia); } } public atomicIncrement_result deepCopy() { return new atomicIncrement_result(this); } @Override public void clear() { setSuccessIsSet(false); this.success = 0; this.io = null; this.ia = null; } public long getSuccess() { return this.success; } public atomicIncrement_result setSuccess(long success) { this.success = success; setSuccessIsSet(true); return this; } public void unsetSuccess() { __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __SUCCESS_ISSET_ID); } /** Returns true if field success is set (has been assigned a value) and false otherwise */ public boolean isSetSuccess() { return EncodingUtils.testBit(__isset_bitfield, __SUCCESS_ISSET_ID); } public void setSuccessIsSet(boolean value) { __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __SUCCESS_ISSET_ID, value); } public IOError getIo() { return this.io; } public atomicIncrement_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public IllegalArgument getIa() { return this.ia; } public atomicIncrement_result setIa(IllegalArgument ia) { this.ia = ia; return this; } public void unsetIa() { this.ia = null; } /** Returns true if field ia is set (has been assigned a value) and false otherwise */ public boolean isSetIa() { return this.ia != null; } public void setIaIsSet(boolean value) { if (!value) { this.ia = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case SUCCESS: if (value == null) { unsetSuccess(); } else { setSuccess((Long)value); } break; case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; case IA: if (value == null) { unsetIa(); } else { setIa((IllegalArgument)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case SUCCESS: return getSuccess(); case IO: return getIo(); case IA: return getIa(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case SUCCESS: return isSetSuccess(); case IO: return isSetIo(); case IA: return isSetIa(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof atomicIncrement_result) return this.equals((atomicIncrement_result)that); return false; } public boolean equals(atomicIncrement_result that) { if (that == null) return false; boolean this_present_success = true; boolean that_present_success = true; if (this_present_success || that_present_success) { if (!(this_present_success && that_present_success)) return false; if (this.success != that.success) return false; } boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } boolean this_present_ia = true && this.isSetIa(); boolean that_present_ia = true && that.isSetIa(); if (this_present_ia || that_present_ia) { if (!(this_present_ia && that_present_ia)) return false; if (!this.ia.equals(that.ia)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_success = true; list.add(present_success); if (present_success) list.add(success); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); boolean present_ia = true && (isSetIa()); list.add(present_ia); if (present_ia) list.add(ia); return list.hashCode(); } @Override public int compareTo(atomicIncrement_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess()); if (lastComparison != 0) { return lastComparison; } if (isSetSuccess()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIa()).compareTo(other.isSetIa()); if (lastComparison != 0) { return lastComparison; } if (isSetIa()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ia, other.ia); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("atomicIncrement_result("); boolean first = true; sb.append("success:"); sb.append(this.success); first = false; if (!first) sb.append(", "); sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; if (!first) sb.append(", "); sb.append("ia:"); if (this.ia == null) { sb.append("null"); } else { sb.append(this.ia); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { // it doesn't seem like you should have to do this, but java serialization is wacky, and doesn't call the default constructor. __isset_bitfield = 0; read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class atomicIncrement_resultStandardSchemeFactory implements SchemeFactory { public atomicIncrement_resultStandardScheme getScheme() { return new atomicIncrement_resultStandardScheme(); } } private static class atomicIncrement_resultStandardScheme extends StandardScheme<atomicIncrement_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, atomicIncrement_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.I64) { struct.success = iprot.readI64(); struct.setSuccessIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // IA if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.ia = new IllegalArgument(); struct.ia.read(iprot); struct.setIaIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, atomicIncrement_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.isSetSuccess()) { oprot.writeFieldBegin(SUCCESS_FIELD_DESC); oprot.writeI64(struct.success); oprot.writeFieldEnd(); } if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } if (struct.ia != null) { oprot.writeFieldBegin(IA_FIELD_DESC); struct.ia.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class atomicIncrement_resultTupleSchemeFactory implements SchemeFactory { public atomicIncrement_resultTupleScheme getScheme() { return new atomicIncrement_resultTupleScheme(); } } private static class atomicIncrement_resultTupleScheme extends TupleScheme<atomicIncrement_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, atomicIncrement_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetSuccess()) { optionals.set(0); } if (struct.isSetIo()) { optionals.set(1); } if (struct.isSetIa()) { optionals.set(2); } oprot.writeBitSet(optionals, 3); if (struct.isSetSuccess()) { oprot.writeI64(struct.success); } if (struct.isSetIo()) { struct.io.write(oprot); } if (struct.isSetIa()) { struct.ia.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, atomicIncrement_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(3); if (incoming.get(0)) { struct.success = iprot.readI64(); struct.setSuccessIsSet(true); } if (incoming.get(1)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } if (incoming.get(2)) { struct.ia = new IllegalArgument(); struct.ia.read(iprot); struct.setIaIsSet(true); } } } } public static class deleteAll_args implements org.apache.thrift.TBase<deleteAll_args, deleteAll_args._Fields>, java.io.Serializable, Cloneable, Comparable<deleteAll_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("deleteAll_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final org.apache.thrift.protocol.TField ROW_FIELD_DESC = new org.apache.thrift.protocol.TField("row", org.apache.thrift.protocol.TType.STRING, (short)2); private static final org.apache.thrift.protocol.TField COLUMN_FIELD_DESC = new org.apache.thrift.protocol.TField("column", org.apache.thrift.protocol.TType.STRING, (short)3); private static final org.apache.thrift.protocol.TField ATTRIBUTES_FIELD_DESC = new org.apache.thrift.protocol.TField("attributes", org.apache.thrift.protocol.TType.MAP, (short)4); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new deleteAll_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new deleteAll_argsTupleSchemeFactory()); } /** * name of table */ public ByteBuffer tableName; // required /** * Row to update */ public ByteBuffer row; // required /** * name of column whose value is to be deleted */ public ByteBuffer column; // required /** * Delete attributes */ public Map<ByteBuffer,ByteBuffer> attributes; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * name of table */ TABLE_NAME((short)1, "tableName"), /** * Row to update */ ROW((short)2, "row"), /** * name of column whose value is to be deleted */ COLUMN((short)3, "column"), /** * Delete attributes */ ATTRIBUTES((short)4, "attributes"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; case 2: // ROW return ROW; case 3: // COLUMN return COLUMN; case 4: // ATTRIBUTES return ATTRIBUTES; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.ROW, new org.apache.thrift.meta_data.FieldMetaData("row", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.COLUMN, new org.apache.thrift.meta_data.FieldMetaData("column", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.ATTRIBUTES, new org.apache.thrift.meta_data.FieldMetaData("attributes", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.MapMetaData(org.apache.thrift.protocol.TType.MAP, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"), new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(deleteAll_args.class, metaDataMap); } public deleteAll_args() { } public deleteAll_args( ByteBuffer tableName, ByteBuffer row, ByteBuffer column, Map<ByteBuffer,ByteBuffer> attributes) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); this.row = org.apache.thrift.TBaseHelper.copyBinary(row); this.column = org.apache.thrift.TBaseHelper.copyBinary(column); this.attributes = attributes; } /** * Performs a deep copy on <i>other</i>. */ public deleteAll_args(deleteAll_args other) { if (other.isSetTableName()) { this.tableName = other.tableName; } if (other.isSetRow()) { this.row = other.row; } if (other.isSetColumn()) { this.column = other.column; } if (other.isSetAttributes()) { Map<ByteBuffer,ByteBuffer> __this__attributes = new HashMap<ByteBuffer,ByteBuffer>(other.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> other_element : other.attributes.entrySet()) { ByteBuffer other_element_key = other_element.getKey(); ByteBuffer other_element_value = other_element.getValue(); ByteBuffer __this__attributes_copy_key = other_element_key; ByteBuffer __this__attributes_copy_value = other_element_value; __this__attributes.put(__this__attributes_copy_key, __this__attributes_copy_value); } this.attributes = __this__attributes; } } public deleteAll_args deepCopy() { return new deleteAll_args(this); } @Override public void clear() { this.tableName = null; this.row = null; this.column = null; this.attributes = null; } /** * name of table */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * name of table */ public deleteAll_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public deleteAll_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } /** * Row to update */ public byte[] getRow() { setRow(org.apache.thrift.TBaseHelper.rightSize(row)); return row == null ? null : row.array(); } public ByteBuffer bufferForRow() { return org.apache.thrift.TBaseHelper.copyBinary(row); } /** * Row to update */ public deleteAll_args setRow(byte[] row) { this.row = row == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(row, row.length)); return this; } public deleteAll_args setRow(ByteBuffer row) { this.row = org.apache.thrift.TBaseHelper.copyBinary(row); return this; } public void unsetRow() { this.row = null; } /** Returns true if field row is set (has been assigned a value) and false otherwise */ public boolean isSetRow() { return this.row != null; } public void setRowIsSet(boolean value) { if (!value) { this.row = null; } } /** * name of column whose value is to be deleted */ public byte[] getColumn() { setColumn(org.apache.thrift.TBaseHelper.rightSize(column)); return column == null ? null : column.array(); } public ByteBuffer bufferForColumn() { return org.apache.thrift.TBaseHelper.copyBinary(column); } /** * name of column whose value is to be deleted */ public deleteAll_args setColumn(byte[] column) { this.column = column == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(column, column.length)); return this; } public deleteAll_args setColumn(ByteBuffer column) { this.column = org.apache.thrift.TBaseHelper.copyBinary(column); return this; } public void unsetColumn() { this.column = null; } /** Returns true if field column is set (has been assigned a value) and false otherwise */ public boolean isSetColumn() { return this.column != null; } public void setColumnIsSet(boolean value) { if (!value) { this.column = null; } } public int getAttributesSize() { return (this.attributes == null) ? 0 : this.attributes.size(); } public void putToAttributes(ByteBuffer key, ByteBuffer val) { if (this.attributes == null) { this.attributes = new HashMap<ByteBuffer,ByteBuffer>(); } this.attributes.put(key, val); } /** * Delete attributes */ public Map<ByteBuffer,ByteBuffer> getAttributes() { return this.attributes; } /** * Delete attributes */ public deleteAll_args setAttributes(Map<ByteBuffer,ByteBuffer> attributes) { this.attributes = attributes; return this; } public void unsetAttributes() { this.attributes = null; } /** Returns true if field attributes is set (has been assigned a value) and false otherwise */ public boolean isSetAttributes() { return this.attributes != null; } public void setAttributesIsSet(boolean value) { if (!value) { this.attributes = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; case ROW: if (value == null) { unsetRow(); } else { setRow((ByteBuffer)value); } break; case COLUMN: if (value == null) { unsetColumn(); } else { setColumn((ByteBuffer)value); } break; case ATTRIBUTES: if (value == null) { unsetAttributes(); } else { setAttributes((Map<ByteBuffer,ByteBuffer>)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); case ROW: return getRow(); case COLUMN: return getColumn(); case ATTRIBUTES: return getAttributes(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); case ROW: return isSetRow(); case COLUMN: return isSetColumn(); case ATTRIBUTES: return isSetAttributes(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof deleteAll_args) return this.equals((deleteAll_args)that); return false; } public boolean equals(deleteAll_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } boolean this_present_row = true && this.isSetRow(); boolean that_present_row = true && that.isSetRow(); if (this_present_row || that_present_row) { if (!(this_present_row && that_present_row)) return false; if (!this.row.equals(that.row)) return false; } boolean this_present_column = true && this.isSetColumn(); boolean that_present_column = true && that.isSetColumn(); if (this_present_column || that_present_column) { if (!(this_present_column && that_present_column)) return false; if (!this.column.equals(that.column)) return false; } boolean this_present_attributes = true && this.isSetAttributes(); boolean that_present_attributes = true && that.isSetAttributes(); if (this_present_attributes || that_present_attributes) { if (!(this_present_attributes && that_present_attributes)) return false; if (!this.attributes.equals(that.attributes)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); boolean present_row = true && (isSetRow()); list.add(present_row); if (present_row) list.add(row); boolean present_column = true && (isSetColumn()); list.add(present_column); if (present_column) list.add(column); boolean present_attributes = true && (isSetAttributes()); list.add(present_attributes); if (present_attributes) list.add(attributes); return list.hashCode(); } @Override public int compareTo(deleteAll_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetRow()).compareTo(other.isSetRow()); if (lastComparison != 0) { return lastComparison; } if (isSetRow()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.row, other.row); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetColumn()).compareTo(other.isSetColumn()); if (lastComparison != 0) { return lastComparison; } if (isSetColumn()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.column, other.column); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetAttributes()).compareTo(other.isSetAttributes()); if (lastComparison != 0) { return lastComparison; } if (isSetAttributes()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.attributes, other.attributes); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("deleteAll_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; if (!first) sb.append(", "); sb.append("row:"); if (this.row == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.row, sb); } first = false; if (!first) sb.append(", "); sb.append("column:"); if (this.column == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.column, sb); } first = false; if (!first) sb.append(", "); sb.append("attributes:"); if (this.attributes == null) { sb.append("null"); } else { sb.append(this.attributes); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class deleteAll_argsStandardSchemeFactory implements SchemeFactory { public deleteAll_argsStandardScheme getScheme() { return new deleteAll_argsStandardScheme(); } } private static class deleteAll_argsStandardScheme extends StandardScheme<deleteAll_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, deleteAll_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // ROW if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.row = iprot.readBinary(); struct.setRowIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 3: // COLUMN if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.column = iprot.readBinary(); struct.setColumnIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 4: // ATTRIBUTES if (schemeField.type == org.apache.thrift.protocol.TType.MAP) { { org.apache.thrift.protocol.TMap _map418 = iprot.readMapBegin(); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map418.size); ByteBuffer _key419; ByteBuffer _val420; for (int _i421 = 0; _i421 < _map418.size; ++_i421) { _key419 = iprot.readBinary(); _val420 = iprot.readBinary(); struct.attributes.put(_key419, _val420); } iprot.readMapEnd(); } struct.setAttributesIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, deleteAll_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } if (struct.row != null) { oprot.writeFieldBegin(ROW_FIELD_DESC); oprot.writeBinary(struct.row); oprot.writeFieldEnd(); } if (struct.column != null) { oprot.writeFieldBegin(COLUMN_FIELD_DESC); oprot.writeBinary(struct.column); oprot.writeFieldEnd(); } if (struct.attributes != null) { oprot.writeFieldBegin(ATTRIBUTES_FIELD_DESC); { oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, struct.attributes.size())); for (Map.Entry<ByteBuffer, ByteBuffer> _iter422 : struct.attributes.entrySet()) { oprot.writeBinary(_iter422.getKey()); oprot.writeBinary(_iter422.getValue()); } oprot.writeMapEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class deleteAll_argsTupleSchemeFactory implements SchemeFactory { public deleteAll_argsTupleScheme getScheme() { return new deleteAll_argsTupleScheme(); } } private static class deleteAll_argsTupleScheme extends TupleScheme<deleteAll_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, deleteAll_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } if (struct.isSetRow()) { optionals.set(1); } if (struct.isSetColumn()) { optionals.set(2); } if (struct.isSetAttributes()) { optionals.set(3); } oprot.writeBitSet(optionals, 4); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } if (struct.isSetRow()) { oprot.writeBinary(struct.row); } if (struct.isSetColumn()) { oprot.writeBinary(struct.column); } if (struct.isSetAttributes()) { { oprot.writeI32(struct.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> _iter423 : struct.attributes.entrySet()) { oprot.writeBinary(_iter423.getKey()); oprot.writeBinary(_iter423.getValue()); } } } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, deleteAll_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(4); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } if (incoming.get(1)) { struct.row = iprot.readBinary(); struct.setRowIsSet(true); } if (incoming.get(2)) { struct.column = iprot.readBinary(); struct.setColumnIsSet(true); } if (incoming.get(3)) { { org.apache.thrift.protocol.TMap _map424 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map424.size); ByteBuffer _key425; ByteBuffer _val426; for (int _i427 = 0; _i427 < _map424.size; ++_i427) { _key425 = iprot.readBinary(); _val426 = iprot.readBinary(); struct.attributes.put(_key425, _val426); } } struct.setAttributesIsSet(true); } } } } public static class deleteAll_result implements org.apache.thrift.TBase<deleteAll_result, deleteAll_result._Fields>, java.io.Serializable, Cloneable, Comparable<deleteAll_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("deleteAll_result"); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new deleteAll_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new deleteAll_resultTupleSchemeFactory()); } public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(deleteAll_result.class, metaDataMap); } public deleteAll_result() { } public deleteAll_result( IOError io) { this(); this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public deleteAll_result(deleteAll_result other) { if (other.isSetIo()) { this.io = new IOError(other.io); } } public deleteAll_result deepCopy() { return new deleteAll_result(this); } @Override public void clear() { this.io = null; } public IOError getIo() { return this.io; } public deleteAll_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof deleteAll_result) return this.equals((deleteAll_result)that); return false; } public boolean equals(deleteAll_result that) { if (that == null) return false; boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(deleteAll_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("deleteAll_result("); boolean first = true; sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class deleteAll_resultStandardSchemeFactory implements SchemeFactory { public deleteAll_resultStandardScheme getScheme() { return new deleteAll_resultStandardScheme(); } } private static class deleteAll_resultStandardScheme extends StandardScheme<deleteAll_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, deleteAll_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, deleteAll_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class deleteAll_resultTupleSchemeFactory implements SchemeFactory { public deleteAll_resultTupleScheme getScheme() { return new deleteAll_resultTupleScheme(); } } private static class deleteAll_resultTupleScheme extends TupleScheme<deleteAll_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, deleteAll_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetIo()) { optionals.set(0); } oprot.writeBitSet(optionals, 1); if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, deleteAll_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(1); if (incoming.get(0)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class deleteAllTs_args implements org.apache.thrift.TBase<deleteAllTs_args, deleteAllTs_args._Fields>, java.io.Serializable, Cloneable, Comparable<deleteAllTs_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("deleteAllTs_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final org.apache.thrift.protocol.TField ROW_FIELD_DESC = new org.apache.thrift.protocol.TField("row", org.apache.thrift.protocol.TType.STRING, (short)2); private static final org.apache.thrift.protocol.TField COLUMN_FIELD_DESC = new org.apache.thrift.protocol.TField("column", org.apache.thrift.protocol.TType.STRING, (short)3); private static final org.apache.thrift.protocol.TField TIMESTAMP_FIELD_DESC = new org.apache.thrift.protocol.TField("timestamp", org.apache.thrift.protocol.TType.I64, (short)4); private static final org.apache.thrift.protocol.TField ATTRIBUTES_FIELD_DESC = new org.apache.thrift.protocol.TField("attributes", org.apache.thrift.protocol.TType.MAP, (short)5); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new deleteAllTs_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new deleteAllTs_argsTupleSchemeFactory()); } /** * name of table */ public ByteBuffer tableName; // required /** * Row to update */ public ByteBuffer row; // required /** * name of column whose value is to be deleted */ public ByteBuffer column; // required /** * timestamp */ public long timestamp; // required /** * Delete attributes */ public Map<ByteBuffer,ByteBuffer> attributes; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * name of table */ TABLE_NAME((short)1, "tableName"), /** * Row to update */ ROW((short)2, "row"), /** * name of column whose value is to be deleted */ COLUMN((short)3, "column"), /** * timestamp */ TIMESTAMP((short)4, "timestamp"), /** * Delete attributes */ ATTRIBUTES((short)5, "attributes"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; case 2: // ROW return ROW; case 3: // COLUMN return COLUMN; case 4: // TIMESTAMP return TIMESTAMP; case 5: // ATTRIBUTES return ATTRIBUTES; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments private static final int __TIMESTAMP_ISSET_ID = 0; private byte __isset_bitfield = 0; public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.ROW, new org.apache.thrift.meta_data.FieldMetaData("row", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.COLUMN, new org.apache.thrift.meta_data.FieldMetaData("column", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.TIMESTAMP, new org.apache.thrift.meta_data.FieldMetaData("timestamp", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.I64))); tmpMap.put(_Fields.ATTRIBUTES, new org.apache.thrift.meta_data.FieldMetaData("attributes", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.MapMetaData(org.apache.thrift.protocol.TType.MAP, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"), new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(deleteAllTs_args.class, metaDataMap); } public deleteAllTs_args() { } public deleteAllTs_args( ByteBuffer tableName, ByteBuffer row, ByteBuffer column, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); this.row = org.apache.thrift.TBaseHelper.copyBinary(row); this.column = org.apache.thrift.TBaseHelper.copyBinary(column); this.timestamp = timestamp; setTimestampIsSet(true); this.attributes = attributes; } /** * Performs a deep copy on <i>other</i>. */ public deleteAllTs_args(deleteAllTs_args other) { __isset_bitfield = other.__isset_bitfield; if (other.isSetTableName()) { this.tableName = other.tableName; } if (other.isSetRow()) { this.row = other.row; } if (other.isSetColumn()) { this.column = other.column; } this.timestamp = other.timestamp; if (other.isSetAttributes()) { Map<ByteBuffer,ByteBuffer> __this__attributes = new HashMap<ByteBuffer,ByteBuffer>(other.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> other_element : other.attributes.entrySet()) { ByteBuffer other_element_key = other_element.getKey(); ByteBuffer other_element_value = other_element.getValue(); ByteBuffer __this__attributes_copy_key = other_element_key; ByteBuffer __this__attributes_copy_value = other_element_value; __this__attributes.put(__this__attributes_copy_key, __this__attributes_copy_value); } this.attributes = __this__attributes; } } public deleteAllTs_args deepCopy() { return new deleteAllTs_args(this); } @Override public void clear() { this.tableName = null; this.row = null; this.column = null; setTimestampIsSet(false); this.timestamp = 0; this.attributes = null; } /** * name of table */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * name of table */ public deleteAllTs_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public deleteAllTs_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } /** * Row to update */ public byte[] getRow() { setRow(org.apache.thrift.TBaseHelper.rightSize(row)); return row == null ? null : row.array(); } public ByteBuffer bufferForRow() { return org.apache.thrift.TBaseHelper.copyBinary(row); } /** * Row to update */ public deleteAllTs_args setRow(byte[] row) { this.row = row == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(row, row.length)); return this; } public deleteAllTs_args setRow(ByteBuffer row) { this.row = org.apache.thrift.TBaseHelper.copyBinary(row); return this; } public void unsetRow() { this.row = null; } /** Returns true if field row is set (has been assigned a value) and false otherwise */ public boolean isSetRow() { return this.row != null; } public void setRowIsSet(boolean value) { if (!value) { this.row = null; } } /** * name of column whose value is to be deleted */ public byte[] getColumn() { setColumn(org.apache.thrift.TBaseHelper.rightSize(column)); return column == null ? null : column.array(); } public ByteBuffer bufferForColumn() { return org.apache.thrift.TBaseHelper.copyBinary(column); } /** * name of column whose value is to be deleted */ public deleteAllTs_args setColumn(byte[] column) { this.column = column == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(column, column.length)); return this; } public deleteAllTs_args setColumn(ByteBuffer column) { this.column = org.apache.thrift.TBaseHelper.copyBinary(column); return this; } public void unsetColumn() { this.column = null; } /** Returns true if field column is set (has been assigned a value) and false otherwise */ public boolean isSetColumn() { return this.column != null; } public void setColumnIsSet(boolean value) { if (!value) { this.column = null; } } /** * timestamp */ public long getTimestamp() { return this.timestamp; } /** * timestamp */ public deleteAllTs_args setTimestamp(long timestamp) { this.timestamp = timestamp; setTimestampIsSet(true); return this; } public void unsetTimestamp() { __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __TIMESTAMP_ISSET_ID); } /** Returns true if field timestamp is set (has been assigned a value) and false otherwise */ public boolean isSetTimestamp() { return EncodingUtils.testBit(__isset_bitfield, __TIMESTAMP_ISSET_ID); } public void setTimestampIsSet(boolean value) { __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __TIMESTAMP_ISSET_ID, value); } public int getAttributesSize() { return (this.attributes == null) ? 0 : this.attributes.size(); } public void putToAttributes(ByteBuffer key, ByteBuffer val) { if (this.attributes == null) { this.attributes = new HashMap<ByteBuffer,ByteBuffer>(); } this.attributes.put(key, val); } /** * Delete attributes */ public Map<ByteBuffer,ByteBuffer> getAttributes() { return this.attributes; } /** * Delete attributes */ public deleteAllTs_args setAttributes(Map<ByteBuffer,ByteBuffer> attributes) { this.attributes = attributes; return this; } public void unsetAttributes() { this.attributes = null; } /** Returns true if field attributes is set (has been assigned a value) and false otherwise */ public boolean isSetAttributes() { return this.attributes != null; } public void setAttributesIsSet(boolean value) { if (!value) { this.attributes = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; case ROW: if (value == null) { unsetRow(); } else { setRow((ByteBuffer)value); } break; case COLUMN: if (value == null) { unsetColumn(); } else { setColumn((ByteBuffer)value); } break; case TIMESTAMP: if (value == null) { unsetTimestamp(); } else { setTimestamp((Long)value); } break; case ATTRIBUTES: if (value == null) { unsetAttributes(); } else { setAttributes((Map<ByteBuffer,ByteBuffer>)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); case ROW: return getRow(); case COLUMN: return getColumn(); case TIMESTAMP: return getTimestamp(); case ATTRIBUTES: return getAttributes(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); case ROW: return isSetRow(); case COLUMN: return isSetColumn(); case TIMESTAMP: return isSetTimestamp(); case ATTRIBUTES: return isSetAttributes(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof deleteAllTs_args) return this.equals((deleteAllTs_args)that); return false; } public boolean equals(deleteAllTs_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } boolean this_present_row = true && this.isSetRow(); boolean that_present_row = true && that.isSetRow(); if (this_present_row || that_present_row) { if (!(this_present_row && that_present_row)) return false; if (!this.row.equals(that.row)) return false; } boolean this_present_column = true && this.isSetColumn(); boolean that_present_column = true && that.isSetColumn(); if (this_present_column || that_present_column) { if (!(this_present_column && that_present_column)) return false; if (!this.column.equals(that.column)) return false; } boolean this_present_timestamp = true; boolean that_present_timestamp = true; if (this_present_timestamp || that_present_timestamp) { if (!(this_present_timestamp && that_present_timestamp)) return false; if (this.timestamp != that.timestamp) return false; } boolean this_present_attributes = true && this.isSetAttributes(); boolean that_present_attributes = true && that.isSetAttributes(); if (this_present_attributes || that_present_attributes) { if (!(this_present_attributes && that_present_attributes)) return false; if (!this.attributes.equals(that.attributes)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); boolean present_row = true && (isSetRow()); list.add(present_row); if (present_row) list.add(row); boolean present_column = true && (isSetColumn()); list.add(present_column); if (present_column) list.add(column); boolean present_timestamp = true; list.add(present_timestamp); if (present_timestamp) list.add(timestamp); boolean present_attributes = true && (isSetAttributes()); list.add(present_attributes); if (present_attributes) list.add(attributes); return list.hashCode(); } @Override public int compareTo(deleteAllTs_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetRow()).compareTo(other.isSetRow()); if (lastComparison != 0) { return lastComparison; } if (isSetRow()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.row, other.row); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetColumn()).compareTo(other.isSetColumn()); if (lastComparison != 0) { return lastComparison; } if (isSetColumn()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.column, other.column); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetTimestamp()).compareTo(other.isSetTimestamp()); if (lastComparison != 0) { return lastComparison; } if (isSetTimestamp()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.timestamp, other.timestamp); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetAttributes()).compareTo(other.isSetAttributes()); if (lastComparison != 0) { return lastComparison; } if (isSetAttributes()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.attributes, other.attributes); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("deleteAllTs_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; if (!first) sb.append(", "); sb.append("row:"); if (this.row == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.row, sb); } first = false; if (!first) sb.append(", "); sb.append("column:"); if (this.column == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.column, sb); } first = false; if (!first) sb.append(", "); sb.append("timestamp:"); sb.append(this.timestamp); first = false; if (!first) sb.append(", "); sb.append("attributes:"); if (this.attributes == null) { sb.append("null"); } else { sb.append(this.attributes); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { // it doesn't seem like you should have to do this, but java serialization is wacky, and doesn't call the default constructor. __isset_bitfield = 0; read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class deleteAllTs_argsStandardSchemeFactory implements SchemeFactory { public deleteAllTs_argsStandardScheme getScheme() { return new deleteAllTs_argsStandardScheme(); } } private static class deleteAllTs_argsStandardScheme extends StandardScheme<deleteAllTs_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, deleteAllTs_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // ROW if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.row = iprot.readBinary(); struct.setRowIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 3: // COLUMN if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.column = iprot.readBinary(); struct.setColumnIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 4: // TIMESTAMP if (schemeField.type == org.apache.thrift.protocol.TType.I64) { struct.timestamp = iprot.readI64(); struct.setTimestampIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 5: // ATTRIBUTES if (schemeField.type == org.apache.thrift.protocol.TType.MAP) { { org.apache.thrift.protocol.TMap _map428 = iprot.readMapBegin(); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map428.size); ByteBuffer _key429; ByteBuffer _val430; for (int _i431 = 0; _i431 < _map428.size; ++_i431) { _key429 = iprot.readBinary(); _val430 = iprot.readBinary(); struct.attributes.put(_key429, _val430); } iprot.readMapEnd(); } struct.setAttributesIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, deleteAllTs_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } if (struct.row != null) { oprot.writeFieldBegin(ROW_FIELD_DESC); oprot.writeBinary(struct.row); oprot.writeFieldEnd(); } if (struct.column != null) { oprot.writeFieldBegin(COLUMN_FIELD_DESC); oprot.writeBinary(struct.column); oprot.writeFieldEnd(); } oprot.writeFieldBegin(TIMESTAMP_FIELD_DESC); oprot.writeI64(struct.timestamp); oprot.writeFieldEnd(); if (struct.attributes != null) { oprot.writeFieldBegin(ATTRIBUTES_FIELD_DESC); { oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, struct.attributes.size())); for (Map.Entry<ByteBuffer, ByteBuffer> _iter432 : struct.attributes.entrySet()) { oprot.writeBinary(_iter432.getKey()); oprot.writeBinary(_iter432.getValue()); } oprot.writeMapEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class deleteAllTs_argsTupleSchemeFactory implements SchemeFactory { public deleteAllTs_argsTupleScheme getScheme() { return new deleteAllTs_argsTupleScheme(); } } private static class deleteAllTs_argsTupleScheme extends TupleScheme<deleteAllTs_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, deleteAllTs_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } if (struct.isSetRow()) { optionals.set(1); } if (struct.isSetColumn()) { optionals.set(2); } if (struct.isSetTimestamp()) { optionals.set(3); } if (struct.isSetAttributes()) { optionals.set(4); } oprot.writeBitSet(optionals, 5); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } if (struct.isSetRow()) { oprot.writeBinary(struct.row); } if (struct.isSetColumn()) { oprot.writeBinary(struct.column); } if (struct.isSetTimestamp()) { oprot.writeI64(struct.timestamp); } if (struct.isSetAttributes()) { { oprot.writeI32(struct.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> _iter433 : struct.attributes.entrySet()) { oprot.writeBinary(_iter433.getKey()); oprot.writeBinary(_iter433.getValue()); } } } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, deleteAllTs_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(5); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } if (incoming.get(1)) { struct.row = iprot.readBinary(); struct.setRowIsSet(true); } if (incoming.get(2)) { struct.column = iprot.readBinary(); struct.setColumnIsSet(true); } if (incoming.get(3)) { struct.timestamp = iprot.readI64(); struct.setTimestampIsSet(true); } if (incoming.get(4)) { { org.apache.thrift.protocol.TMap _map434 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map434.size); ByteBuffer _key435; ByteBuffer _val436; for (int _i437 = 0; _i437 < _map434.size; ++_i437) { _key435 = iprot.readBinary(); _val436 = iprot.readBinary(); struct.attributes.put(_key435, _val436); } } struct.setAttributesIsSet(true); } } } } public static class deleteAllTs_result implements org.apache.thrift.TBase<deleteAllTs_result, deleteAllTs_result._Fields>, java.io.Serializable, Cloneable, Comparable<deleteAllTs_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("deleteAllTs_result"); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new deleteAllTs_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new deleteAllTs_resultTupleSchemeFactory()); } public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(deleteAllTs_result.class, metaDataMap); } public deleteAllTs_result() { } public deleteAllTs_result( IOError io) { this(); this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public deleteAllTs_result(deleteAllTs_result other) { if (other.isSetIo()) { this.io = new IOError(other.io); } } public deleteAllTs_result deepCopy() { return new deleteAllTs_result(this); } @Override public void clear() { this.io = null; } public IOError getIo() { return this.io; } public deleteAllTs_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof deleteAllTs_result) return this.equals((deleteAllTs_result)that); return false; } public boolean equals(deleteAllTs_result that) { if (that == null) return false; boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(deleteAllTs_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("deleteAllTs_result("); boolean first = true; sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class deleteAllTs_resultStandardSchemeFactory implements SchemeFactory { public deleteAllTs_resultStandardScheme getScheme() { return new deleteAllTs_resultStandardScheme(); } } private static class deleteAllTs_resultStandardScheme extends StandardScheme<deleteAllTs_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, deleteAllTs_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, deleteAllTs_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class deleteAllTs_resultTupleSchemeFactory implements SchemeFactory { public deleteAllTs_resultTupleScheme getScheme() { return new deleteAllTs_resultTupleScheme(); } } private static class deleteAllTs_resultTupleScheme extends TupleScheme<deleteAllTs_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, deleteAllTs_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetIo()) { optionals.set(0); } oprot.writeBitSet(optionals, 1); if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, deleteAllTs_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(1); if (incoming.get(0)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class deleteAllRow_args implements org.apache.thrift.TBase<deleteAllRow_args, deleteAllRow_args._Fields>, java.io.Serializable, Cloneable, Comparable<deleteAllRow_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("deleteAllRow_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final org.apache.thrift.protocol.TField ROW_FIELD_DESC = new org.apache.thrift.protocol.TField("row", org.apache.thrift.protocol.TType.STRING, (short)2); private static final org.apache.thrift.protocol.TField ATTRIBUTES_FIELD_DESC = new org.apache.thrift.protocol.TField("attributes", org.apache.thrift.protocol.TType.MAP, (short)3); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new deleteAllRow_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new deleteAllRow_argsTupleSchemeFactory()); } /** * name of table */ public ByteBuffer tableName; // required /** * key of the row to be completely deleted. */ public ByteBuffer row; // required /** * Delete attributes */ public Map<ByteBuffer,ByteBuffer> attributes; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * name of table */ TABLE_NAME((short)1, "tableName"), /** * key of the row to be completely deleted. */ ROW((short)2, "row"), /** * Delete attributes */ ATTRIBUTES((short)3, "attributes"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; case 2: // ROW return ROW; case 3: // ATTRIBUTES return ATTRIBUTES; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.ROW, new org.apache.thrift.meta_data.FieldMetaData("row", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.ATTRIBUTES, new org.apache.thrift.meta_data.FieldMetaData("attributes", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.MapMetaData(org.apache.thrift.protocol.TType.MAP, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"), new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(deleteAllRow_args.class, metaDataMap); } public deleteAllRow_args() { } public deleteAllRow_args( ByteBuffer tableName, ByteBuffer row, Map<ByteBuffer,ByteBuffer> attributes) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); this.row = org.apache.thrift.TBaseHelper.copyBinary(row); this.attributes = attributes; } /** * Performs a deep copy on <i>other</i>. */ public deleteAllRow_args(deleteAllRow_args other) { if (other.isSetTableName()) { this.tableName = other.tableName; } if (other.isSetRow()) { this.row = other.row; } if (other.isSetAttributes()) { Map<ByteBuffer,ByteBuffer> __this__attributes = new HashMap<ByteBuffer,ByteBuffer>(other.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> other_element : other.attributes.entrySet()) { ByteBuffer other_element_key = other_element.getKey(); ByteBuffer other_element_value = other_element.getValue(); ByteBuffer __this__attributes_copy_key = other_element_key; ByteBuffer __this__attributes_copy_value = other_element_value; __this__attributes.put(__this__attributes_copy_key, __this__attributes_copy_value); } this.attributes = __this__attributes; } } public deleteAllRow_args deepCopy() { return new deleteAllRow_args(this); } @Override public void clear() { this.tableName = null; this.row = null; this.attributes = null; } /** * name of table */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * name of table */ public deleteAllRow_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public deleteAllRow_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } /** * key of the row to be completely deleted. */ public byte[] getRow() { setRow(org.apache.thrift.TBaseHelper.rightSize(row)); return row == null ? null : row.array(); } public ByteBuffer bufferForRow() { return org.apache.thrift.TBaseHelper.copyBinary(row); } /** * key of the row to be completely deleted. */ public deleteAllRow_args setRow(byte[] row) { this.row = row == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(row, row.length)); return this; } public deleteAllRow_args setRow(ByteBuffer row) { this.row = org.apache.thrift.TBaseHelper.copyBinary(row); return this; } public void unsetRow() { this.row = null; } /** Returns true if field row is set (has been assigned a value) and false otherwise */ public boolean isSetRow() { return this.row != null; } public void setRowIsSet(boolean value) { if (!value) { this.row = null; } } public int getAttributesSize() { return (this.attributes == null) ? 0 : this.attributes.size(); } public void putToAttributes(ByteBuffer key, ByteBuffer val) { if (this.attributes == null) { this.attributes = new HashMap<ByteBuffer,ByteBuffer>(); } this.attributes.put(key, val); } /** * Delete attributes */ public Map<ByteBuffer,ByteBuffer> getAttributes() { return this.attributes; } /** * Delete attributes */ public deleteAllRow_args setAttributes(Map<ByteBuffer,ByteBuffer> attributes) { this.attributes = attributes; return this; } public void unsetAttributes() { this.attributes = null; } /** Returns true if field attributes is set (has been assigned a value) and false otherwise */ public boolean isSetAttributes() { return this.attributes != null; } public void setAttributesIsSet(boolean value) { if (!value) { this.attributes = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; case ROW: if (value == null) { unsetRow(); } else { setRow((ByteBuffer)value); } break; case ATTRIBUTES: if (value == null) { unsetAttributes(); } else { setAttributes((Map<ByteBuffer,ByteBuffer>)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); case ROW: return getRow(); case ATTRIBUTES: return getAttributes(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); case ROW: return isSetRow(); case ATTRIBUTES: return isSetAttributes(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof deleteAllRow_args) return this.equals((deleteAllRow_args)that); return false; } public boolean equals(deleteAllRow_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } boolean this_present_row = true && this.isSetRow(); boolean that_present_row = true && that.isSetRow(); if (this_present_row || that_present_row) { if (!(this_present_row && that_present_row)) return false; if (!this.row.equals(that.row)) return false; } boolean this_present_attributes = true && this.isSetAttributes(); boolean that_present_attributes = true && that.isSetAttributes(); if (this_present_attributes || that_present_attributes) { if (!(this_present_attributes && that_present_attributes)) return false; if (!this.attributes.equals(that.attributes)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); boolean present_row = true && (isSetRow()); list.add(present_row); if (present_row) list.add(row); boolean present_attributes = true && (isSetAttributes()); list.add(present_attributes); if (present_attributes) list.add(attributes); return list.hashCode(); } @Override public int compareTo(deleteAllRow_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetRow()).compareTo(other.isSetRow()); if (lastComparison != 0) { return lastComparison; } if (isSetRow()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.row, other.row); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetAttributes()).compareTo(other.isSetAttributes()); if (lastComparison != 0) { return lastComparison; } if (isSetAttributes()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.attributes, other.attributes); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("deleteAllRow_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; if (!first) sb.append(", "); sb.append("row:"); if (this.row == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.row, sb); } first = false; if (!first) sb.append(", "); sb.append("attributes:"); if (this.attributes == null) { sb.append("null"); } else { sb.append(this.attributes); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class deleteAllRow_argsStandardSchemeFactory implements SchemeFactory { public deleteAllRow_argsStandardScheme getScheme() { return new deleteAllRow_argsStandardScheme(); } } private static class deleteAllRow_argsStandardScheme extends StandardScheme<deleteAllRow_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, deleteAllRow_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // ROW if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.row = iprot.readBinary(); struct.setRowIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 3: // ATTRIBUTES if (schemeField.type == org.apache.thrift.protocol.TType.MAP) { { org.apache.thrift.protocol.TMap _map438 = iprot.readMapBegin(); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map438.size); ByteBuffer _key439; ByteBuffer _val440; for (int _i441 = 0; _i441 < _map438.size; ++_i441) { _key439 = iprot.readBinary(); _val440 = iprot.readBinary(); struct.attributes.put(_key439, _val440); } iprot.readMapEnd(); } struct.setAttributesIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, deleteAllRow_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } if (struct.row != null) { oprot.writeFieldBegin(ROW_FIELD_DESC); oprot.writeBinary(struct.row); oprot.writeFieldEnd(); } if (struct.attributes != null) { oprot.writeFieldBegin(ATTRIBUTES_FIELD_DESC); { oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, struct.attributes.size())); for (Map.Entry<ByteBuffer, ByteBuffer> _iter442 : struct.attributes.entrySet()) { oprot.writeBinary(_iter442.getKey()); oprot.writeBinary(_iter442.getValue()); } oprot.writeMapEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class deleteAllRow_argsTupleSchemeFactory implements SchemeFactory { public deleteAllRow_argsTupleScheme getScheme() { return new deleteAllRow_argsTupleScheme(); } } private static class deleteAllRow_argsTupleScheme extends TupleScheme<deleteAllRow_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, deleteAllRow_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } if (struct.isSetRow()) { optionals.set(1); } if (struct.isSetAttributes()) { optionals.set(2); } oprot.writeBitSet(optionals, 3); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } if (struct.isSetRow()) { oprot.writeBinary(struct.row); } if (struct.isSetAttributes()) { { oprot.writeI32(struct.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> _iter443 : struct.attributes.entrySet()) { oprot.writeBinary(_iter443.getKey()); oprot.writeBinary(_iter443.getValue()); } } } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, deleteAllRow_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(3); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } if (incoming.get(1)) { struct.row = iprot.readBinary(); struct.setRowIsSet(true); } if (incoming.get(2)) { { org.apache.thrift.protocol.TMap _map444 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map444.size); ByteBuffer _key445; ByteBuffer _val446; for (int _i447 = 0; _i447 < _map444.size; ++_i447) { _key445 = iprot.readBinary(); _val446 = iprot.readBinary(); struct.attributes.put(_key445, _val446); } } struct.setAttributesIsSet(true); } } } } public static class deleteAllRow_result implements org.apache.thrift.TBase<deleteAllRow_result, deleteAllRow_result._Fields>, java.io.Serializable, Cloneable, Comparable<deleteAllRow_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("deleteAllRow_result"); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new deleteAllRow_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new deleteAllRow_resultTupleSchemeFactory()); } public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(deleteAllRow_result.class, metaDataMap); } public deleteAllRow_result() { } public deleteAllRow_result( IOError io) { this(); this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public deleteAllRow_result(deleteAllRow_result other) { if (other.isSetIo()) { this.io = new IOError(other.io); } } public deleteAllRow_result deepCopy() { return new deleteAllRow_result(this); } @Override public void clear() { this.io = null; } public IOError getIo() { return this.io; } public deleteAllRow_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof deleteAllRow_result) return this.equals((deleteAllRow_result)that); return false; } public boolean equals(deleteAllRow_result that) { if (that == null) return false; boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(deleteAllRow_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("deleteAllRow_result("); boolean first = true; sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class deleteAllRow_resultStandardSchemeFactory implements SchemeFactory { public deleteAllRow_resultStandardScheme getScheme() { return new deleteAllRow_resultStandardScheme(); } } private static class deleteAllRow_resultStandardScheme extends StandardScheme<deleteAllRow_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, deleteAllRow_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, deleteAllRow_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class deleteAllRow_resultTupleSchemeFactory implements SchemeFactory { public deleteAllRow_resultTupleScheme getScheme() { return new deleteAllRow_resultTupleScheme(); } } private static class deleteAllRow_resultTupleScheme extends TupleScheme<deleteAllRow_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, deleteAllRow_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetIo()) { optionals.set(0); } oprot.writeBitSet(optionals, 1); if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, deleteAllRow_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(1); if (incoming.get(0)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class increment_args implements org.apache.thrift.TBase<increment_args, increment_args._Fields>, java.io.Serializable, Cloneable, Comparable<increment_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("increment_args"); private static final org.apache.thrift.protocol.TField INCREMENT_FIELD_DESC = new org.apache.thrift.protocol.TField("increment", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new increment_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new increment_argsTupleSchemeFactory()); } /** * The single increment to apply */ public TIncrement increment; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * The single increment to apply */ INCREMENT((short)1, "increment"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // INCREMENT return INCREMENT; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.INCREMENT, new org.apache.thrift.meta_data.FieldMetaData("increment", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, TIncrement.class))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(increment_args.class, metaDataMap); } public increment_args() { } public increment_args( TIncrement increment) { this(); this.increment = increment; } /** * Performs a deep copy on <i>other</i>. */ public increment_args(increment_args other) { if (other.isSetIncrement()) { this.increment = new TIncrement(other.increment); } } public increment_args deepCopy() { return new increment_args(this); } @Override public void clear() { this.increment = null; } /** * The single increment to apply */ public TIncrement getIncrement() { return this.increment; } /** * The single increment to apply */ public increment_args setIncrement(TIncrement increment) { this.increment = increment; return this; } public void unsetIncrement() { this.increment = null; } /** Returns true if field increment is set (has been assigned a value) and false otherwise */ public boolean isSetIncrement() { return this.increment != null; } public void setIncrementIsSet(boolean value) { if (!value) { this.increment = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case INCREMENT: if (value == null) { unsetIncrement(); } else { setIncrement((TIncrement)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case INCREMENT: return getIncrement(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case INCREMENT: return isSetIncrement(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof increment_args) return this.equals((increment_args)that); return false; } public boolean equals(increment_args that) { if (that == null) return false; boolean this_present_increment = true && this.isSetIncrement(); boolean that_present_increment = true && that.isSetIncrement(); if (this_present_increment || that_present_increment) { if (!(this_present_increment && that_present_increment)) return false; if (!this.increment.equals(that.increment)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_increment = true && (isSetIncrement()); list.add(present_increment); if (present_increment) list.add(increment); return list.hashCode(); } @Override public int compareTo(increment_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetIncrement()).compareTo(other.isSetIncrement()); if (lastComparison != 0) { return lastComparison; } if (isSetIncrement()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.increment, other.increment); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("increment_args("); boolean first = true; sb.append("increment:"); if (this.increment == null) { sb.append("null"); } else { sb.append(this.increment); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity if (increment != null) { increment.validate(); } } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class increment_argsStandardSchemeFactory implements SchemeFactory { public increment_argsStandardScheme getScheme() { return new increment_argsStandardScheme(); } } private static class increment_argsStandardScheme extends StandardScheme<increment_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, increment_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // INCREMENT if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.increment = new TIncrement(); struct.increment.read(iprot); struct.setIncrementIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, increment_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.increment != null) { oprot.writeFieldBegin(INCREMENT_FIELD_DESC); struct.increment.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class increment_argsTupleSchemeFactory implements SchemeFactory { public increment_argsTupleScheme getScheme() { return new increment_argsTupleScheme(); } } private static class increment_argsTupleScheme extends TupleScheme<increment_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, increment_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetIncrement()) { optionals.set(0); } oprot.writeBitSet(optionals, 1); if (struct.isSetIncrement()) { struct.increment.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, increment_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(1); if (incoming.get(0)) { struct.increment = new TIncrement(); struct.increment.read(iprot); struct.setIncrementIsSet(true); } } } } public static class increment_result implements org.apache.thrift.TBase<increment_result, increment_result._Fields>, java.io.Serializable, Cloneable, Comparable<increment_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("increment_result"); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new increment_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new increment_resultTupleSchemeFactory()); } public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(increment_result.class, metaDataMap); } public increment_result() { } public increment_result( IOError io) { this(); this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public increment_result(increment_result other) { if (other.isSetIo()) { this.io = new IOError(other.io); } } public increment_result deepCopy() { return new increment_result(this); } @Override public void clear() { this.io = null; } public IOError getIo() { return this.io; } public increment_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof increment_result) return this.equals((increment_result)that); return false; } public boolean equals(increment_result that) { if (that == null) return false; boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(increment_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("increment_result("); boolean first = true; sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class increment_resultStandardSchemeFactory implements SchemeFactory { public increment_resultStandardScheme getScheme() { return new increment_resultStandardScheme(); } } private static class increment_resultStandardScheme extends StandardScheme<increment_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, increment_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, increment_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class increment_resultTupleSchemeFactory implements SchemeFactory { public increment_resultTupleScheme getScheme() { return new increment_resultTupleScheme(); } } private static class increment_resultTupleScheme extends TupleScheme<increment_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, increment_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetIo()) { optionals.set(0); } oprot.writeBitSet(optionals, 1); if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, increment_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(1); if (incoming.get(0)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class incrementRows_args implements org.apache.thrift.TBase<incrementRows_args, incrementRows_args._Fields>, java.io.Serializable, Cloneable, Comparable<incrementRows_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("incrementRows_args"); private static final org.apache.thrift.protocol.TField INCREMENTS_FIELD_DESC = new org.apache.thrift.protocol.TField("increments", org.apache.thrift.protocol.TType.LIST, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new incrementRows_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new incrementRows_argsTupleSchemeFactory()); } /** * The list of increments */ public List<TIncrement> increments; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * The list of increments */ INCREMENTS((short)1, "increments"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // INCREMENTS return INCREMENTS; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.INCREMENTS, new org.apache.thrift.meta_data.FieldMetaData("increments", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, TIncrement.class)))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(incrementRows_args.class, metaDataMap); } public incrementRows_args() { } public incrementRows_args( List<TIncrement> increments) { this(); this.increments = increments; } /** * Performs a deep copy on <i>other</i>. */ public incrementRows_args(incrementRows_args other) { if (other.isSetIncrements()) { List<TIncrement> __this__increments = new ArrayList<TIncrement>(other.increments.size()); for (TIncrement other_element : other.increments) { __this__increments.add(new TIncrement(other_element)); } this.increments = __this__increments; } } public incrementRows_args deepCopy() { return new incrementRows_args(this); } @Override public void clear() { this.increments = null; } public int getIncrementsSize() { return (this.increments == null) ? 0 : this.increments.size(); } public java.util.Iterator<TIncrement> getIncrementsIterator() { return (this.increments == null) ? null : this.increments.iterator(); } public void addToIncrements(TIncrement elem) { if (this.increments == null) { this.increments = new ArrayList<TIncrement>(); } this.increments.add(elem); } /** * The list of increments */ public List<TIncrement> getIncrements() { return this.increments; } /** * The list of increments */ public incrementRows_args setIncrements(List<TIncrement> increments) { this.increments = increments; return this; } public void unsetIncrements() { this.increments = null; } /** Returns true if field increments is set (has been assigned a value) and false otherwise */ public boolean isSetIncrements() { return this.increments != null; } public void setIncrementsIsSet(boolean value) { if (!value) { this.increments = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case INCREMENTS: if (value == null) { unsetIncrements(); } else { setIncrements((List<TIncrement>)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case INCREMENTS: return getIncrements(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case INCREMENTS: return isSetIncrements(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof incrementRows_args) return this.equals((incrementRows_args)that); return false; } public boolean equals(incrementRows_args that) { if (that == null) return false; boolean this_present_increments = true && this.isSetIncrements(); boolean that_present_increments = true && that.isSetIncrements(); if (this_present_increments || that_present_increments) { if (!(this_present_increments && that_present_increments)) return false; if (!this.increments.equals(that.increments)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_increments = true && (isSetIncrements()); list.add(present_increments); if (present_increments) list.add(increments); return list.hashCode(); } @Override public int compareTo(incrementRows_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetIncrements()).compareTo(other.isSetIncrements()); if (lastComparison != 0) { return lastComparison; } if (isSetIncrements()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.increments, other.increments); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("incrementRows_args("); boolean first = true; sb.append("increments:"); if (this.increments == null) { sb.append("null"); } else { sb.append(this.increments); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class incrementRows_argsStandardSchemeFactory implements SchemeFactory { public incrementRows_argsStandardScheme getScheme() { return new incrementRows_argsStandardScheme(); } } private static class incrementRows_argsStandardScheme extends StandardScheme<incrementRows_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, incrementRows_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // INCREMENTS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list448 = iprot.readListBegin(); struct.increments = new ArrayList<TIncrement>(_list448.size); TIncrement _elem449; for (int _i450 = 0; _i450 < _list448.size; ++_i450) { _elem449 = new TIncrement(); _elem449.read(iprot); struct.increments.add(_elem449); } iprot.readListEnd(); } struct.setIncrementsIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, incrementRows_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.increments != null) { oprot.writeFieldBegin(INCREMENTS_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.increments.size())); for (TIncrement _iter451 : struct.increments) { _iter451.write(oprot); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class incrementRows_argsTupleSchemeFactory implements SchemeFactory { public incrementRows_argsTupleScheme getScheme() { return new incrementRows_argsTupleScheme(); } } private static class incrementRows_argsTupleScheme extends TupleScheme<incrementRows_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, incrementRows_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetIncrements()) { optionals.set(0); } oprot.writeBitSet(optionals, 1); if (struct.isSetIncrements()) { { oprot.writeI32(struct.increments.size()); for (TIncrement _iter452 : struct.increments) { _iter452.write(oprot); } } } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, incrementRows_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(1); if (incoming.get(0)) { { org.apache.thrift.protocol.TList _list453 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32()); struct.increments = new ArrayList<TIncrement>(_list453.size); TIncrement _elem454; for (int _i455 = 0; _i455 < _list453.size; ++_i455) { _elem454 = new TIncrement(); _elem454.read(iprot); struct.increments.add(_elem454); } } struct.setIncrementsIsSet(true); } } } } public static class incrementRows_result implements org.apache.thrift.TBase<incrementRows_result, incrementRows_result._Fields>, java.io.Serializable, Cloneable, Comparable<incrementRows_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("incrementRows_result"); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new incrementRows_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new incrementRows_resultTupleSchemeFactory()); } public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(incrementRows_result.class, metaDataMap); } public incrementRows_result() { } public incrementRows_result( IOError io) { this(); this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public incrementRows_result(incrementRows_result other) { if (other.isSetIo()) { this.io = new IOError(other.io); } } public incrementRows_result deepCopy() { return new incrementRows_result(this); } @Override public void clear() { this.io = null; } public IOError getIo() { return this.io; } public incrementRows_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof incrementRows_result) return this.equals((incrementRows_result)that); return false; } public boolean equals(incrementRows_result that) { if (that == null) return false; boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(incrementRows_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("incrementRows_result("); boolean first = true; sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class incrementRows_resultStandardSchemeFactory implements SchemeFactory { public incrementRows_resultStandardScheme getScheme() { return new incrementRows_resultStandardScheme(); } } private static class incrementRows_resultStandardScheme extends StandardScheme<incrementRows_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, incrementRows_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, incrementRows_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class incrementRows_resultTupleSchemeFactory implements SchemeFactory { public incrementRows_resultTupleScheme getScheme() { return new incrementRows_resultTupleScheme(); } } private static class incrementRows_resultTupleScheme extends TupleScheme<incrementRows_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, incrementRows_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetIo()) { optionals.set(0); } oprot.writeBitSet(optionals, 1); if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, incrementRows_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(1); if (incoming.get(0)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class deleteAllRowTs_args implements org.apache.thrift.TBase<deleteAllRowTs_args, deleteAllRowTs_args._Fields>, java.io.Serializable, Cloneable, Comparable<deleteAllRowTs_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("deleteAllRowTs_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final org.apache.thrift.protocol.TField ROW_FIELD_DESC = new org.apache.thrift.protocol.TField("row", org.apache.thrift.protocol.TType.STRING, (short)2); private static final org.apache.thrift.protocol.TField TIMESTAMP_FIELD_DESC = new org.apache.thrift.protocol.TField("timestamp", org.apache.thrift.protocol.TType.I64, (short)3); private static final org.apache.thrift.protocol.TField ATTRIBUTES_FIELD_DESC = new org.apache.thrift.protocol.TField("attributes", org.apache.thrift.protocol.TType.MAP, (short)4); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new deleteAllRowTs_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new deleteAllRowTs_argsTupleSchemeFactory()); } /** * name of table */ public ByteBuffer tableName; // required /** * key of the row to be completely deleted. */ public ByteBuffer row; // required /** * timestamp */ public long timestamp; // required /** * Delete attributes */ public Map<ByteBuffer,ByteBuffer> attributes; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * name of table */ TABLE_NAME((short)1, "tableName"), /** * key of the row to be completely deleted. */ ROW((short)2, "row"), /** * timestamp */ TIMESTAMP((short)3, "timestamp"), /** * Delete attributes */ ATTRIBUTES((short)4, "attributes"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; case 2: // ROW return ROW; case 3: // TIMESTAMP return TIMESTAMP; case 4: // ATTRIBUTES return ATTRIBUTES; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments private static final int __TIMESTAMP_ISSET_ID = 0; private byte __isset_bitfield = 0; public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.ROW, new org.apache.thrift.meta_data.FieldMetaData("row", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.TIMESTAMP, new org.apache.thrift.meta_data.FieldMetaData("timestamp", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.I64))); tmpMap.put(_Fields.ATTRIBUTES, new org.apache.thrift.meta_data.FieldMetaData("attributes", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.MapMetaData(org.apache.thrift.protocol.TType.MAP, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"), new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(deleteAllRowTs_args.class, metaDataMap); } public deleteAllRowTs_args() { } public deleteAllRowTs_args( ByteBuffer tableName, ByteBuffer row, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); this.row = org.apache.thrift.TBaseHelper.copyBinary(row); this.timestamp = timestamp; setTimestampIsSet(true); this.attributes = attributes; } /** * Performs a deep copy on <i>other</i>. */ public deleteAllRowTs_args(deleteAllRowTs_args other) { __isset_bitfield = other.__isset_bitfield; if (other.isSetTableName()) { this.tableName = other.tableName; } if (other.isSetRow()) { this.row = other.row; } this.timestamp = other.timestamp; if (other.isSetAttributes()) { Map<ByteBuffer,ByteBuffer> __this__attributes = new HashMap<ByteBuffer,ByteBuffer>(other.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> other_element : other.attributes.entrySet()) { ByteBuffer other_element_key = other_element.getKey(); ByteBuffer other_element_value = other_element.getValue(); ByteBuffer __this__attributes_copy_key = other_element_key; ByteBuffer __this__attributes_copy_value = other_element_value; __this__attributes.put(__this__attributes_copy_key, __this__attributes_copy_value); } this.attributes = __this__attributes; } } public deleteAllRowTs_args deepCopy() { return new deleteAllRowTs_args(this); } @Override public void clear() { this.tableName = null; this.row = null; setTimestampIsSet(false); this.timestamp = 0; this.attributes = null; } /** * name of table */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * name of table */ public deleteAllRowTs_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public deleteAllRowTs_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } /** * key of the row to be completely deleted. */ public byte[] getRow() { setRow(org.apache.thrift.TBaseHelper.rightSize(row)); return row == null ? null : row.array(); } public ByteBuffer bufferForRow() { return org.apache.thrift.TBaseHelper.copyBinary(row); } /** * key of the row to be completely deleted. */ public deleteAllRowTs_args setRow(byte[] row) { this.row = row == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(row, row.length)); return this; } public deleteAllRowTs_args setRow(ByteBuffer row) { this.row = org.apache.thrift.TBaseHelper.copyBinary(row); return this; } public void unsetRow() { this.row = null; } /** Returns true if field row is set (has been assigned a value) and false otherwise */ public boolean isSetRow() { return this.row != null; } public void setRowIsSet(boolean value) { if (!value) { this.row = null; } } /** * timestamp */ public long getTimestamp() { return this.timestamp; } /** * timestamp */ public deleteAllRowTs_args setTimestamp(long timestamp) { this.timestamp = timestamp; setTimestampIsSet(true); return this; } public void unsetTimestamp() { __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __TIMESTAMP_ISSET_ID); } /** Returns true if field timestamp is set (has been assigned a value) and false otherwise */ public boolean isSetTimestamp() { return EncodingUtils.testBit(__isset_bitfield, __TIMESTAMP_ISSET_ID); } public void setTimestampIsSet(boolean value) { __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __TIMESTAMP_ISSET_ID, value); } public int getAttributesSize() { return (this.attributes == null) ? 0 : this.attributes.size(); } public void putToAttributes(ByteBuffer key, ByteBuffer val) { if (this.attributes == null) { this.attributes = new HashMap<ByteBuffer,ByteBuffer>(); } this.attributes.put(key, val); } /** * Delete attributes */ public Map<ByteBuffer,ByteBuffer> getAttributes() { return this.attributes; } /** * Delete attributes */ public deleteAllRowTs_args setAttributes(Map<ByteBuffer,ByteBuffer> attributes) { this.attributes = attributes; return this; } public void unsetAttributes() { this.attributes = null; } /** Returns true if field attributes is set (has been assigned a value) and false otherwise */ public boolean isSetAttributes() { return this.attributes != null; } public void setAttributesIsSet(boolean value) { if (!value) { this.attributes = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; case ROW: if (value == null) { unsetRow(); } else { setRow((ByteBuffer)value); } break; case TIMESTAMP: if (value == null) { unsetTimestamp(); } else { setTimestamp((Long)value); } break; case ATTRIBUTES: if (value == null) { unsetAttributes(); } else { setAttributes((Map<ByteBuffer,ByteBuffer>)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); case ROW: return getRow(); case TIMESTAMP: return getTimestamp(); case ATTRIBUTES: return getAttributes(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); case ROW: return isSetRow(); case TIMESTAMP: return isSetTimestamp(); case ATTRIBUTES: return isSetAttributes(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof deleteAllRowTs_args) return this.equals((deleteAllRowTs_args)that); return false; } public boolean equals(deleteAllRowTs_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } boolean this_present_row = true && this.isSetRow(); boolean that_present_row = true && that.isSetRow(); if (this_present_row || that_present_row) { if (!(this_present_row && that_present_row)) return false; if (!this.row.equals(that.row)) return false; } boolean this_present_timestamp = true; boolean that_present_timestamp = true; if (this_present_timestamp || that_present_timestamp) { if (!(this_present_timestamp && that_present_timestamp)) return false; if (this.timestamp != that.timestamp) return false; } boolean this_present_attributes = true && this.isSetAttributes(); boolean that_present_attributes = true && that.isSetAttributes(); if (this_present_attributes || that_present_attributes) { if (!(this_present_attributes && that_present_attributes)) return false; if (!this.attributes.equals(that.attributes)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); boolean present_row = true && (isSetRow()); list.add(present_row); if (present_row) list.add(row); boolean present_timestamp = true; list.add(present_timestamp); if (present_timestamp) list.add(timestamp); boolean present_attributes = true && (isSetAttributes()); list.add(present_attributes); if (present_attributes) list.add(attributes); return list.hashCode(); } @Override public int compareTo(deleteAllRowTs_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetRow()).compareTo(other.isSetRow()); if (lastComparison != 0) { return lastComparison; } if (isSetRow()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.row, other.row); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetTimestamp()).compareTo(other.isSetTimestamp()); if (lastComparison != 0) { return lastComparison; } if (isSetTimestamp()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.timestamp, other.timestamp); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetAttributes()).compareTo(other.isSetAttributes()); if (lastComparison != 0) { return lastComparison; } if (isSetAttributes()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.attributes, other.attributes); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("deleteAllRowTs_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; if (!first) sb.append(", "); sb.append("row:"); if (this.row == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.row, sb); } first = false; if (!first) sb.append(", "); sb.append("timestamp:"); sb.append(this.timestamp); first = false; if (!first) sb.append(", "); sb.append("attributes:"); if (this.attributes == null) { sb.append("null"); } else { sb.append(this.attributes); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { // it doesn't seem like you should have to do this, but java serialization is wacky, and doesn't call the default constructor. __isset_bitfield = 0; read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class deleteAllRowTs_argsStandardSchemeFactory implements SchemeFactory { public deleteAllRowTs_argsStandardScheme getScheme() { return new deleteAllRowTs_argsStandardScheme(); } } private static class deleteAllRowTs_argsStandardScheme extends StandardScheme<deleteAllRowTs_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, deleteAllRowTs_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // ROW if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.row = iprot.readBinary(); struct.setRowIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 3: // TIMESTAMP if (schemeField.type == org.apache.thrift.protocol.TType.I64) { struct.timestamp = iprot.readI64(); struct.setTimestampIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 4: // ATTRIBUTES if (schemeField.type == org.apache.thrift.protocol.TType.MAP) { { org.apache.thrift.protocol.TMap _map456 = iprot.readMapBegin(); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map456.size); ByteBuffer _key457; ByteBuffer _val458; for (int _i459 = 0; _i459 < _map456.size; ++_i459) { _key457 = iprot.readBinary(); _val458 = iprot.readBinary(); struct.attributes.put(_key457, _val458); } iprot.readMapEnd(); } struct.setAttributesIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, deleteAllRowTs_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } if (struct.row != null) { oprot.writeFieldBegin(ROW_FIELD_DESC); oprot.writeBinary(struct.row); oprot.writeFieldEnd(); } oprot.writeFieldBegin(TIMESTAMP_FIELD_DESC); oprot.writeI64(struct.timestamp); oprot.writeFieldEnd(); if (struct.attributes != null) { oprot.writeFieldBegin(ATTRIBUTES_FIELD_DESC); { oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, struct.attributes.size())); for (Map.Entry<ByteBuffer, ByteBuffer> _iter460 : struct.attributes.entrySet()) { oprot.writeBinary(_iter460.getKey()); oprot.writeBinary(_iter460.getValue()); } oprot.writeMapEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class deleteAllRowTs_argsTupleSchemeFactory implements SchemeFactory { public deleteAllRowTs_argsTupleScheme getScheme() { return new deleteAllRowTs_argsTupleScheme(); } } private static class deleteAllRowTs_argsTupleScheme extends TupleScheme<deleteAllRowTs_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, deleteAllRowTs_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } if (struct.isSetRow()) { optionals.set(1); } if (struct.isSetTimestamp()) { optionals.set(2); } if (struct.isSetAttributes()) { optionals.set(3); } oprot.writeBitSet(optionals, 4); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } if (struct.isSetRow()) { oprot.writeBinary(struct.row); } if (struct.isSetTimestamp()) { oprot.writeI64(struct.timestamp); } if (struct.isSetAttributes()) { { oprot.writeI32(struct.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> _iter461 : struct.attributes.entrySet()) { oprot.writeBinary(_iter461.getKey()); oprot.writeBinary(_iter461.getValue()); } } } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, deleteAllRowTs_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(4); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } if (incoming.get(1)) { struct.row = iprot.readBinary(); struct.setRowIsSet(true); } if (incoming.get(2)) { struct.timestamp = iprot.readI64(); struct.setTimestampIsSet(true); } if (incoming.get(3)) { { org.apache.thrift.protocol.TMap _map462 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map462.size); ByteBuffer _key463; ByteBuffer _val464; for (int _i465 = 0; _i465 < _map462.size; ++_i465) { _key463 = iprot.readBinary(); _val464 = iprot.readBinary(); struct.attributes.put(_key463, _val464); } } struct.setAttributesIsSet(true); } } } } public static class deleteAllRowTs_result implements org.apache.thrift.TBase<deleteAllRowTs_result, deleteAllRowTs_result._Fields>, java.io.Serializable, Cloneable, Comparable<deleteAllRowTs_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("deleteAllRowTs_result"); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new deleteAllRowTs_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new deleteAllRowTs_resultTupleSchemeFactory()); } public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(deleteAllRowTs_result.class, metaDataMap); } public deleteAllRowTs_result() { } public deleteAllRowTs_result( IOError io) { this(); this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public deleteAllRowTs_result(deleteAllRowTs_result other) { if (other.isSetIo()) { this.io = new IOError(other.io); } } public deleteAllRowTs_result deepCopy() { return new deleteAllRowTs_result(this); } @Override public void clear() { this.io = null; } public IOError getIo() { return this.io; } public deleteAllRowTs_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof deleteAllRowTs_result) return this.equals((deleteAllRowTs_result)that); return false; } public boolean equals(deleteAllRowTs_result that) { if (that == null) return false; boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(deleteAllRowTs_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("deleteAllRowTs_result("); boolean first = true; sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class deleteAllRowTs_resultStandardSchemeFactory implements SchemeFactory { public deleteAllRowTs_resultStandardScheme getScheme() { return new deleteAllRowTs_resultStandardScheme(); } } private static class deleteAllRowTs_resultStandardScheme extends StandardScheme<deleteAllRowTs_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, deleteAllRowTs_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, deleteAllRowTs_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class deleteAllRowTs_resultTupleSchemeFactory implements SchemeFactory { public deleteAllRowTs_resultTupleScheme getScheme() { return new deleteAllRowTs_resultTupleScheme(); } } private static class deleteAllRowTs_resultTupleScheme extends TupleScheme<deleteAllRowTs_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, deleteAllRowTs_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetIo()) { optionals.set(0); } oprot.writeBitSet(optionals, 1); if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, deleteAllRowTs_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(1); if (incoming.get(0)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class scannerOpenWithScan_args implements org.apache.thrift.TBase<scannerOpenWithScan_args, scannerOpenWithScan_args._Fields>, java.io.Serializable, Cloneable, Comparable<scannerOpenWithScan_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("scannerOpenWithScan_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final org.apache.thrift.protocol.TField SCAN_FIELD_DESC = new org.apache.thrift.protocol.TField("scan", org.apache.thrift.protocol.TType.STRUCT, (short)2); private static final org.apache.thrift.protocol.TField ATTRIBUTES_FIELD_DESC = new org.apache.thrift.protocol.TField("attributes", org.apache.thrift.protocol.TType.MAP, (short)3); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new scannerOpenWithScan_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new scannerOpenWithScan_argsTupleSchemeFactory()); } /** * name of table */ public ByteBuffer tableName; // required /** * Scan instance */ public TScan scan; // required /** * Scan attributes */ public Map<ByteBuffer,ByteBuffer> attributes; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * name of table */ TABLE_NAME((short)1, "tableName"), /** * Scan instance */ SCAN((short)2, "scan"), /** * Scan attributes */ ATTRIBUTES((short)3, "attributes"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; case 2: // SCAN return SCAN; case 3: // ATTRIBUTES return ATTRIBUTES; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.SCAN, new org.apache.thrift.meta_data.FieldMetaData("scan", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, TScan.class))); tmpMap.put(_Fields.ATTRIBUTES, new org.apache.thrift.meta_data.FieldMetaData("attributes", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.MapMetaData(org.apache.thrift.protocol.TType.MAP, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"), new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(scannerOpenWithScan_args.class, metaDataMap); } public scannerOpenWithScan_args() { } public scannerOpenWithScan_args( ByteBuffer tableName, TScan scan, Map<ByteBuffer,ByteBuffer> attributes) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); this.scan = scan; this.attributes = attributes; } /** * Performs a deep copy on <i>other</i>. */ public scannerOpenWithScan_args(scannerOpenWithScan_args other) { if (other.isSetTableName()) { this.tableName = other.tableName; } if (other.isSetScan()) { this.scan = new TScan(other.scan); } if (other.isSetAttributes()) { Map<ByteBuffer,ByteBuffer> __this__attributes = new HashMap<ByteBuffer,ByteBuffer>(other.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> other_element : other.attributes.entrySet()) { ByteBuffer other_element_key = other_element.getKey(); ByteBuffer other_element_value = other_element.getValue(); ByteBuffer __this__attributes_copy_key = other_element_key; ByteBuffer __this__attributes_copy_value = other_element_value; __this__attributes.put(__this__attributes_copy_key, __this__attributes_copy_value); } this.attributes = __this__attributes; } } public scannerOpenWithScan_args deepCopy() { return new scannerOpenWithScan_args(this); } @Override public void clear() { this.tableName = null; this.scan = null; this.attributes = null; } /** * name of table */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * name of table */ public scannerOpenWithScan_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public scannerOpenWithScan_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } /** * Scan instance */ public TScan getScan() { return this.scan; } /** * Scan instance */ public scannerOpenWithScan_args setScan(TScan scan) { this.scan = scan; return this; } public void unsetScan() { this.scan = null; } /** Returns true if field scan is set (has been assigned a value) and false otherwise */ public boolean isSetScan() { return this.scan != null; } public void setScanIsSet(boolean value) { if (!value) { this.scan = null; } } public int getAttributesSize() { return (this.attributes == null) ? 0 : this.attributes.size(); } public void putToAttributes(ByteBuffer key, ByteBuffer val) { if (this.attributes == null) { this.attributes = new HashMap<ByteBuffer,ByteBuffer>(); } this.attributes.put(key, val); } /** * Scan attributes */ public Map<ByteBuffer,ByteBuffer> getAttributes() { return this.attributes; } /** * Scan attributes */ public scannerOpenWithScan_args setAttributes(Map<ByteBuffer,ByteBuffer> attributes) { this.attributes = attributes; return this; } public void unsetAttributes() { this.attributes = null; } /** Returns true if field attributes is set (has been assigned a value) and false otherwise */ public boolean isSetAttributes() { return this.attributes != null; } public void setAttributesIsSet(boolean value) { if (!value) { this.attributes = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; case SCAN: if (value == null) { unsetScan(); } else { setScan((TScan)value); } break; case ATTRIBUTES: if (value == null) { unsetAttributes(); } else { setAttributes((Map<ByteBuffer,ByteBuffer>)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); case SCAN: return getScan(); case ATTRIBUTES: return getAttributes(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); case SCAN: return isSetScan(); case ATTRIBUTES: return isSetAttributes(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof scannerOpenWithScan_args) return this.equals((scannerOpenWithScan_args)that); return false; } public boolean equals(scannerOpenWithScan_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } boolean this_present_scan = true && this.isSetScan(); boolean that_present_scan = true && that.isSetScan(); if (this_present_scan || that_present_scan) { if (!(this_present_scan && that_present_scan)) return false; if (!this.scan.equals(that.scan)) return false; } boolean this_present_attributes = true && this.isSetAttributes(); boolean that_present_attributes = true && that.isSetAttributes(); if (this_present_attributes || that_present_attributes) { if (!(this_present_attributes && that_present_attributes)) return false; if (!this.attributes.equals(that.attributes)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); boolean present_scan = true && (isSetScan()); list.add(present_scan); if (present_scan) list.add(scan); boolean present_attributes = true && (isSetAttributes()); list.add(present_attributes); if (present_attributes) list.add(attributes); return list.hashCode(); } @Override public int compareTo(scannerOpenWithScan_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetScan()).compareTo(other.isSetScan()); if (lastComparison != 0) { return lastComparison; } if (isSetScan()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.scan, other.scan); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetAttributes()).compareTo(other.isSetAttributes()); if (lastComparison != 0) { return lastComparison; } if (isSetAttributes()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.attributes, other.attributes); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("scannerOpenWithScan_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; if (!first) sb.append(", "); sb.append("scan:"); if (this.scan == null) { sb.append("null"); } else { sb.append(this.scan); } first = false; if (!first) sb.append(", "); sb.append("attributes:"); if (this.attributes == null) { sb.append("null"); } else { sb.append(this.attributes); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity if (scan != null) { scan.validate(); } } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class scannerOpenWithScan_argsStandardSchemeFactory implements SchemeFactory { public scannerOpenWithScan_argsStandardScheme getScheme() { return new scannerOpenWithScan_argsStandardScheme(); } } private static class scannerOpenWithScan_argsStandardScheme extends StandardScheme<scannerOpenWithScan_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, scannerOpenWithScan_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // SCAN if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.scan = new TScan(); struct.scan.read(iprot); struct.setScanIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 3: // ATTRIBUTES if (schemeField.type == org.apache.thrift.protocol.TType.MAP) { { org.apache.thrift.protocol.TMap _map466 = iprot.readMapBegin(); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map466.size); ByteBuffer _key467; ByteBuffer _val468; for (int _i469 = 0; _i469 < _map466.size; ++_i469) { _key467 = iprot.readBinary(); _val468 = iprot.readBinary(); struct.attributes.put(_key467, _val468); } iprot.readMapEnd(); } struct.setAttributesIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, scannerOpenWithScan_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } if (struct.scan != null) { oprot.writeFieldBegin(SCAN_FIELD_DESC); struct.scan.write(oprot); oprot.writeFieldEnd(); } if (struct.attributes != null) { oprot.writeFieldBegin(ATTRIBUTES_FIELD_DESC); { oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, struct.attributes.size())); for (Map.Entry<ByteBuffer, ByteBuffer> _iter470 : struct.attributes.entrySet()) { oprot.writeBinary(_iter470.getKey()); oprot.writeBinary(_iter470.getValue()); } oprot.writeMapEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class scannerOpenWithScan_argsTupleSchemeFactory implements SchemeFactory { public scannerOpenWithScan_argsTupleScheme getScheme() { return new scannerOpenWithScan_argsTupleScheme(); } } private static class scannerOpenWithScan_argsTupleScheme extends TupleScheme<scannerOpenWithScan_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, scannerOpenWithScan_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } if (struct.isSetScan()) { optionals.set(1); } if (struct.isSetAttributes()) { optionals.set(2); } oprot.writeBitSet(optionals, 3); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } if (struct.isSetScan()) { struct.scan.write(oprot); } if (struct.isSetAttributes()) { { oprot.writeI32(struct.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> _iter471 : struct.attributes.entrySet()) { oprot.writeBinary(_iter471.getKey()); oprot.writeBinary(_iter471.getValue()); } } } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, scannerOpenWithScan_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(3); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } if (incoming.get(1)) { struct.scan = new TScan(); struct.scan.read(iprot); struct.setScanIsSet(true); } if (incoming.get(2)) { { org.apache.thrift.protocol.TMap _map472 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map472.size); ByteBuffer _key473; ByteBuffer _val474; for (int _i475 = 0; _i475 < _map472.size; ++_i475) { _key473 = iprot.readBinary(); _val474 = iprot.readBinary(); struct.attributes.put(_key473, _val474); } } struct.setAttributesIsSet(true); } } } } public static class scannerOpenWithScan_result implements org.apache.thrift.TBase<scannerOpenWithScan_result, scannerOpenWithScan_result._Fields>, java.io.Serializable, Cloneable, Comparable<scannerOpenWithScan_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("scannerOpenWithScan_result"); private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.I32, (short)0); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new scannerOpenWithScan_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new scannerOpenWithScan_resultTupleSchemeFactory()); } public int success; // required public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { SUCCESS((short)0, "success"), IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 0: // SUCCESS return SUCCESS; case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments private static final int __SUCCESS_ISSET_ID = 0; private byte __isset_bitfield = 0; public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.SUCCESS, new org.apache.thrift.meta_data.FieldMetaData("success", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.I32 , "ScannerID"))); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(scannerOpenWithScan_result.class, metaDataMap); } public scannerOpenWithScan_result() { } public scannerOpenWithScan_result( int success, IOError io) { this(); this.success = success; setSuccessIsSet(true); this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public scannerOpenWithScan_result(scannerOpenWithScan_result other) { __isset_bitfield = other.__isset_bitfield; this.success = other.success; if (other.isSetIo()) { this.io = new IOError(other.io); } } public scannerOpenWithScan_result deepCopy() { return new scannerOpenWithScan_result(this); } @Override public void clear() { setSuccessIsSet(false); this.success = 0; this.io = null; } public int getSuccess() { return this.success; } public scannerOpenWithScan_result setSuccess(int success) { this.success = success; setSuccessIsSet(true); return this; } public void unsetSuccess() { __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __SUCCESS_ISSET_ID); } /** Returns true if field success is set (has been assigned a value) and false otherwise */ public boolean isSetSuccess() { return EncodingUtils.testBit(__isset_bitfield, __SUCCESS_ISSET_ID); } public void setSuccessIsSet(boolean value) { __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __SUCCESS_ISSET_ID, value); } public IOError getIo() { return this.io; } public scannerOpenWithScan_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case SUCCESS: if (value == null) { unsetSuccess(); } else { setSuccess((Integer)value); } break; case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case SUCCESS: return getSuccess(); case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case SUCCESS: return isSetSuccess(); case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof scannerOpenWithScan_result) return this.equals((scannerOpenWithScan_result)that); return false; } public boolean equals(scannerOpenWithScan_result that) { if (that == null) return false; boolean this_present_success = true; boolean that_present_success = true; if (this_present_success || that_present_success) { if (!(this_present_success && that_present_success)) return false; if (this.success != that.success) return false; } boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_success = true; list.add(present_success); if (present_success) list.add(success); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(scannerOpenWithScan_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess()); if (lastComparison != 0) { return lastComparison; } if (isSetSuccess()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("scannerOpenWithScan_result("); boolean first = true; sb.append("success:"); sb.append(this.success); first = false; if (!first) sb.append(", "); sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { // it doesn't seem like you should have to do this, but java serialization is wacky, and doesn't call the default constructor. __isset_bitfield = 0; read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class scannerOpenWithScan_resultStandardSchemeFactory implements SchemeFactory { public scannerOpenWithScan_resultStandardScheme getScheme() { return new scannerOpenWithScan_resultStandardScheme(); } } private static class scannerOpenWithScan_resultStandardScheme extends StandardScheme<scannerOpenWithScan_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, scannerOpenWithScan_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.I32) { struct.success = iprot.readI32(); struct.setSuccessIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, scannerOpenWithScan_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.isSetSuccess()) { oprot.writeFieldBegin(SUCCESS_FIELD_DESC); oprot.writeI32(struct.success); oprot.writeFieldEnd(); } if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class scannerOpenWithScan_resultTupleSchemeFactory implements SchemeFactory { public scannerOpenWithScan_resultTupleScheme getScheme() { return new scannerOpenWithScan_resultTupleScheme(); } } private static class scannerOpenWithScan_resultTupleScheme extends TupleScheme<scannerOpenWithScan_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, scannerOpenWithScan_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetSuccess()) { optionals.set(0); } if (struct.isSetIo()) { optionals.set(1); } oprot.writeBitSet(optionals, 2); if (struct.isSetSuccess()) { oprot.writeI32(struct.success); } if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, scannerOpenWithScan_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { struct.success = iprot.readI32(); struct.setSuccessIsSet(true); } if (incoming.get(1)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class scannerOpen_args implements org.apache.thrift.TBase<scannerOpen_args, scannerOpen_args._Fields>, java.io.Serializable, Cloneable, Comparable<scannerOpen_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("scannerOpen_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final org.apache.thrift.protocol.TField START_ROW_FIELD_DESC = new org.apache.thrift.protocol.TField("startRow", org.apache.thrift.protocol.TType.STRING, (short)2); private static final org.apache.thrift.protocol.TField COLUMNS_FIELD_DESC = new org.apache.thrift.protocol.TField("columns", org.apache.thrift.protocol.TType.LIST, (short)3); private static final org.apache.thrift.protocol.TField ATTRIBUTES_FIELD_DESC = new org.apache.thrift.protocol.TField("attributes", org.apache.thrift.protocol.TType.MAP, (short)4); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new scannerOpen_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new scannerOpen_argsTupleSchemeFactory()); } /** * name of table */ public ByteBuffer tableName; // required /** * Starting row in table to scan. * Send "" (empty string) to start at the first row. */ public ByteBuffer startRow; // required /** * columns to scan. If column name is a column family, all * columns of the specified column family are returned. It's also possible * to pass a regex in the column qualifier. */ public List<ByteBuffer> columns; // required /** * Scan attributes */ public Map<ByteBuffer,ByteBuffer> attributes; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * name of table */ TABLE_NAME((short)1, "tableName"), /** * Starting row in table to scan. * Send "" (empty string) to start at the first row. */ START_ROW((short)2, "startRow"), /** * columns to scan. If column name is a column family, all * columns of the specified column family are returned. It's also possible * to pass a regex in the column qualifier. */ COLUMNS((short)3, "columns"), /** * Scan attributes */ ATTRIBUTES((short)4, "attributes"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; case 2: // START_ROW return START_ROW; case 3: // COLUMNS return COLUMNS; case 4: // ATTRIBUTES return ATTRIBUTES; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.START_ROW, new org.apache.thrift.meta_data.FieldMetaData("startRow", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.COLUMNS, new org.apache.thrift.meta_data.FieldMetaData("columns", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); tmpMap.put(_Fields.ATTRIBUTES, new org.apache.thrift.meta_data.FieldMetaData("attributes", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.MapMetaData(org.apache.thrift.protocol.TType.MAP, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"), new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(scannerOpen_args.class, metaDataMap); } public scannerOpen_args() { } public scannerOpen_args( ByteBuffer tableName, ByteBuffer startRow, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); this.startRow = org.apache.thrift.TBaseHelper.copyBinary(startRow); this.columns = columns; this.attributes = attributes; } /** * Performs a deep copy on <i>other</i>. */ public scannerOpen_args(scannerOpen_args other) { if (other.isSetTableName()) { this.tableName = other.tableName; } if (other.isSetStartRow()) { this.startRow = other.startRow; } if (other.isSetColumns()) { List<ByteBuffer> __this__columns = new ArrayList<ByteBuffer>(other.columns.size()); for (ByteBuffer other_element : other.columns) { __this__columns.add(other_element); } this.columns = __this__columns; } if (other.isSetAttributes()) { Map<ByteBuffer,ByteBuffer> __this__attributes = new HashMap<ByteBuffer,ByteBuffer>(other.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> other_element : other.attributes.entrySet()) { ByteBuffer other_element_key = other_element.getKey(); ByteBuffer other_element_value = other_element.getValue(); ByteBuffer __this__attributes_copy_key = other_element_key; ByteBuffer __this__attributes_copy_value = other_element_value; __this__attributes.put(__this__attributes_copy_key, __this__attributes_copy_value); } this.attributes = __this__attributes; } } public scannerOpen_args deepCopy() { return new scannerOpen_args(this); } @Override public void clear() { this.tableName = null; this.startRow = null; this.columns = null; this.attributes = null; } /** * name of table */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * name of table */ public scannerOpen_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public scannerOpen_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } /** * Starting row in table to scan. * Send "" (empty string) to start at the first row. */ public byte[] getStartRow() { setStartRow(org.apache.thrift.TBaseHelper.rightSize(startRow)); return startRow == null ? null : startRow.array(); } public ByteBuffer bufferForStartRow() { return org.apache.thrift.TBaseHelper.copyBinary(startRow); } /** * Starting row in table to scan. * Send "" (empty string) to start at the first row. */ public scannerOpen_args setStartRow(byte[] startRow) { this.startRow = startRow == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(startRow, startRow.length)); return this; } public scannerOpen_args setStartRow(ByteBuffer startRow) { this.startRow = org.apache.thrift.TBaseHelper.copyBinary(startRow); return this; } public void unsetStartRow() { this.startRow = null; } /** Returns true if field startRow is set (has been assigned a value) and false otherwise */ public boolean isSetStartRow() { return this.startRow != null; } public void setStartRowIsSet(boolean value) { if (!value) { this.startRow = null; } } public int getColumnsSize() { return (this.columns == null) ? 0 : this.columns.size(); } public java.util.Iterator<ByteBuffer> getColumnsIterator() { return (this.columns == null) ? null : this.columns.iterator(); } public void addToColumns(ByteBuffer elem) { if (this.columns == null) { this.columns = new ArrayList<ByteBuffer>(); } this.columns.add(elem); } /** * columns to scan. If column name is a column family, all * columns of the specified column family are returned. It's also possible * to pass a regex in the column qualifier. */ public List<ByteBuffer> getColumns() { return this.columns; } /** * columns to scan. If column name is a column family, all * columns of the specified column family are returned. It's also possible * to pass a regex in the column qualifier. */ public scannerOpen_args setColumns(List<ByteBuffer> columns) { this.columns = columns; return this; } public void unsetColumns() { this.columns = null; } /** Returns true if field columns is set (has been assigned a value) and false otherwise */ public boolean isSetColumns() { return this.columns != null; } public void setColumnsIsSet(boolean value) { if (!value) { this.columns = null; } } public int getAttributesSize() { return (this.attributes == null) ? 0 : this.attributes.size(); } public void putToAttributes(ByteBuffer key, ByteBuffer val) { if (this.attributes == null) { this.attributes = new HashMap<ByteBuffer,ByteBuffer>(); } this.attributes.put(key, val); } /** * Scan attributes */ public Map<ByteBuffer,ByteBuffer> getAttributes() { return this.attributes; } /** * Scan attributes */ public scannerOpen_args setAttributes(Map<ByteBuffer,ByteBuffer> attributes) { this.attributes = attributes; return this; } public void unsetAttributes() { this.attributes = null; } /** Returns true if field attributes is set (has been assigned a value) and false otherwise */ public boolean isSetAttributes() { return this.attributes != null; } public void setAttributesIsSet(boolean value) { if (!value) { this.attributes = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; case START_ROW: if (value == null) { unsetStartRow(); } else { setStartRow((ByteBuffer)value); } break; case COLUMNS: if (value == null) { unsetColumns(); } else { setColumns((List<ByteBuffer>)value); } break; case ATTRIBUTES: if (value == null) { unsetAttributes(); } else { setAttributes((Map<ByteBuffer,ByteBuffer>)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); case START_ROW: return getStartRow(); case COLUMNS: return getColumns(); case ATTRIBUTES: return getAttributes(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); case START_ROW: return isSetStartRow(); case COLUMNS: return isSetColumns(); case ATTRIBUTES: return isSetAttributes(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof scannerOpen_args) return this.equals((scannerOpen_args)that); return false; } public boolean equals(scannerOpen_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } boolean this_present_startRow = true && this.isSetStartRow(); boolean that_present_startRow = true && that.isSetStartRow(); if (this_present_startRow || that_present_startRow) { if (!(this_present_startRow && that_present_startRow)) return false; if (!this.startRow.equals(that.startRow)) return false; } boolean this_present_columns = true && this.isSetColumns(); boolean that_present_columns = true && that.isSetColumns(); if (this_present_columns || that_present_columns) { if (!(this_present_columns && that_present_columns)) return false; if (!this.columns.equals(that.columns)) return false; } boolean this_present_attributes = true && this.isSetAttributes(); boolean that_present_attributes = true && that.isSetAttributes(); if (this_present_attributes || that_present_attributes) { if (!(this_present_attributes && that_present_attributes)) return false; if (!this.attributes.equals(that.attributes)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); boolean present_startRow = true && (isSetStartRow()); list.add(present_startRow); if (present_startRow) list.add(startRow); boolean present_columns = true && (isSetColumns()); list.add(present_columns); if (present_columns) list.add(columns); boolean present_attributes = true && (isSetAttributes()); list.add(present_attributes); if (present_attributes) list.add(attributes); return list.hashCode(); } @Override public int compareTo(scannerOpen_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetStartRow()).compareTo(other.isSetStartRow()); if (lastComparison != 0) { return lastComparison; } if (isSetStartRow()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.startRow, other.startRow); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetColumns()).compareTo(other.isSetColumns()); if (lastComparison != 0) { return lastComparison; } if (isSetColumns()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.columns, other.columns); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetAttributes()).compareTo(other.isSetAttributes()); if (lastComparison != 0) { return lastComparison; } if (isSetAttributes()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.attributes, other.attributes); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("scannerOpen_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; if (!first) sb.append(", "); sb.append("startRow:"); if (this.startRow == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.startRow, sb); } first = false; if (!first) sb.append(", "); sb.append("columns:"); if (this.columns == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.columns, sb); } first = false; if (!first) sb.append(", "); sb.append("attributes:"); if (this.attributes == null) { sb.append("null"); } else { sb.append(this.attributes); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class scannerOpen_argsStandardSchemeFactory implements SchemeFactory { public scannerOpen_argsStandardScheme getScheme() { return new scannerOpen_argsStandardScheme(); } } private static class scannerOpen_argsStandardScheme extends StandardScheme<scannerOpen_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, scannerOpen_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // START_ROW if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.startRow = iprot.readBinary(); struct.setStartRowIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 3: // COLUMNS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list476 = iprot.readListBegin(); struct.columns = new ArrayList<ByteBuffer>(_list476.size); ByteBuffer _elem477; for (int _i478 = 0; _i478 < _list476.size; ++_i478) { _elem477 = iprot.readBinary(); struct.columns.add(_elem477); } iprot.readListEnd(); } struct.setColumnsIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 4: // ATTRIBUTES if (schemeField.type == org.apache.thrift.protocol.TType.MAP) { { org.apache.thrift.protocol.TMap _map479 = iprot.readMapBegin(); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map479.size); ByteBuffer _key480; ByteBuffer _val481; for (int _i482 = 0; _i482 < _map479.size; ++_i482) { _key480 = iprot.readBinary(); _val481 = iprot.readBinary(); struct.attributes.put(_key480, _val481); } iprot.readMapEnd(); } struct.setAttributesIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, scannerOpen_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } if (struct.startRow != null) { oprot.writeFieldBegin(START_ROW_FIELD_DESC); oprot.writeBinary(struct.startRow); oprot.writeFieldEnd(); } if (struct.columns != null) { oprot.writeFieldBegin(COLUMNS_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.columns.size())); for (ByteBuffer _iter483 : struct.columns) { oprot.writeBinary(_iter483); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } if (struct.attributes != null) { oprot.writeFieldBegin(ATTRIBUTES_FIELD_DESC); { oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, struct.attributes.size())); for (Map.Entry<ByteBuffer, ByteBuffer> _iter484 : struct.attributes.entrySet()) { oprot.writeBinary(_iter484.getKey()); oprot.writeBinary(_iter484.getValue()); } oprot.writeMapEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class scannerOpen_argsTupleSchemeFactory implements SchemeFactory { public scannerOpen_argsTupleScheme getScheme() { return new scannerOpen_argsTupleScheme(); } } private static class scannerOpen_argsTupleScheme extends TupleScheme<scannerOpen_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, scannerOpen_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } if (struct.isSetStartRow()) { optionals.set(1); } if (struct.isSetColumns()) { optionals.set(2); } if (struct.isSetAttributes()) { optionals.set(3); } oprot.writeBitSet(optionals, 4); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } if (struct.isSetStartRow()) { oprot.writeBinary(struct.startRow); } if (struct.isSetColumns()) { { oprot.writeI32(struct.columns.size()); for (ByteBuffer _iter485 : struct.columns) { oprot.writeBinary(_iter485); } } } if (struct.isSetAttributes()) { { oprot.writeI32(struct.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> _iter486 : struct.attributes.entrySet()) { oprot.writeBinary(_iter486.getKey()); oprot.writeBinary(_iter486.getValue()); } } } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, scannerOpen_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(4); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } if (incoming.get(1)) { struct.startRow = iprot.readBinary(); struct.setStartRowIsSet(true); } if (incoming.get(2)) { { org.apache.thrift.protocol.TList _list487 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.columns = new ArrayList<ByteBuffer>(_list487.size); ByteBuffer _elem488; for (int _i489 = 0; _i489 < _list487.size; ++_i489) { _elem488 = iprot.readBinary(); struct.columns.add(_elem488); } } struct.setColumnsIsSet(true); } if (incoming.get(3)) { { org.apache.thrift.protocol.TMap _map490 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map490.size); ByteBuffer _key491; ByteBuffer _val492; for (int _i493 = 0; _i493 < _map490.size; ++_i493) { _key491 = iprot.readBinary(); _val492 = iprot.readBinary(); struct.attributes.put(_key491, _val492); } } struct.setAttributesIsSet(true); } } } } public static class scannerOpen_result implements org.apache.thrift.TBase<scannerOpen_result, scannerOpen_result._Fields>, java.io.Serializable, Cloneable, Comparable<scannerOpen_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("scannerOpen_result"); private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.I32, (short)0); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new scannerOpen_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new scannerOpen_resultTupleSchemeFactory()); } public int success; // required public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { SUCCESS((short)0, "success"), IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 0: // SUCCESS return SUCCESS; case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments private static final int __SUCCESS_ISSET_ID = 0; private byte __isset_bitfield = 0; public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.SUCCESS, new org.apache.thrift.meta_data.FieldMetaData("success", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.I32 , "ScannerID"))); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(scannerOpen_result.class, metaDataMap); } public scannerOpen_result() { } public scannerOpen_result( int success, IOError io) { this(); this.success = success; setSuccessIsSet(true); this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public scannerOpen_result(scannerOpen_result other) { __isset_bitfield = other.__isset_bitfield; this.success = other.success; if (other.isSetIo()) { this.io = new IOError(other.io); } } public scannerOpen_result deepCopy() { return new scannerOpen_result(this); } @Override public void clear() { setSuccessIsSet(false); this.success = 0; this.io = null; } public int getSuccess() { return this.success; } public scannerOpen_result setSuccess(int success) { this.success = success; setSuccessIsSet(true); return this; } public void unsetSuccess() { __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __SUCCESS_ISSET_ID); } /** Returns true if field success is set (has been assigned a value) and false otherwise */ public boolean isSetSuccess() { return EncodingUtils.testBit(__isset_bitfield, __SUCCESS_ISSET_ID); } public void setSuccessIsSet(boolean value) { __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __SUCCESS_ISSET_ID, value); } public IOError getIo() { return this.io; } public scannerOpen_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case SUCCESS: if (value == null) { unsetSuccess(); } else { setSuccess((Integer)value); } break; case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case SUCCESS: return getSuccess(); case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case SUCCESS: return isSetSuccess(); case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof scannerOpen_result) return this.equals((scannerOpen_result)that); return false; } public boolean equals(scannerOpen_result that) { if (that == null) return false; boolean this_present_success = true; boolean that_present_success = true; if (this_present_success || that_present_success) { if (!(this_present_success && that_present_success)) return false; if (this.success != that.success) return false; } boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_success = true; list.add(present_success); if (present_success) list.add(success); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(scannerOpen_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess()); if (lastComparison != 0) { return lastComparison; } if (isSetSuccess()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("scannerOpen_result("); boolean first = true; sb.append("success:"); sb.append(this.success); first = false; if (!first) sb.append(", "); sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { // it doesn't seem like you should have to do this, but java serialization is wacky, and doesn't call the default constructor. __isset_bitfield = 0; read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class scannerOpen_resultStandardSchemeFactory implements SchemeFactory { public scannerOpen_resultStandardScheme getScheme() { return new scannerOpen_resultStandardScheme(); } } private static class scannerOpen_resultStandardScheme extends StandardScheme<scannerOpen_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, scannerOpen_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.I32) { struct.success = iprot.readI32(); struct.setSuccessIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, scannerOpen_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.isSetSuccess()) { oprot.writeFieldBegin(SUCCESS_FIELD_DESC); oprot.writeI32(struct.success); oprot.writeFieldEnd(); } if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class scannerOpen_resultTupleSchemeFactory implements SchemeFactory { public scannerOpen_resultTupleScheme getScheme() { return new scannerOpen_resultTupleScheme(); } } private static class scannerOpen_resultTupleScheme extends TupleScheme<scannerOpen_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, scannerOpen_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetSuccess()) { optionals.set(0); } if (struct.isSetIo()) { optionals.set(1); } oprot.writeBitSet(optionals, 2); if (struct.isSetSuccess()) { oprot.writeI32(struct.success); } if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, scannerOpen_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { struct.success = iprot.readI32(); struct.setSuccessIsSet(true); } if (incoming.get(1)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class scannerOpenWithStop_args implements org.apache.thrift.TBase<scannerOpenWithStop_args, scannerOpenWithStop_args._Fields>, java.io.Serializable, Cloneable, Comparable<scannerOpenWithStop_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("scannerOpenWithStop_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final org.apache.thrift.protocol.TField START_ROW_FIELD_DESC = new org.apache.thrift.protocol.TField("startRow", org.apache.thrift.protocol.TType.STRING, (short)2); private static final org.apache.thrift.protocol.TField STOP_ROW_FIELD_DESC = new org.apache.thrift.protocol.TField("stopRow", org.apache.thrift.protocol.TType.STRING, (short)3); private static final org.apache.thrift.protocol.TField COLUMNS_FIELD_DESC = new org.apache.thrift.protocol.TField("columns", org.apache.thrift.protocol.TType.LIST, (short)4); private static final org.apache.thrift.protocol.TField ATTRIBUTES_FIELD_DESC = new org.apache.thrift.protocol.TField("attributes", org.apache.thrift.protocol.TType.MAP, (short)5); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new scannerOpenWithStop_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new scannerOpenWithStop_argsTupleSchemeFactory()); } /** * name of table */ public ByteBuffer tableName; // required /** * Starting row in table to scan. * Send "" (empty string) to start at the first row. */ public ByteBuffer startRow; // required /** * row to stop scanning on. This row is *not* included in the * scanner's results */ public ByteBuffer stopRow; // required /** * columns to scan. If column name is a column family, all * columns of the specified column family are returned. It's also possible * to pass a regex in the column qualifier. */ public List<ByteBuffer> columns; // required /** * Scan attributes */ public Map<ByteBuffer,ByteBuffer> attributes; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * name of table */ TABLE_NAME((short)1, "tableName"), /** * Starting row in table to scan. * Send "" (empty string) to start at the first row. */ START_ROW((short)2, "startRow"), /** * row to stop scanning on. This row is *not* included in the * scanner's results */ STOP_ROW((short)3, "stopRow"), /** * columns to scan. If column name is a column family, all * columns of the specified column family are returned. It's also possible * to pass a regex in the column qualifier. */ COLUMNS((short)4, "columns"), /** * Scan attributes */ ATTRIBUTES((short)5, "attributes"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; case 2: // START_ROW return START_ROW; case 3: // STOP_ROW return STOP_ROW; case 4: // COLUMNS return COLUMNS; case 5: // ATTRIBUTES return ATTRIBUTES; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.START_ROW, new org.apache.thrift.meta_data.FieldMetaData("startRow", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.STOP_ROW, new org.apache.thrift.meta_data.FieldMetaData("stopRow", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.COLUMNS, new org.apache.thrift.meta_data.FieldMetaData("columns", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); tmpMap.put(_Fields.ATTRIBUTES, new org.apache.thrift.meta_data.FieldMetaData("attributes", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.MapMetaData(org.apache.thrift.protocol.TType.MAP, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"), new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(scannerOpenWithStop_args.class, metaDataMap); } public scannerOpenWithStop_args() { } public scannerOpenWithStop_args( ByteBuffer tableName, ByteBuffer startRow, ByteBuffer stopRow, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); this.startRow = org.apache.thrift.TBaseHelper.copyBinary(startRow); this.stopRow = org.apache.thrift.TBaseHelper.copyBinary(stopRow); this.columns = columns; this.attributes = attributes; } /** * Performs a deep copy on <i>other</i>. */ public scannerOpenWithStop_args(scannerOpenWithStop_args other) { if (other.isSetTableName()) { this.tableName = other.tableName; } if (other.isSetStartRow()) { this.startRow = other.startRow; } if (other.isSetStopRow()) { this.stopRow = other.stopRow; } if (other.isSetColumns()) { List<ByteBuffer> __this__columns = new ArrayList<ByteBuffer>(other.columns.size()); for (ByteBuffer other_element : other.columns) { __this__columns.add(other_element); } this.columns = __this__columns; } if (other.isSetAttributes()) { Map<ByteBuffer,ByteBuffer> __this__attributes = new HashMap<ByteBuffer,ByteBuffer>(other.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> other_element : other.attributes.entrySet()) { ByteBuffer other_element_key = other_element.getKey(); ByteBuffer other_element_value = other_element.getValue(); ByteBuffer __this__attributes_copy_key = other_element_key; ByteBuffer __this__attributes_copy_value = other_element_value; __this__attributes.put(__this__attributes_copy_key, __this__attributes_copy_value); } this.attributes = __this__attributes; } } public scannerOpenWithStop_args deepCopy() { return new scannerOpenWithStop_args(this); } @Override public void clear() { this.tableName = null; this.startRow = null; this.stopRow = null; this.columns = null; this.attributes = null; } /** * name of table */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * name of table */ public scannerOpenWithStop_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public scannerOpenWithStop_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } /** * Starting row in table to scan. * Send "" (empty string) to start at the first row. */ public byte[] getStartRow() { setStartRow(org.apache.thrift.TBaseHelper.rightSize(startRow)); return startRow == null ? null : startRow.array(); } public ByteBuffer bufferForStartRow() { return org.apache.thrift.TBaseHelper.copyBinary(startRow); } /** * Starting row in table to scan. * Send "" (empty string) to start at the first row. */ public scannerOpenWithStop_args setStartRow(byte[] startRow) { this.startRow = startRow == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(startRow, startRow.length)); return this; } public scannerOpenWithStop_args setStartRow(ByteBuffer startRow) { this.startRow = org.apache.thrift.TBaseHelper.copyBinary(startRow); return this; } public void unsetStartRow() { this.startRow = null; } /** Returns true if field startRow is set (has been assigned a value) and false otherwise */ public boolean isSetStartRow() { return this.startRow != null; } public void setStartRowIsSet(boolean value) { if (!value) { this.startRow = null; } } /** * row to stop scanning on. This row is *not* included in the * scanner's results */ public byte[] getStopRow() { setStopRow(org.apache.thrift.TBaseHelper.rightSize(stopRow)); return stopRow == null ? null : stopRow.array(); } public ByteBuffer bufferForStopRow() { return org.apache.thrift.TBaseHelper.copyBinary(stopRow); } /** * row to stop scanning on. This row is *not* included in the * scanner's results */ public scannerOpenWithStop_args setStopRow(byte[] stopRow) { this.stopRow = stopRow == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(stopRow, stopRow.length)); return this; } public scannerOpenWithStop_args setStopRow(ByteBuffer stopRow) { this.stopRow = org.apache.thrift.TBaseHelper.copyBinary(stopRow); return this; } public void unsetStopRow() { this.stopRow = null; } /** Returns true if field stopRow is set (has been assigned a value) and false otherwise */ public boolean isSetStopRow() { return this.stopRow != null; } public void setStopRowIsSet(boolean value) { if (!value) { this.stopRow = null; } } public int getColumnsSize() { return (this.columns == null) ? 0 : this.columns.size(); } public java.util.Iterator<ByteBuffer> getColumnsIterator() { return (this.columns == null) ? null : this.columns.iterator(); } public void addToColumns(ByteBuffer elem) { if (this.columns == null) { this.columns = new ArrayList<ByteBuffer>(); } this.columns.add(elem); } /** * columns to scan. If column name is a column family, all * columns of the specified column family are returned. It's also possible * to pass a regex in the column qualifier. */ public List<ByteBuffer> getColumns() { return this.columns; } /** * columns to scan. If column name is a column family, all * columns of the specified column family are returned. It's also possible * to pass a regex in the column qualifier. */ public scannerOpenWithStop_args setColumns(List<ByteBuffer> columns) { this.columns = columns; return this; } public void unsetColumns() { this.columns = null; } /** Returns true if field columns is set (has been assigned a value) and false otherwise */ public boolean isSetColumns() { return this.columns != null; } public void setColumnsIsSet(boolean value) { if (!value) { this.columns = null; } } public int getAttributesSize() { return (this.attributes == null) ? 0 : this.attributes.size(); } public void putToAttributes(ByteBuffer key, ByteBuffer val) { if (this.attributes == null) { this.attributes = new HashMap<ByteBuffer,ByteBuffer>(); } this.attributes.put(key, val); } /** * Scan attributes */ public Map<ByteBuffer,ByteBuffer> getAttributes() { return this.attributes; } /** * Scan attributes */ public scannerOpenWithStop_args setAttributes(Map<ByteBuffer,ByteBuffer> attributes) { this.attributes = attributes; return this; } public void unsetAttributes() { this.attributes = null; } /** Returns true if field attributes is set (has been assigned a value) and false otherwise */ public boolean isSetAttributes() { return this.attributes != null; } public void setAttributesIsSet(boolean value) { if (!value) { this.attributes = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; case START_ROW: if (value == null) { unsetStartRow(); } else { setStartRow((ByteBuffer)value); } break; case STOP_ROW: if (value == null) { unsetStopRow(); } else { setStopRow((ByteBuffer)value); } break; case COLUMNS: if (value == null) { unsetColumns(); } else { setColumns((List<ByteBuffer>)value); } break; case ATTRIBUTES: if (value == null) { unsetAttributes(); } else { setAttributes((Map<ByteBuffer,ByteBuffer>)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); case START_ROW: return getStartRow(); case STOP_ROW: return getStopRow(); case COLUMNS: return getColumns(); case ATTRIBUTES: return getAttributes(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); case START_ROW: return isSetStartRow(); case STOP_ROW: return isSetStopRow(); case COLUMNS: return isSetColumns(); case ATTRIBUTES: return isSetAttributes(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof scannerOpenWithStop_args) return this.equals((scannerOpenWithStop_args)that); return false; } public boolean equals(scannerOpenWithStop_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } boolean this_present_startRow = true && this.isSetStartRow(); boolean that_present_startRow = true && that.isSetStartRow(); if (this_present_startRow || that_present_startRow) { if (!(this_present_startRow && that_present_startRow)) return false; if (!this.startRow.equals(that.startRow)) return false; } boolean this_present_stopRow = true && this.isSetStopRow(); boolean that_present_stopRow = true && that.isSetStopRow(); if (this_present_stopRow || that_present_stopRow) { if (!(this_present_stopRow && that_present_stopRow)) return false; if (!this.stopRow.equals(that.stopRow)) return false; } boolean this_present_columns = true && this.isSetColumns(); boolean that_present_columns = true && that.isSetColumns(); if (this_present_columns || that_present_columns) { if (!(this_present_columns && that_present_columns)) return false; if (!this.columns.equals(that.columns)) return false; } boolean this_present_attributes = true && this.isSetAttributes(); boolean that_present_attributes = true && that.isSetAttributes(); if (this_present_attributes || that_present_attributes) { if (!(this_present_attributes && that_present_attributes)) return false; if (!this.attributes.equals(that.attributes)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); boolean present_startRow = true && (isSetStartRow()); list.add(present_startRow); if (present_startRow) list.add(startRow); boolean present_stopRow = true && (isSetStopRow()); list.add(present_stopRow); if (present_stopRow) list.add(stopRow); boolean present_columns = true && (isSetColumns()); list.add(present_columns); if (present_columns) list.add(columns); boolean present_attributes = true && (isSetAttributes()); list.add(present_attributes); if (present_attributes) list.add(attributes); return list.hashCode(); } @Override public int compareTo(scannerOpenWithStop_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetStartRow()).compareTo(other.isSetStartRow()); if (lastComparison != 0) { return lastComparison; } if (isSetStartRow()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.startRow, other.startRow); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetStopRow()).compareTo(other.isSetStopRow()); if (lastComparison != 0) { return lastComparison; } if (isSetStopRow()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.stopRow, other.stopRow); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetColumns()).compareTo(other.isSetColumns()); if (lastComparison != 0) { return lastComparison; } if (isSetColumns()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.columns, other.columns); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetAttributes()).compareTo(other.isSetAttributes()); if (lastComparison != 0) { return lastComparison; } if (isSetAttributes()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.attributes, other.attributes); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("scannerOpenWithStop_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; if (!first) sb.append(", "); sb.append("startRow:"); if (this.startRow == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.startRow, sb); } first = false; if (!first) sb.append(", "); sb.append("stopRow:"); if (this.stopRow == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.stopRow, sb); } first = false; if (!first) sb.append(", "); sb.append("columns:"); if (this.columns == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.columns, sb); } first = false; if (!first) sb.append(", "); sb.append("attributes:"); if (this.attributes == null) { sb.append("null"); } else { sb.append(this.attributes); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class scannerOpenWithStop_argsStandardSchemeFactory implements SchemeFactory { public scannerOpenWithStop_argsStandardScheme getScheme() { return new scannerOpenWithStop_argsStandardScheme(); } } private static class scannerOpenWithStop_argsStandardScheme extends StandardScheme<scannerOpenWithStop_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, scannerOpenWithStop_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // START_ROW if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.startRow = iprot.readBinary(); struct.setStartRowIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 3: // STOP_ROW if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.stopRow = iprot.readBinary(); struct.setStopRowIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 4: // COLUMNS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list494 = iprot.readListBegin(); struct.columns = new ArrayList<ByteBuffer>(_list494.size); ByteBuffer _elem495; for (int _i496 = 0; _i496 < _list494.size; ++_i496) { _elem495 = iprot.readBinary(); struct.columns.add(_elem495); } iprot.readListEnd(); } struct.setColumnsIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 5: // ATTRIBUTES if (schemeField.type == org.apache.thrift.protocol.TType.MAP) { { org.apache.thrift.protocol.TMap _map497 = iprot.readMapBegin(); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map497.size); ByteBuffer _key498; ByteBuffer _val499; for (int _i500 = 0; _i500 < _map497.size; ++_i500) { _key498 = iprot.readBinary(); _val499 = iprot.readBinary(); struct.attributes.put(_key498, _val499); } iprot.readMapEnd(); } struct.setAttributesIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, scannerOpenWithStop_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } if (struct.startRow != null) { oprot.writeFieldBegin(START_ROW_FIELD_DESC); oprot.writeBinary(struct.startRow); oprot.writeFieldEnd(); } if (struct.stopRow != null) { oprot.writeFieldBegin(STOP_ROW_FIELD_DESC); oprot.writeBinary(struct.stopRow); oprot.writeFieldEnd(); } if (struct.columns != null) { oprot.writeFieldBegin(COLUMNS_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.columns.size())); for (ByteBuffer _iter501 : struct.columns) { oprot.writeBinary(_iter501); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } if (struct.attributes != null) { oprot.writeFieldBegin(ATTRIBUTES_FIELD_DESC); { oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, struct.attributes.size())); for (Map.Entry<ByteBuffer, ByteBuffer> _iter502 : struct.attributes.entrySet()) { oprot.writeBinary(_iter502.getKey()); oprot.writeBinary(_iter502.getValue()); } oprot.writeMapEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class scannerOpenWithStop_argsTupleSchemeFactory implements SchemeFactory { public scannerOpenWithStop_argsTupleScheme getScheme() { return new scannerOpenWithStop_argsTupleScheme(); } } private static class scannerOpenWithStop_argsTupleScheme extends TupleScheme<scannerOpenWithStop_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, scannerOpenWithStop_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } if (struct.isSetStartRow()) { optionals.set(1); } if (struct.isSetStopRow()) { optionals.set(2); } if (struct.isSetColumns()) { optionals.set(3); } if (struct.isSetAttributes()) { optionals.set(4); } oprot.writeBitSet(optionals, 5); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } if (struct.isSetStartRow()) { oprot.writeBinary(struct.startRow); } if (struct.isSetStopRow()) { oprot.writeBinary(struct.stopRow); } if (struct.isSetColumns()) { { oprot.writeI32(struct.columns.size()); for (ByteBuffer _iter503 : struct.columns) { oprot.writeBinary(_iter503); } } } if (struct.isSetAttributes()) { { oprot.writeI32(struct.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> _iter504 : struct.attributes.entrySet()) { oprot.writeBinary(_iter504.getKey()); oprot.writeBinary(_iter504.getValue()); } } } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, scannerOpenWithStop_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(5); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } if (incoming.get(1)) { struct.startRow = iprot.readBinary(); struct.setStartRowIsSet(true); } if (incoming.get(2)) { struct.stopRow = iprot.readBinary(); struct.setStopRowIsSet(true); } if (incoming.get(3)) { { org.apache.thrift.protocol.TList _list505 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.columns = new ArrayList<ByteBuffer>(_list505.size); ByteBuffer _elem506; for (int _i507 = 0; _i507 < _list505.size; ++_i507) { _elem506 = iprot.readBinary(); struct.columns.add(_elem506); } } struct.setColumnsIsSet(true); } if (incoming.get(4)) { { org.apache.thrift.protocol.TMap _map508 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map508.size); ByteBuffer _key509; ByteBuffer _val510; for (int _i511 = 0; _i511 < _map508.size; ++_i511) { _key509 = iprot.readBinary(); _val510 = iprot.readBinary(); struct.attributes.put(_key509, _val510); } } struct.setAttributesIsSet(true); } } } } public static class scannerOpenWithStop_result implements org.apache.thrift.TBase<scannerOpenWithStop_result, scannerOpenWithStop_result._Fields>, java.io.Serializable, Cloneable, Comparable<scannerOpenWithStop_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("scannerOpenWithStop_result"); private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.I32, (short)0); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new scannerOpenWithStop_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new scannerOpenWithStop_resultTupleSchemeFactory()); } public int success; // required public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { SUCCESS((short)0, "success"), IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 0: // SUCCESS return SUCCESS; case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments private static final int __SUCCESS_ISSET_ID = 0; private byte __isset_bitfield = 0; public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.SUCCESS, new org.apache.thrift.meta_data.FieldMetaData("success", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.I32 , "ScannerID"))); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(scannerOpenWithStop_result.class, metaDataMap); } public scannerOpenWithStop_result() { } public scannerOpenWithStop_result( int success, IOError io) { this(); this.success = success; setSuccessIsSet(true); this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public scannerOpenWithStop_result(scannerOpenWithStop_result other) { __isset_bitfield = other.__isset_bitfield; this.success = other.success; if (other.isSetIo()) { this.io = new IOError(other.io); } } public scannerOpenWithStop_result deepCopy() { return new scannerOpenWithStop_result(this); } @Override public void clear() { setSuccessIsSet(false); this.success = 0; this.io = null; } public int getSuccess() { return this.success; } public scannerOpenWithStop_result setSuccess(int success) { this.success = success; setSuccessIsSet(true); return this; } public void unsetSuccess() { __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __SUCCESS_ISSET_ID); } /** Returns true if field success is set (has been assigned a value) and false otherwise */ public boolean isSetSuccess() { return EncodingUtils.testBit(__isset_bitfield, __SUCCESS_ISSET_ID); } public void setSuccessIsSet(boolean value) { __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __SUCCESS_ISSET_ID, value); } public IOError getIo() { return this.io; } public scannerOpenWithStop_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case SUCCESS: if (value == null) { unsetSuccess(); } else { setSuccess((Integer)value); } break; case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case SUCCESS: return getSuccess(); case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case SUCCESS: return isSetSuccess(); case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof scannerOpenWithStop_result) return this.equals((scannerOpenWithStop_result)that); return false; } public boolean equals(scannerOpenWithStop_result that) { if (that == null) return false; boolean this_present_success = true; boolean that_present_success = true; if (this_present_success || that_present_success) { if (!(this_present_success && that_present_success)) return false; if (this.success != that.success) return false; } boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_success = true; list.add(present_success); if (present_success) list.add(success); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(scannerOpenWithStop_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess()); if (lastComparison != 0) { return lastComparison; } if (isSetSuccess()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("scannerOpenWithStop_result("); boolean first = true; sb.append("success:"); sb.append(this.success); first = false; if (!first) sb.append(", "); sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { // it doesn't seem like you should have to do this, but java serialization is wacky, and doesn't call the default constructor. __isset_bitfield = 0; read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class scannerOpenWithStop_resultStandardSchemeFactory implements SchemeFactory { public scannerOpenWithStop_resultStandardScheme getScheme() { return new scannerOpenWithStop_resultStandardScheme(); } } private static class scannerOpenWithStop_resultStandardScheme extends StandardScheme<scannerOpenWithStop_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, scannerOpenWithStop_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.I32) { struct.success = iprot.readI32(); struct.setSuccessIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, scannerOpenWithStop_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.isSetSuccess()) { oprot.writeFieldBegin(SUCCESS_FIELD_DESC); oprot.writeI32(struct.success); oprot.writeFieldEnd(); } if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class scannerOpenWithStop_resultTupleSchemeFactory implements SchemeFactory { public scannerOpenWithStop_resultTupleScheme getScheme() { return new scannerOpenWithStop_resultTupleScheme(); } } private static class scannerOpenWithStop_resultTupleScheme extends TupleScheme<scannerOpenWithStop_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, scannerOpenWithStop_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetSuccess()) { optionals.set(0); } if (struct.isSetIo()) { optionals.set(1); } oprot.writeBitSet(optionals, 2); if (struct.isSetSuccess()) { oprot.writeI32(struct.success); } if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, scannerOpenWithStop_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { struct.success = iprot.readI32(); struct.setSuccessIsSet(true); } if (incoming.get(1)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class scannerOpenWithPrefix_args implements org.apache.thrift.TBase<scannerOpenWithPrefix_args, scannerOpenWithPrefix_args._Fields>, java.io.Serializable, Cloneable, Comparable<scannerOpenWithPrefix_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("scannerOpenWithPrefix_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final org.apache.thrift.protocol.TField START_AND_PREFIX_FIELD_DESC = new org.apache.thrift.protocol.TField("startAndPrefix", org.apache.thrift.protocol.TType.STRING, (short)2); private static final org.apache.thrift.protocol.TField COLUMNS_FIELD_DESC = new org.apache.thrift.protocol.TField("columns", org.apache.thrift.protocol.TType.LIST, (short)3); private static final org.apache.thrift.protocol.TField ATTRIBUTES_FIELD_DESC = new org.apache.thrift.protocol.TField("attributes", org.apache.thrift.protocol.TType.MAP, (short)4); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new scannerOpenWithPrefix_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new scannerOpenWithPrefix_argsTupleSchemeFactory()); } /** * name of table */ public ByteBuffer tableName; // required /** * the prefix (and thus start row) of the keys you want */ public ByteBuffer startAndPrefix; // required /** * the columns you want returned */ public List<ByteBuffer> columns; // required /** * Scan attributes */ public Map<ByteBuffer,ByteBuffer> attributes; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * name of table */ TABLE_NAME((short)1, "tableName"), /** * the prefix (and thus start row) of the keys you want */ START_AND_PREFIX((short)2, "startAndPrefix"), /** * the columns you want returned */ COLUMNS((short)3, "columns"), /** * Scan attributes */ ATTRIBUTES((short)4, "attributes"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; case 2: // START_AND_PREFIX return START_AND_PREFIX; case 3: // COLUMNS return COLUMNS; case 4: // ATTRIBUTES return ATTRIBUTES; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.START_AND_PREFIX, new org.apache.thrift.meta_data.FieldMetaData("startAndPrefix", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.COLUMNS, new org.apache.thrift.meta_data.FieldMetaData("columns", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); tmpMap.put(_Fields.ATTRIBUTES, new org.apache.thrift.meta_data.FieldMetaData("attributes", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.MapMetaData(org.apache.thrift.protocol.TType.MAP, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"), new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(scannerOpenWithPrefix_args.class, metaDataMap); } public scannerOpenWithPrefix_args() { } public scannerOpenWithPrefix_args( ByteBuffer tableName, ByteBuffer startAndPrefix, List<ByteBuffer> columns, Map<ByteBuffer,ByteBuffer> attributes) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); this.startAndPrefix = org.apache.thrift.TBaseHelper.copyBinary(startAndPrefix); this.columns = columns; this.attributes = attributes; } /** * Performs a deep copy on <i>other</i>. */ public scannerOpenWithPrefix_args(scannerOpenWithPrefix_args other) { if (other.isSetTableName()) { this.tableName = other.tableName; } if (other.isSetStartAndPrefix()) { this.startAndPrefix = other.startAndPrefix; } if (other.isSetColumns()) { List<ByteBuffer> __this__columns = new ArrayList<ByteBuffer>(other.columns.size()); for (ByteBuffer other_element : other.columns) { __this__columns.add(other_element); } this.columns = __this__columns; } if (other.isSetAttributes()) { Map<ByteBuffer,ByteBuffer> __this__attributes = new HashMap<ByteBuffer,ByteBuffer>(other.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> other_element : other.attributes.entrySet()) { ByteBuffer other_element_key = other_element.getKey(); ByteBuffer other_element_value = other_element.getValue(); ByteBuffer __this__attributes_copy_key = other_element_key; ByteBuffer __this__attributes_copy_value = other_element_value; __this__attributes.put(__this__attributes_copy_key, __this__attributes_copy_value); } this.attributes = __this__attributes; } } public scannerOpenWithPrefix_args deepCopy() { return new scannerOpenWithPrefix_args(this); } @Override public void clear() { this.tableName = null; this.startAndPrefix = null; this.columns = null; this.attributes = null; } /** * name of table */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * name of table */ public scannerOpenWithPrefix_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public scannerOpenWithPrefix_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } /** * the prefix (and thus start row) of the keys you want */ public byte[] getStartAndPrefix() { setStartAndPrefix(org.apache.thrift.TBaseHelper.rightSize(startAndPrefix)); return startAndPrefix == null ? null : startAndPrefix.array(); } public ByteBuffer bufferForStartAndPrefix() { return org.apache.thrift.TBaseHelper.copyBinary(startAndPrefix); } /** * the prefix (and thus start row) of the keys you want */ public scannerOpenWithPrefix_args setStartAndPrefix(byte[] startAndPrefix) { this.startAndPrefix = startAndPrefix == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(startAndPrefix, startAndPrefix.length)); return this; } public scannerOpenWithPrefix_args setStartAndPrefix(ByteBuffer startAndPrefix) { this.startAndPrefix = org.apache.thrift.TBaseHelper.copyBinary(startAndPrefix); return this; } public void unsetStartAndPrefix() { this.startAndPrefix = null; } /** Returns true if field startAndPrefix is set (has been assigned a value) and false otherwise */ public boolean isSetStartAndPrefix() { return this.startAndPrefix != null; } public void setStartAndPrefixIsSet(boolean value) { if (!value) { this.startAndPrefix = null; } } public int getColumnsSize() { return (this.columns == null) ? 0 : this.columns.size(); } public java.util.Iterator<ByteBuffer> getColumnsIterator() { return (this.columns == null) ? null : this.columns.iterator(); } public void addToColumns(ByteBuffer elem) { if (this.columns == null) { this.columns = new ArrayList<ByteBuffer>(); } this.columns.add(elem); } /** * the columns you want returned */ public List<ByteBuffer> getColumns() { return this.columns; } /** * the columns you want returned */ public scannerOpenWithPrefix_args setColumns(List<ByteBuffer> columns) { this.columns = columns; return this; } public void unsetColumns() { this.columns = null; } /** Returns true if field columns is set (has been assigned a value) and false otherwise */ public boolean isSetColumns() { return this.columns != null; } public void setColumnsIsSet(boolean value) { if (!value) { this.columns = null; } } public int getAttributesSize() { return (this.attributes == null) ? 0 : this.attributes.size(); } public void putToAttributes(ByteBuffer key, ByteBuffer val) { if (this.attributes == null) { this.attributes = new HashMap<ByteBuffer,ByteBuffer>(); } this.attributes.put(key, val); } /** * Scan attributes */ public Map<ByteBuffer,ByteBuffer> getAttributes() { return this.attributes; } /** * Scan attributes */ public scannerOpenWithPrefix_args setAttributes(Map<ByteBuffer,ByteBuffer> attributes) { this.attributes = attributes; return this; } public void unsetAttributes() { this.attributes = null; } /** Returns true if field attributes is set (has been assigned a value) and false otherwise */ public boolean isSetAttributes() { return this.attributes != null; } public void setAttributesIsSet(boolean value) { if (!value) { this.attributes = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; case START_AND_PREFIX: if (value == null) { unsetStartAndPrefix(); } else { setStartAndPrefix((ByteBuffer)value); } break; case COLUMNS: if (value == null) { unsetColumns(); } else { setColumns((List<ByteBuffer>)value); } break; case ATTRIBUTES: if (value == null) { unsetAttributes(); } else { setAttributes((Map<ByteBuffer,ByteBuffer>)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); case START_AND_PREFIX: return getStartAndPrefix(); case COLUMNS: return getColumns(); case ATTRIBUTES: return getAttributes(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); case START_AND_PREFIX: return isSetStartAndPrefix(); case COLUMNS: return isSetColumns(); case ATTRIBUTES: return isSetAttributes(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof scannerOpenWithPrefix_args) return this.equals((scannerOpenWithPrefix_args)that); return false; } public boolean equals(scannerOpenWithPrefix_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } boolean this_present_startAndPrefix = true && this.isSetStartAndPrefix(); boolean that_present_startAndPrefix = true && that.isSetStartAndPrefix(); if (this_present_startAndPrefix || that_present_startAndPrefix) { if (!(this_present_startAndPrefix && that_present_startAndPrefix)) return false; if (!this.startAndPrefix.equals(that.startAndPrefix)) return false; } boolean this_present_columns = true && this.isSetColumns(); boolean that_present_columns = true && that.isSetColumns(); if (this_present_columns || that_present_columns) { if (!(this_present_columns && that_present_columns)) return false; if (!this.columns.equals(that.columns)) return false; } boolean this_present_attributes = true && this.isSetAttributes(); boolean that_present_attributes = true && that.isSetAttributes(); if (this_present_attributes || that_present_attributes) { if (!(this_present_attributes && that_present_attributes)) return false; if (!this.attributes.equals(that.attributes)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); boolean present_startAndPrefix = true && (isSetStartAndPrefix()); list.add(present_startAndPrefix); if (present_startAndPrefix) list.add(startAndPrefix); boolean present_columns = true && (isSetColumns()); list.add(present_columns); if (present_columns) list.add(columns); boolean present_attributes = true && (isSetAttributes()); list.add(present_attributes); if (present_attributes) list.add(attributes); return list.hashCode(); } @Override public int compareTo(scannerOpenWithPrefix_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetStartAndPrefix()).compareTo(other.isSetStartAndPrefix()); if (lastComparison != 0) { return lastComparison; } if (isSetStartAndPrefix()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.startAndPrefix, other.startAndPrefix); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetColumns()).compareTo(other.isSetColumns()); if (lastComparison != 0) { return lastComparison; } if (isSetColumns()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.columns, other.columns); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetAttributes()).compareTo(other.isSetAttributes()); if (lastComparison != 0) { return lastComparison; } if (isSetAttributes()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.attributes, other.attributes); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("scannerOpenWithPrefix_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; if (!first) sb.append(", "); sb.append("startAndPrefix:"); if (this.startAndPrefix == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.startAndPrefix, sb); } first = false; if (!first) sb.append(", "); sb.append("columns:"); if (this.columns == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.columns, sb); } first = false; if (!first) sb.append(", "); sb.append("attributes:"); if (this.attributes == null) { sb.append("null"); } else { sb.append(this.attributes); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class scannerOpenWithPrefix_argsStandardSchemeFactory implements SchemeFactory { public scannerOpenWithPrefix_argsStandardScheme getScheme() { return new scannerOpenWithPrefix_argsStandardScheme(); } } private static class scannerOpenWithPrefix_argsStandardScheme extends StandardScheme<scannerOpenWithPrefix_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, scannerOpenWithPrefix_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // START_AND_PREFIX if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.startAndPrefix = iprot.readBinary(); struct.setStartAndPrefixIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 3: // COLUMNS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list512 = iprot.readListBegin(); struct.columns = new ArrayList<ByteBuffer>(_list512.size); ByteBuffer _elem513; for (int _i514 = 0; _i514 < _list512.size; ++_i514) { _elem513 = iprot.readBinary(); struct.columns.add(_elem513); } iprot.readListEnd(); } struct.setColumnsIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 4: // ATTRIBUTES if (schemeField.type == org.apache.thrift.protocol.TType.MAP) { { org.apache.thrift.protocol.TMap _map515 = iprot.readMapBegin(); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map515.size); ByteBuffer _key516; ByteBuffer _val517; for (int _i518 = 0; _i518 < _map515.size; ++_i518) { _key516 = iprot.readBinary(); _val517 = iprot.readBinary(); struct.attributes.put(_key516, _val517); } iprot.readMapEnd(); } struct.setAttributesIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, scannerOpenWithPrefix_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } if (struct.startAndPrefix != null) { oprot.writeFieldBegin(START_AND_PREFIX_FIELD_DESC); oprot.writeBinary(struct.startAndPrefix); oprot.writeFieldEnd(); } if (struct.columns != null) { oprot.writeFieldBegin(COLUMNS_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.columns.size())); for (ByteBuffer _iter519 : struct.columns) { oprot.writeBinary(_iter519); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } if (struct.attributes != null) { oprot.writeFieldBegin(ATTRIBUTES_FIELD_DESC); { oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, struct.attributes.size())); for (Map.Entry<ByteBuffer, ByteBuffer> _iter520 : struct.attributes.entrySet()) { oprot.writeBinary(_iter520.getKey()); oprot.writeBinary(_iter520.getValue()); } oprot.writeMapEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class scannerOpenWithPrefix_argsTupleSchemeFactory implements SchemeFactory { public scannerOpenWithPrefix_argsTupleScheme getScheme() { return new scannerOpenWithPrefix_argsTupleScheme(); } } private static class scannerOpenWithPrefix_argsTupleScheme extends TupleScheme<scannerOpenWithPrefix_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, scannerOpenWithPrefix_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } if (struct.isSetStartAndPrefix()) { optionals.set(1); } if (struct.isSetColumns()) { optionals.set(2); } if (struct.isSetAttributes()) { optionals.set(3); } oprot.writeBitSet(optionals, 4); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } if (struct.isSetStartAndPrefix()) { oprot.writeBinary(struct.startAndPrefix); } if (struct.isSetColumns()) { { oprot.writeI32(struct.columns.size()); for (ByteBuffer _iter521 : struct.columns) { oprot.writeBinary(_iter521); } } } if (struct.isSetAttributes()) { { oprot.writeI32(struct.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> _iter522 : struct.attributes.entrySet()) { oprot.writeBinary(_iter522.getKey()); oprot.writeBinary(_iter522.getValue()); } } } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, scannerOpenWithPrefix_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(4); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } if (incoming.get(1)) { struct.startAndPrefix = iprot.readBinary(); struct.setStartAndPrefixIsSet(true); } if (incoming.get(2)) { { org.apache.thrift.protocol.TList _list523 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.columns = new ArrayList<ByteBuffer>(_list523.size); ByteBuffer _elem524; for (int _i525 = 0; _i525 < _list523.size; ++_i525) { _elem524 = iprot.readBinary(); struct.columns.add(_elem524); } } struct.setColumnsIsSet(true); } if (incoming.get(3)) { { org.apache.thrift.protocol.TMap _map526 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map526.size); ByteBuffer _key527; ByteBuffer _val528; for (int _i529 = 0; _i529 < _map526.size; ++_i529) { _key527 = iprot.readBinary(); _val528 = iprot.readBinary(); struct.attributes.put(_key527, _val528); } } struct.setAttributesIsSet(true); } } } } public static class scannerOpenWithPrefix_result implements org.apache.thrift.TBase<scannerOpenWithPrefix_result, scannerOpenWithPrefix_result._Fields>, java.io.Serializable, Cloneable, Comparable<scannerOpenWithPrefix_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("scannerOpenWithPrefix_result"); private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.I32, (short)0); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new scannerOpenWithPrefix_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new scannerOpenWithPrefix_resultTupleSchemeFactory()); } public int success; // required public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { SUCCESS((short)0, "success"), IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 0: // SUCCESS return SUCCESS; case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments private static final int __SUCCESS_ISSET_ID = 0; private byte __isset_bitfield = 0; public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.SUCCESS, new org.apache.thrift.meta_data.FieldMetaData("success", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.I32 , "ScannerID"))); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(scannerOpenWithPrefix_result.class, metaDataMap); } public scannerOpenWithPrefix_result() { } public scannerOpenWithPrefix_result( int success, IOError io) { this(); this.success = success; setSuccessIsSet(true); this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public scannerOpenWithPrefix_result(scannerOpenWithPrefix_result other) { __isset_bitfield = other.__isset_bitfield; this.success = other.success; if (other.isSetIo()) { this.io = new IOError(other.io); } } public scannerOpenWithPrefix_result deepCopy() { return new scannerOpenWithPrefix_result(this); } @Override public void clear() { setSuccessIsSet(false); this.success = 0; this.io = null; } public int getSuccess() { return this.success; } public scannerOpenWithPrefix_result setSuccess(int success) { this.success = success; setSuccessIsSet(true); return this; } public void unsetSuccess() { __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __SUCCESS_ISSET_ID); } /** Returns true if field success is set (has been assigned a value) and false otherwise */ public boolean isSetSuccess() { return EncodingUtils.testBit(__isset_bitfield, __SUCCESS_ISSET_ID); } public void setSuccessIsSet(boolean value) { __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __SUCCESS_ISSET_ID, value); } public IOError getIo() { return this.io; } public scannerOpenWithPrefix_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case SUCCESS: if (value == null) { unsetSuccess(); } else { setSuccess((Integer)value); } break; case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case SUCCESS: return getSuccess(); case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case SUCCESS: return isSetSuccess(); case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof scannerOpenWithPrefix_result) return this.equals((scannerOpenWithPrefix_result)that); return false; } public boolean equals(scannerOpenWithPrefix_result that) { if (that == null) return false; boolean this_present_success = true; boolean that_present_success = true; if (this_present_success || that_present_success) { if (!(this_present_success && that_present_success)) return false; if (this.success != that.success) return false; } boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_success = true; list.add(present_success); if (present_success) list.add(success); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(scannerOpenWithPrefix_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess()); if (lastComparison != 0) { return lastComparison; } if (isSetSuccess()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("scannerOpenWithPrefix_result("); boolean first = true; sb.append("success:"); sb.append(this.success); first = false; if (!first) sb.append(", "); sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { // it doesn't seem like you should have to do this, but java serialization is wacky, and doesn't call the default constructor. __isset_bitfield = 0; read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class scannerOpenWithPrefix_resultStandardSchemeFactory implements SchemeFactory { public scannerOpenWithPrefix_resultStandardScheme getScheme() { return new scannerOpenWithPrefix_resultStandardScheme(); } } private static class scannerOpenWithPrefix_resultStandardScheme extends StandardScheme<scannerOpenWithPrefix_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, scannerOpenWithPrefix_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.I32) { struct.success = iprot.readI32(); struct.setSuccessIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, scannerOpenWithPrefix_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.isSetSuccess()) { oprot.writeFieldBegin(SUCCESS_FIELD_DESC); oprot.writeI32(struct.success); oprot.writeFieldEnd(); } if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class scannerOpenWithPrefix_resultTupleSchemeFactory implements SchemeFactory { public scannerOpenWithPrefix_resultTupleScheme getScheme() { return new scannerOpenWithPrefix_resultTupleScheme(); } } private static class scannerOpenWithPrefix_resultTupleScheme extends TupleScheme<scannerOpenWithPrefix_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, scannerOpenWithPrefix_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetSuccess()) { optionals.set(0); } if (struct.isSetIo()) { optionals.set(1); } oprot.writeBitSet(optionals, 2); if (struct.isSetSuccess()) { oprot.writeI32(struct.success); } if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, scannerOpenWithPrefix_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { struct.success = iprot.readI32(); struct.setSuccessIsSet(true); } if (incoming.get(1)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class scannerOpenTs_args implements org.apache.thrift.TBase<scannerOpenTs_args, scannerOpenTs_args._Fields>, java.io.Serializable, Cloneable, Comparable<scannerOpenTs_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("scannerOpenTs_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final org.apache.thrift.protocol.TField START_ROW_FIELD_DESC = new org.apache.thrift.protocol.TField("startRow", org.apache.thrift.protocol.TType.STRING, (short)2); private static final org.apache.thrift.protocol.TField COLUMNS_FIELD_DESC = new org.apache.thrift.protocol.TField("columns", org.apache.thrift.protocol.TType.LIST, (short)3); private static final org.apache.thrift.protocol.TField TIMESTAMP_FIELD_DESC = new org.apache.thrift.protocol.TField("timestamp", org.apache.thrift.protocol.TType.I64, (short)4); private static final org.apache.thrift.protocol.TField ATTRIBUTES_FIELD_DESC = new org.apache.thrift.protocol.TField("attributes", org.apache.thrift.protocol.TType.MAP, (short)5); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new scannerOpenTs_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new scannerOpenTs_argsTupleSchemeFactory()); } /** * name of table */ public ByteBuffer tableName; // required /** * Starting row in table to scan. * Send "" (empty string) to start at the first row. */ public ByteBuffer startRow; // required /** * columns to scan. If column name is a column family, all * columns of the specified column family are returned. It's also possible * to pass a regex in the column qualifier. */ public List<ByteBuffer> columns; // required /** * timestamp */ public long timestamp; // required /** * Scan attributes */ public Map<ByteBuffer,ByteBuffer> attributes; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * name of table */ TABLE_NAME((short)1, "tableName"), /** * Starting row in table to scan. * Send "" (empty string) to start at the first row. */ START_ROW((short)2, "startRow"), /** * columns to scan. If column name is a column family, all * columns of the specified column family are returned. It's also possible * to pass a regex in the column qualifier. */ COLUMNS((short)3, "columns"), /** * timestamp */ TIMESTAMP((short)4, "timestamp"), /** * Scan attributes */ ATTRIBUTES((short)5, "attributes"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; case 2: // START_ROW return START_ROW; case 3: // COLUMNS return COLUMNS; case 4: // TIMESTAMP return TIMESTAMP; case 5: // ATTRIBUTES return ATTRIBUTES; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments private static final int __TIMESTAMP_ISSET_ID = 0; private byte __isset_bitfield = 0; public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.START_ROW, new org.apache.thrift.meta_data.FieldMetaData("startRow", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.COLUMNS, new org.apache.thrift.meta_data.FieldMetaData("columns", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); tmpMap.put(_Fields.TIMESTAMP, new org.apache.thrift.meta_data.FieldMetaData("timestamp", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.I64))); tmpMap.put(_Fields.ATTRIBUTES, new org.apache.thrift.meta_data.FieldMetaData("attributes", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.MapMetaData(org.apache.thrift.protocol.TType.MAP, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"), new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(scannerOpenTs_args.class, metaDataMap); } public scannerOpenTs_args() { } public scannerOpenTs_args( ByteBuffer tableName, ByteBuffer startRow, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); this.startRow = org.apache.thrift.TBaseHelper.copyBinary(startRow); this.columns = columns; this.timestamp = timestamp; setTimestampIsSet(true); this.attributes = attributes; } /** * Performs a deep copy on <i>other</i>. */ public scannerOpenTs_args(scannerOpenTs_args other) { __isset_bitfield = other.__isset_bitfield; if (other.isSetTableName()) { this.tableName = other.tableName; } if (other.isSetStartRow()) { this.startRow = other.startRow; } if (other.isSetColumns()) { List<ByteBuffer> __this__columns = new ArrayList<ByteBuffer>(other.columns.size()); for (ByteBuffer other_element : other.columns) { __this__columns.add(other_element); } this.columns = __this__columns; } this.timestamp = other.timestamp; if (other.isSetAttributes()) { Map<ByteBuffer,ByteBuffer> __this__attributes = new HashMap<ByteBuffer,ByteBuffer>(other.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> other_element : other.attributes.entrySet()) { ByteBuffer other_element_key = other_element.getKey(); ByteBuffer other_element_value = other_element.getValue(); ByteBuffer __this__attributes_copy_key = other_element_key; ByteBuffer __this__attributes_copy_value = other_element_value; __this__attributes.put(__this__attributes_copy_key, __this__attributes_copy_value); } this.attributes = __this__attributes; } } public scannerOpenTs_args deepCopy() { return new scannerOpenTs_args(this); } @Override public void clear() { this.tableName = null; this.startRow = null; this.columns = null; setTimestampIsSet(false); this.timestamp = 0; this.attributes = null; } /** * name of table */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * name of table */ public scannerOpenTs_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public scannerOpenTs_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } /** * Starting row in table to scan. * Send "" (empty string) to start at the first row. */ public byte[] getStartRow() { setStartRow(org.apache.thrift.TBaseHelper.rightSize(startRow)); return startRow == null ? null : startRow.array(); } public ByteBuffer bufferForStartRow() { return org.apache.thrift.TBaseHelper.copyBinary(startRow); } /** * Starting row in table to scan. * Send "" (empty string) to start at the first row. */ public scannerOpenTs_args setStartRow(byte[] startRow) { this.startRow = startRow == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(startRow, startRow.length)); return this; } public scannerOpenTs_args setStartRow(ByteBuffer startRow) { this.startRow = org.apache.thrift.TBaseHelper.copyBinary(startRow); return this; } public void unsetStartRow() { this.startRow = null; } /** Returns true if field startRow is set (has been assigned a value) and false otherwise */ public boolean isSetStartRow() { return this.startRow != null; } public void setStartRowIsSet(boolean value) { if (!value) { this.startRow = null; } } public int getColumnsSize() { return (this.columns == null) ? 0 : this.columns.size(); } public java.util.Iterator<ByteBuffer> getColumnsIterator() { return (this.columns == null) ? null : this.columns.iterator(); } public void addToColumns(ByteBuffer elem) { if (this.columns == null) { this.columns = new ArrayList<ByteBuffer>(); } this.columns.add(elem); } /** * columns to scan. If column name is a column family, all * columns of the specified column family are returned. It's also possible * to pass a regex in the column qualifier. */ public List<ByteBuffer> getColumns() { return this.columns; } /** * columns to scan. If column name is a column family, all * columns of the specified column family are returned. It's also possible * to pass a regex in the column qualifier. */ public scannerOpenTs_args setColumns(List<ByteBuffer> columns) { this.columns = columns; return this; } public void unsetColumns() { this.columns = null; } /** Returns true if field columns is set (has been assigned a value) and false otherwise */ public boolean isSetColumns() { return this.columns != null; } public void setColumnsIsSet(boolean value) { if (!value) { this.columns = null; } } /** * timestamp */ public long getTimestamp() { return this.timestamp; } /** * timestamp */ public scannerOpenTs_args setTimestamp(long timestamp) { this.timestamp = timestamp; setTimestampIsSet(true); return this; } public void unsetTimestamp() { __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __TIMESTAMP_ISSET_ID); } /** Returns true if field timestamp is set (has been assigned a value) and false otherwise */ public boolean isSetTimestamp() { return EncodingUtils.testBit(__isset_bitfield, __TIMESTAMP_ISSET_ID); } public void setTimestampIsSet(boolean value) { __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __TIMESTAMP_ISSET_ID, value); } public int getAttributesSize() { return (this.attributes == null) ? 0 : this.attributes.size(); } public void putToAttributes(ByteBuffer key, ByteBuffer val) { if (this.attributes == null) { this.attributes = new HashMap<ByteBuffer,ByteBuffer>(); } this.attributes.put(key, val); } /** * Scan attributes */ public Map<ByteBuffer,ByteBuffer> getAttributes() { return this.attributes; } /** * Scan attributes */ public scannerOpenTs_args setAttributes(Map<ByteBuffer,ByteBuffer> attributes) { this.attributes = attributes; return this; } public void unsetAttributes() { this.attributes = null; } /** Returns true if field attributes is set (has been assigned a value) and false otherwise */ public boolean isSetAttributes() { return this.attributes != null; } public void setAttributesIsSet(boolean value) { if (!value) { this.attributes = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; case START_ROW: if (value == null) { unsetStartRow(); } else { setStartRow((ByteBuffer)value); } break; case COLUMNS: if (value == null) { unsetColumns(); } else { setColumns((List<ByteBuffer>)value); } break; case TIMESTAMP: if (value == null) { unsetTimestamp(); } else { setTimestamp((Long)value); } break; case ATTRIBUTES: if (value == null) { unsetAttributes(); } else { setAttributes((Map<ByteBuffer,ByteBuffer>)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); case START_ROW: return getStartRow(); case COLUMNS: return getColumns(); case TIMESTAMP: return getTimestamp(); case ATTRIBUTES: return getAttributes(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); case START_ROW: return isSetStartRow(); case COLUMNS: return isSetColumns(); case TIMESTAMP: return isSetTimestamp(); case ATTRIBUTES: return isSetAttributes(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof scannerOpenTs_args) return this.equals((scannerOpenTs_args)that); return false; } public boolean equals(scannerOpenTs_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } boolean this_present_startRow = true && this.isSetStartRow(); boolean that_present_startRow = true && that.isSetStartRow(); if (this_present_startRow || that_present_startRow) { if (!(this_present_startRow && that_present_startRow)) return false; if (!this.startRow.equals(that.startRow)) return false; } boolean this_present_columns = true && this.isSetColumns(); boolean that_present_columns = true && that.isSetColumns(); if (this_present_columns || that_present_columns) { if (!(this_present_columns && that_present_columns)) return false; if (!this.columns.equals(that.columns)) return false; } boolean this_present_timestamp = true; boolean that_present_timestamp = true; if (this_present_timestamp || that_present_timestamp) { if (!(this_present_timestamp && that_present_timestamp)) return false; if (this.timestamp != that.timestamp) return false; } boolean this_present_attributes = true && this.isSetAttributes(); boolean that_present_attributes = true && that.isSetAttributes(); if (this_present_attributes || that_present_attributes) { if (!(this_present_attributes && that_present_attributes)) return false; if (!this.attributes.equals(that.attributes)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); boolean present_startRow = true && (isSetStartRow()); list.add(present_startRow); if (present_startRow) list.add(startRow); boolean present_columns = true && (isSetColumns()); list.add(present_columns); if (present_columns) list.add(columns); boolean present_timestamp = true; list.add(present_timestamp); if (present_timestamp) list.add(timestamp); boolean present_attributes = true && (isSetAttributes()); list.add(present_attributes); if (present_attributes) list.add(attributes); return list.hashCode(); } @Override public int compareTo(scannerOpenTs_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetStartRow()).compareTo(other.isSetStartRow()); if (lastComparison != 0) { return lastComparison; } if (isSetStartRow()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.startRow, other.startRow); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetColumns()).compareTo(other.isSetColumns()); if (lastComparison != 0) { return lastComparison; } if (isSetColumns()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.columns, other.columns); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetTimestamp()).compareTo(other.isSetTimestamp()); if (lastComparison != 0) { return lastComparison; } if (isSetTimestamp()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.timestamp, other.timestamp); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetAttributes()).compareTo(other.isSetAttributes()); if (lastComparison != 0) { return lastComparison; } if (isSetAttributes()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.attributes, other.attributes); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("scannerOpenTs_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; if (!first) sb.append(", "); sb.append("startRow:"); if (this.startRow == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.startRow, sb); } first = false; if (!first) sb.append(", "); sb.append("columns:"); if (this.columns == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.columns, sb); } first = false; if (!first) sb.append(", "); sb.append("timestamp:"); sb.append(this.timestamp); first = false; if (!first) sb.append(", "); sb.append("attributes:"); if (this.attributes == null) { sb.append("null"); } else { sb.append(this.attributes); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { // it doesn't seem like you should have to do this, but java serialization is wacky, and doesn't call the default constructor. __isset_bitfield = 0; read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class scannerOpenTs_argsStandardSchemeFactory implements SchemeFactory { public scannerOpenTs_argsStandardScheme getScheme() { return new scannerOpenTs_argsStandardScheme(); } } private static class scannerOpenTs_argsStandardScheme extends StandardScheme<scannerOpenTs_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, scannerOpenTs_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // START_ROW if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.startRow = iprot.readBinary(); struct.setStartRowIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 3: // COLUMNS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list530 = iprot.readListBegin(); struct.columns = new ArrayList<ByteBuffer>(_list530.size); ByteBuffer _elem531; for (int _i532 = 0; _i532 < _list530.size; ++_i532) { _elem531 = iprot.readBinary(); struct.columns.add(_elem531); } iprot.readListEnd(); } struct.setColumnsIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 4: // TIMESTAMP if (schemeField.type == org.apache.thrift.protocol.TType.I64) { struct.timestamp = iprot.readI64(); struct.setTimestampIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 5: // ATTRIBUTES if (schemeField.type == org.apache.thrift.protocol.TType.MAP) { { org.apache.thrift.protocol.TMap _map533 = iprot.readMapBegin(); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map533.size); ByteBuffer _key534; ByteBuffer _val535; for (int _i536 = 0; _i536 < _map533.size; ++_i536) { _key534 = iprot.readBinary(); _val535 = iprot.readBinary(); struct.attributes.put(_key534, _val535); } iprot.readMapEnd(); } struct.setAttributesIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, scannerOpenTs_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } if (struct.startRow != null) { oprot.writeFieldBegin(START_ROW_FIELD_DESC); oprot.writeBinary(struct.startRow); oprot.writeFieldEnd(); } if (struct.columns != null) { oprot.writeFieldBegin(COLUMNS_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.columns.size())); for (ByteBuffer _iter537 : struct.columns) { oprot.writeBinary(_iter537); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldBegin(TIMESTAMP_FIELD_DESC); oprot.writeI64(struct.timestamp); oprot.writeFieldEnd(); if (struct.attributes != null) { oprot.writeFieldBegin(ATTRIBUTES_FIELD_DESC); { oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, struct.attributes.size())); for (Map.Entry<ByteBuffer, ByteBuffer> _iter538 : struct.attributes.entrySet()) { oprot.writeBinary(_iter538.getKey()); oprot.writeBinary(_iter538.getValue()); } oprot.writeMapEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class scannerOpenTs_argsTupleSchemeFactory implements SchemeFactory { public scannerOpenTs_argsTupleScheme getScheme() { return new scannerOpenTs_argsTupleScheme(); } } private static class scannerOpenTs_argsTupleScheme extends TupleScheme<scannerOpenTs_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, scannerOpenTs_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } if (struct.isSetStartRow()) { optionals.set(1); } if (struct.isSetColumns()) { optionals.set(2); } if (struct.isSetTimestamp()) { optionals.set(3); } if (struct.isSetAttributes()) { optionals.set(4); } oprot.writeBitSet(optionals, 5); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } if (struct.isSetStartRow()) { oprot.writeBinary(struct.startRow); } if (struct.isSetColumns()) { { oprot.writeI32(struct.columns.size()); for (ByteBuffer _iter539 : struct.columns) { oprot.writeBinary(_iter539); } } } if (struct.isSetTimestamp()) { oprot.writeI64(struct.timestamp); } if (struct.isSetAttributes()) { { oprot.writeI32(struct.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> _iter540 : struct.attributes.entrySet()) { oprot.writeBinary(_iter540.getKey()); oprot.writeBinary(_iter540.getValue()); } } } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, scannerOpenTs_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(5); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } if (incoming.get(1)) { struct.startRow = iprot.readBinary(); struct.setStartRowIsSet(true); } if (incoming.get(2)) { { org.apache.thrift.protocol.TList _list541 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.columns = new ArrayList<ByteBuffer>(_list541.size); ByteBuffer _elem542; for (int _i543 = 0; _i543 < _list541.size; ++_i543) { _elem542 = iprot.readBinary(); struct.columns.add(_elem542); } } struct.setColumnsIsSet(true); } if (incoming.get(3)) { struct.timestamp = iprot.readI64(); struct.setTimestampIsSet(true); } if (incoming.get(4)) { { org.apache.thrift.protocol.TMap _map544 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map544.size); ByteBuffer _key545; ByteBuffer _val546; for (int _i547 = 0; _i547 < _map544.size; ++_i547) { _key545 = iprot.readBinary(); _val546 = iprot.readBinary(); struct.attributes.put(_key545, _val546); } } struct.setAttributesIsSet(true); } } } } public static class scannerOpenTs_result implements org.apache.thrift.TBase<scannerOpenTs_result, scannerOpenTs_result._Fields>, java.io.Serializable, Cloneable, Comparable<scannerOpenTs_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("scannerOpenTs_result"); private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.I32, (short)0); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new scannerOpenTs_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new scannerOpenTs_resultTupleSchemeFactory()); } public int success; // required public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { SUCCESS((short)0, "success"), IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 0: // SUCCESS return SUCCESS; case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments private static final int __SUCCESS_ISSET_ID = 0; private byte __isset_bitfield = 0; public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.SUCCESS, new org.apache.thrift.meta_data.FieldMetaData("success", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.I32 , "ScannerID"))); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(scannerOpenTs_result.class, metaDataMap); } public scannerOpenTs_result() { } public scannerOpenTs_result( int success, IOError io) { this(); this.success = success; setSuccessIsSet(true); this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public scannerOpenTs_result(scannerOpenTs_result other) { __isset_bitfield = other.__isset_bitfield; this.success = other.success; if (other.isSetIo()) { this.io = new IOError(other.io); } } public scannerOpenTs_result deepCopy() { return new scannerOpenTs_result(this); } @Override public void clear() { setSuccessIsSet(false); this.success = 0; this.io = null; } public int getSuccess() { return this.success; } public scannerOpenTs_result setSuccess(int success) { this.success = success; setSuccessIsSet(true); return this; } public void unsetSuccess() { __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __SUCCESS_ISSET_ID); } /** Returns true if field success is set (has been assigned a value) and false otherwise */ public boolean isSetSuccess() { return EncodingUtils.testBit(__isset_bitfield, __SUCCESS_ISSET_ID); } public void setSuccessIsSet(boolean value) { __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __SUCCESS_ISSET_ID, value); } public IOError getIo() { return this.io; } public scannerOpenTs_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case SUCCESS: if (value == null) { unsetSuccess(); } else { setSuccess((Integer)value); } break; case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case SUCCESS: return getSuccess(); case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case SUCCESS: return isSetSuccess(); case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof scannerOpenTs_result) return this.equals((scannerOpenTs_result)that); return false; } public boolean equals(scannerOpenTs_result that) { if (that == null) return false; boolean this_present_success = true; boolean that_present_success = true; if (this_present_success || that_present_success) { if (!(this_present_success && that_present_success)) return false; if (this.success != that.success) return false; } boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_success = true; list.add(present_success); if (present_success) list.add(success); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(scannerOpenTs_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess()); if (lastComparison != 0) { return lastComparison; } if (isSetSuccess()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("scannerOpenTs_result("); boolean first = true; sb.append("success:"); sb.append(this.success); first = false; if (!first) sb.append(", "); sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { // it doesn't seem like you should have to do this, but java serialization is wacky, and doesn't call the default constructor. __isset_bitfield = 0; read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class scannerOpenTs_resultStandardSchemeFactory implements SchemeFactory { public scannerOpenTs_resultStandardScheme getScheme() { return new scannerOpenTs_resultStandardScheme(); } } private static class scannerOpenTs_resultStandardScheme extends StandardScheme<scannerOpenTs_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, scannerOpenTs_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.I32) { struct.success = iprot.readI32(); struct.setSuccessIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, scannerOpenTs_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.isSetSuccess()) { oprot.writeFieldBegin(SUCCESS_FIELD_DESC); oprot.writeI32(struct.success); oprot.writeFieldEnd(); } if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class scannerOpenTs_resultTupleSchemeFactory implements SchemeFactory { public scannerOpenTs_resultTupleScheme getScheme() { return new scannerOpenTs_resultTupleScheme(); } } private static class scannerOpenTs_resultTupleScheme extends TupleScheme<scannerOpenTs_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, scannerOpenTs_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetSuccess()) { optionals.set(0); } if (struct.isSetIo()) { optionals.set(1); } oprot.writeBitSet(optionals, 2); if (struct.isSetSuccess()) { oprot.writeI32(struct.success); } if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, scannerOpenTs_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { struct.success = iprot.readI32(); struct.setSuccessIsSet(true); } if (incoming.get(1)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class scannerOpenWithStopTs_args implements org.apache.thrift.TBase<scannerOpenWithStopTs_args, scannerOpenWithStopTs_args._Fields>, java.io.Serializable, Cloneable, Comparable<scannerOpenWithStopTs_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("scannerOpenWithStopTs_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final org.apache.thrift.protocol.TField START_ROW_FIELD_DESC = new org.apache.thrift.protocol.TField("startRow", org.apache.thrift.protocol.TType.STRING, (short)2); private static final org.apache.thrift.protocol.TField STOP_ROW_FIELD_DESC = new org.apache.thrift.protocol.TField("stopRow", org.apache.thrift.protocol.TType.STRING, (short)3); private static final org.apache.thrift.protocol.TField COLUMNS_FIELD_DESC = new org.apache.thrift.protocol.TField("columns", org.apache.thrift.protocol.TType.LIST, (short)4); private static final org.apache.thrift.protocol.TField TIMESTAMP_FIELD_DESC = new org.apache.thrift.protocol.TField("timestamp", org.apache.thrift.protocol.TType.I64, (short)5); private static final org.apache.thrift.protocol.TField ATTRIBUTES_FIELD_DESC = new org.apache.thrift.protocol.TField("attributes", org.apache.thrift.protocol.TType.MAP, (short)6); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new scannerOpenWithStopTs_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new scannerOpenWithStopTs_argsTupleSchemeFactory()); } /** * name of table */ public ByteBuffer tableName; // required /** * Starting row in table to scan. * Send "" (empty string) to start at the first row. */ public ByteBuffer startRow; // required /** * row to stop scanning on. This row is *not* included in the * scanner's results */ public ByteBuffer stopRow; // required /** * columns to scan. If column name is a column family, all * columns of the specified column family are returned. It's also possible * to pass a regex in the column qualifier. */ public List<ByteBuffer> columns; // required /** * timestamp */ public long timestamp; // required /** * Scan attributes */ public Map<ByteBuffer,ByteBuffer> attributes; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * name of table */ TABLE_NAME((short)1, "tableName"), /** * Starting row in table to scan. * Send "" (empty string) to start at the first row. */ START_ROW((short)2, "startRow"), /** * row to stop scanning on. This row is *not* included in the * scanner's results */ STOP_ROW((short)3, "stopRow"), /** * columns to scan. If column name is a column family, all * columns of the specified column family are returned. It's also possible * to pass a regex in the column qualifier. */ COLUMNS((short)4, "columns"), /** * timestamp */ TIMESTAMP((short)5, "timestamp"), /** * Scan attributes */ ATTRIBUTES((short)6, "attributes"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; case 2: // START_ROW return START_ROW; case 3: // STOP_ROW return STOP_ROW; case 4: // COLUMNS return COLUMNS; case 5: // TIMESTAMP return TIMESTAMP; case 6: // ATTRIBUTES return ATTRIBUTES; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments private static final int __TIMESTAMP_ISSET_ID = 0; private byte __isset_bitfield = 0; public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.START_ROW, new org.apache.thrift.meta_data.FieldMetaData("startRow", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.STOP_ROW, new org.apache.thrift.meta_data.FieldMetaData("stopRow", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.COLUMNS, new org.apache.thrift.meta_data.FieldMetaData("columns", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); tmpMap.put(_Fields.TIMESTAMP, new org.apache.thrift.meta_data.FieldMetaData("timestamp", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.I64))); tmpMap.put(_Fields.ATTRIBUTES, new org.apache.thrift.meta_data.FieldMetaData("attributes", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.MapMetaData(org.apache.thrift.protocol.TType.MAP, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"), new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(scannerOpenWithStopTs_args.class, metaDataMap); } public scannerOpenWithStopTs_args() { } public scannerOpenWithStopTs_args( ByteBuffer tableName, ByteBuffer startRow, ByteBuffer stopRow, List<ByteBuffer> columns, long timestamp, Map<ByteBuffer,ByteBuffer> attributes) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); this.startRow = org.apache.thrift.TBaseHelper.copyBinary(startRow); this.stopRow = org.apache.thrift.TBaseHelper.copyBinary(stopRow); this.columns = columns; this.timestamp = timestamp; setTimestampIsSet(true); this.attributes = attributes; } /** * Performs a deep copy on <i>other</i>. */ public scannerOpenWithStopTs_args(scannerOpenWithStopTs_args other) { __isset_bitfield = other.__isset_bitfield; if (other.isSetTableName()) { this.tableName = other.tableName; } if (other.isSetStartRow()) { this.startRow = other.startRow; } if (other.isSetStopRow()) { this.stopRow = other.stopRow; } if (other.isSetColumns()) { List<ByteBuffer> __this__columns = new ArrayList<ByteBuffer>(other.columns.size()); for (ByteBuffer other_element : other.columns) { __this__columns.add(other_element); } this.columns = __this__columns; } this.timestamp = other.timestamp; if (other.isSetAttributes()) { Map<ByteBuffer,ByteBuffer> __this__attributes = new HashMap<ByteBuffer,ByteBuffer>(other.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> other_element : other.attributes.entrySet()) { ByteBuffer other_element_key = other_element.getKey(); ByteBuffer other_element_value = other_element.getValue(); ByteBuffer __this__attributes_copy_key = other_element_key; ByteBuffer __this__attributes_copy_value = other_element_value; __this__attributes.put(__this__attributes_copy_key, __this__attributes_copy_value); } this.attributes = __this__attributes; } } public scannerOpenWithStopTs_args deepCopy() { return new scannerOpenWithStopTs_args(this); } @Override public void clear() { this.tableName = null; this.startRow = null; this.stopRow = null; this.columns = null; setTimestampIsSet(false); this.timestamp = 0; this.attributes = null; } /** * name of table */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * name of table */ public scannerOpenWithStopTs_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public scannerOpenWithStopTs_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } /** * Starting row in table to scan. * Send "" (empty string) to start at the first row. */ public byte[] getStartRow() { setStartRow(org.apache.thrift.TBaseHelper.rightSize(startRow)); return startRow == null ? null : startRow.array(); } public ByteBuffer bufferForStartRow() { return org.apache.thrift.TBaseHelper.copyBinary(startRow); } /** * Starting row in table to scan. * Send "" (empty string) to start at the first row. */ public scannerOpenWithStopTs_args setStartRow(byte[] startRow) { this.startRow = startRow == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(startRow, startRow.length)); return this; } public scannerOpenWithStopTs_args setStartRow(ByteBuffer startRow) { this.startRow = org.apache.thrift.TBaseHelper.copyBinary(startRow); return this; } public void unsetStartRow() { this.startRow = null; } /** Returns true if field startRow is set (has been assigned a value) and false otherwise */ public boolean isSetStartRow() { return this.startRow != null; } public void setStartRowIsSet(boolean value) { if (!value) { this.startRow = null; } } /** * row to stop scanning on. This row is *not* included in the * scanner's results */ public byte[] getStopRow() { setStopRow(org.apache.thrift.TBaseHelper.rightSize(stopRow)); return stopRow == null ? null : stopRow.array(); } public ByteBuffer bufferForStopRow() { return org.apache.thrift.TBaseHelper.copyBinary(stopRow); } /** * row to stop scanning on. This row is *not* included in the * scanner's results */ public scannerOpenWithStopTs_args setStopRow(byte[] stopRow) { this.stopRow = stopRow == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(stopRow, stopRow.length)); return this; } public scannerOpenWithStopTs_args setStopRow(ByteBuffer stopRow) { this.stopRow = org.apache.thrift.TBaseHelper.copyBinary(stopRow); return this; } public void unsetStopRow() { this.stopRow = null; } /** Returns true if field stopRow is set (has been assigned a value) and false otherwise */ public boolean isSetStopRow() { return this.stopRow != null; } public void setStopRowIsSet(boolean value) { if (!value) { this.stopRow = null; } } public int getColumnsSize() { return (this.columns == null) ? 0 : this.columns.size(); } public java.util.Iterator<ByteBuffer> getColumnsIterator() { return (this.columns == null) ? null : this.columns.iterator(); } public void addToColumns(ByteBuffer elem) { if (this.columns == null) { this.columns = new ArrayList<ByteBuffer>(); } this.columns.add(elem); } /** * columns to scan. If column name is a column family, all * columns of the specified column family are returned. It's also possible * to pass a regex in the column qualifier. */ public List<ByteBuffer> getColumns() { return this.columns; } /** * columns to scan. If column name is a column family, all * columns of the specified column family are returned. It's also possible * to pass a regex in the column qualifier. */ public scannerOpenWithStopTs_args setColumns(List<ByteBuffer> columns) { this.columns = columns; return this; } public void unsetColumns() { this.columns = null; } /** Returns true if field columns is set (has been assigned a value) and false otherwise */ public boolean isSetColumns() { return this.columns != null; } public void setColumnsIsSet(boolean value) { if (!value) { this.columns = null; } } /** * timestamp */ public long getTimestamp() { return this.timestamp; } /** * timestamp */ public scannerOpenWithStopTs_args setTimestamp(long timestamp) { this.timestamp = timestamp; setTimestampIsSet(true); return this; } public void unsetTimestamp() { __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __TIMESTAMP_ISSET_ID); } /** Returns true if field timestamp is set (has been assigned a value) and false otherwise */ public boolean isSetTimestamp() { return EncodingUtils.testBit(__isset_bitfield, __TIMESTAMP_ISSET_ID); } public void setTimestampIsSet(boolean value) { __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __TIMESTAMP_ISSET_ID, value); } public int getAttributesSize() { return (this.attributes == null) ? 0 : this.attributes.size(); } public void putToAttributes(ByteBuffer key, ByteBuffer val) { if (this.attributes == null) { this.attributes = new HashMap<ByteBuffer,ByteBuffer>(); } this.attributes.put(key, val); } /** * Scan attributes */ public Map<ByteBuffer,ByteBuffer> getAttributes() { return this.attributes; } /** * Scan attributes */ public scannerOpenWithStopTs_args setAttributes(Map<ByteBuffer,ByteBuffer> attributes) { this.attributes = attributes; return this; } public void unsetAttributes() { this.attributes = null; } /** Returns true if field attributes is set (has been assigned a value) and false otherwise */ public boolean isSetAttributes() { return this.attributes != null; } public void setAttributesIsSet(boolean value) { if (!value) { this.attributes = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; case START_ROW: if (value == null) { unsetStartRow(); } else { setStartRow((ByteBuffer)value); } break; case STOP_ROW: if (value == null) { unsetStopRow(); } else { setStopRow((ByteBuffer)value); } break; case COLUMNS: if (value == null) { unsetColumns(); } else { setColumns((List<ByteBuffer>)value); } break; case TIMESTAMP: if (value == null) { unsetTimestamp(); } else { setTimestamp((Long)value); } break; case ATTRIBUTES: if (value == null) { unsetAttributes(); } else { setAttributes((Map<ByteBuffer,ByteBuffer>)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); case START_ROW: return getStartRow(); case STOP_ROW: return getStopRow(); case COLUMNS: return getColumns(); case TIMESTAMP: return getTimestamp(); case ATTRIBUTES: return getAttributes(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); case START_ROW: return isSetStartRow(); case STOP_ROW: return isSetStopRow(); case COLUMNS: return isSetColumns(); case TIMESTAMP: return isSetTimestamp(); case ATTRIBUTES: return isSetAttributes(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof scannerOpenWithStopTs_args) return this.equals((scannerOpenWithStopTs_args)that); return false; } public boolean equals(scannerOpenWithStopTs_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } boolean this_present_startRow = true && this.isSetStartRow(); boolean that_present_startRow = true && that.isSetStartRow(); if (this_present_startRow || that_present_startRow) { if (!(this_present_startRow && that_present_startRow)) return false; if (!this.startRow.equals(that.startRow)) return false; } boolean this_present_stopRow = true && this.isSetStopRow(); boolean that_present_stopRow = true && that.isSetStopRow(); if (this_present_stopRow || that_present_stopRow) { if (!(this_present_stopRow && that_present_stopRow)) return false; if (!this.stopRow.equals(that.stopRow)) return false; } boolean this_present_columns = true && this.isSetColumns(); boolean that_present_columns = true && that.isSetColumns(); if (this_present_columns || that_present_columns) { if (!(this_present_columns && that_present_columns)) return false; if (!this.columns.equals(that.columns)) return false; } boolean this_present_timestamp = true; boolean that_present_timestamp = true; if (this_present_timestamp || that_present_timestamp) { if (!(this_present_timestamp && that_present_timestamp)) return false; if (this.timestamp != that.timestamp) return false; } boolean this_present_attributes = true && this.isSetAttributes(); boolean that_present_attributes = true && that.isSetAttributes(); if (this_present_attributes || that_present_attributes) { if (!(this_present_attributes && that_present_attributes)) return false; if (!this.attributes.equals(that.attributes)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); boolean present_startRow = true && (isSetStartRow()); list.add(present_startRow); if (present_startRow) list.add(startRow); boolean present_stopRow = true && (isSetStopRow()); list.add(present_stopRow); if (present_stopRow) list.add(stopRow); boolean present_columns = true && (isSetColumns()); list.add(present_columns); if (present_columns) list.add(columns); boolean present_timestamp = true; list.add(present_timestamp); if (present_timestamp) list.add(timestamp); boolean present_attributes = true && (isSetAttributes()); list.add(present_attributes); if (present_attributes) list.add(attributes); return list.hashCode(); } @Override public int compareTo(scannerOpenWithStopTs_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetStartRow()).compareTo(other.isSetStartRow()); if (lastComparison != 0) { return lastComparison; } if (isSetStartRow()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.startRow, other.startRow); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetStopRow()).compareTo(other.isSetStopRow()); if (lastComparison != 0) { return lastComparison; } if (isSetStopRow()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.stopRow, other.stopRow); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetColumns()).compareTo(other.isSetColumns()); if (lastComparison != 0) { return lastComparison; } if (isSetColumns()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.columns, other.columns); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetTimestamp()).compareTo(other.isSetTimestamp()); if (lastComparison != 0) { return lastComparison; } if (isSetTimestamp()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.timestamp, other.timestamp); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetAttributes()).compareTo(other.isSetAttributes()); if (lastComparison != 0) { return lastComparison; } if (isSetAttributes()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.attributes, other.attributes); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("scannerOpenWithStopTs_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; if (!first) sb.append(", "); sb.append("startRow:"); if (this.startRow == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.startRow, sb); } first = false; if (!first) sb.append(", "); sb.append("stopRow:"); if (this.stopRow == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.stopRow, sb); } first = false; if (!first) sb.append(", "); sb.append("columns:"); if (this.columns == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.columns, sb); } first = false; if (!first) sb.append(", "); sb.append("timestamp:"); sb.append(this.timestamp); first = false; if (!first) sb.append(", "); sb.append("attributes:"); if (this.attributes == null) { sb.append("null"); } else { sb.append(this.attributes); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { // it doesn't seem like you should have to do this, but java serialization is wacky, and doesn't call the default constructor. __isset_bitfield = 0; read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class scannerOpenWithStopTs_argsStandardSchemeFactory implements SchemeFactory { public scannerOpenWithStopTs_argsStandardScheme getScheme() { return new scannerOpenWithStopTs_argsStandardScheme(); } } private static class scannerOpenWithStopTs_argsStandardScheme extends StandardScheme<scannerOpenWithStopTs_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, scannerOpenWithStopTs_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // START_ROW if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.startRow = iprot.readBinary(); struct.setStartRowIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 3: // STOP_ROW if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.stopRow = iprot.readBinary(); struct.setStopRowIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 4: // COLUMNS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list548 = iprot.readListBegin(); struct.columns = new ArrayList<ByteBuffer>(_list548.size); ByteBuffer _elem549; for (int _i550 = 0; _i550 < _list548.size; ++_i550) { _elem549 = iprot.readBinary(); struct.columns.add(_elem549); } iprot.readListEnd(); } struct.setColumnsIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 5: // TIMESTAMP if (schemeField.type == org.apache.thrift.protocol.TType.I64) { struct.timestamp = iprot.readI64(); struct.setTimestampIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 6: // ATTRIBUTES if (schemeField.type == org.apache.thrift.protocol.TType.MAP) { { org.apache.thrift.protocol.TMap _map551 = iprot.readMapBegin(); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map551.size); ByteBuffer _key552; ByteBuffer _val553; for (int _i554 = 0; _i554 < _map551.size; ++_i554) { _key552 = iprot.readBinary(); _val553 = iprot.readBinary(); struct.attributes.put(_key552, _val553); } iprot.readMapEnd(); } struct.setAttributesIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, scannerOpenWithStopTs_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } if (struct.startRow != null) { oprot.writeFieldBegin(START_ROW_FIELD_DESC); oprot.writeBinary(struct.startRow); oprot.writeFieldEnd(); } if (struct.stopRow != null) { oprot.writeFieldBegin(STOP_ROW_FIELD_DESC); oprot.writeBinary(struct.stopRow); oprot.writeFieldEnd(); } if (struct.columns != null) { oprot.writeFieldBegin(COLUMNS_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.columns.size())); for (ByteBuffer _iter555 : struct.columns) { oprot.writeBinary(_iter555); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldBegin(TIMESTAMP_FIELD_DESC); oprot.writeI64(struct.timestamp); oprot.writeFieldEnd(); if (struct.attributes != null) { oprot.writeFieldBegin(ATTRIBUTES_FIELD_DESC); { oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, struct.attributes.size())); for (Map.Entry<ByteBuffer, ByteBuffer> _iter556 : struct.attributes.entrySet()) { oprot.writeBinary(_iter556.getKey()); oprot.writeBinary(_iter556.getValue()); } oprot.writeMapEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class scannerOpenWithStopTs_argsTupleSchemeFactory implements SchemeFactory { public scannerOpenWithStopTs_argsTupleScheme getScheme() { return new scannerOpenWithStopTs_argsTupleScheme(); } } private static class scannerOpenWithStopTs_argsTupleScheme extends TupleScheme<scannerOpenWithStopTs_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, scannerOpenWithStopTs_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } if (struct.isSetStartRow()) { optionals.set(1); } if (struct.isSetStopRow()) { optionals.set(2); } if (struct.isSetColumns()) { optionals.set(3); } if (struct.isSetTimestamp()) { optionals.set(4); } if (struct.isSetAttributes()) { optionals.set(5); } oprot.writeBitSet(optionals, 6); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } if (struct.isSetStartRow()) { oprot.writeBinary(struct.startRow); } if (struct.isSetStopRow()) { oprot.writeBinary(struct.stopRow); } if (struct.isSetColumns()) { { oprot.writeI32(struct.columns.size()); for (ByteBuffer _iter557 : struct.columns) { oprot.writeBinary(_iter557); } } } if (struct.isSetTimestamp()) { oprot.writeI64(struct.timestamp); } if (struct.isSetAttributes()) { { oprot.writeI32(struct.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> _iter558 : struct.attributes.entrySet()) { oprot.writeBinary(_iter558.getKey()); oprot.writeBinary(_iter558.getValue()); } } } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, scannerOpenWithStopTs_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(6); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } if (incoming.get(1)) { struct.startRow = iprot.readBinary(); struct.setStartRowIsSet(true); } if (incoming.get(2)) { struct.stopRow = iprot.readBinary(); struct.setStopRowIsSet(true); } if (incoming.get(3)) { { org.apache.thrift.protocol.TList _list559 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.columns = new ArrayList<ByteBuffer>(_list559.size); ByteBuffer _elem560; for (int _i561 = 0; _i561 < _list559.size; ++_i561) { _elem560 = iprot.readBinary(); struct.columns.add(_elem560); } } struct.setColumnsIsSet(true); } if (incoming.get(4)) { struct.timestamp = iprot.readI64(); struct.setTimestampIsSet(true); } if (incoming.get(5)) { { org.apache.thrift.protocol.TMap _map562 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map562.size); ByteBuffer _key563; ByteBuffer _val564; for (int _i565 = 0; _i565 < _map562.size; ++_i565) { _key563 = iprot.readBinary(); _val564 = iprot.readBinary(); struct.attributes.put(_key563, _val564); } } struct.setAttributesIsSet(true); } } } } public static class scannerOpenWithStopTs_result implements org.apache.thrift.TBase<scannerOpenWithStopTs_result, scannerOpenWithStopTs_result._Fields>, java.io.Serializable, Cloneable, Comparable<scannerOpenWithStopTs_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("scannerOpenWithStopTs_result"); private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.I32, (short)0); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new scannerOpenWithStopTs_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new scannerOpenWithStopTs_resultTupleSchemeFactory()); } public int success; // required public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { SUCCESS((short)0, "success"), IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 0: // SUCCESS return SUCCESS; case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments private static final int __SUCCESS_ISSET_ID = 0; private byte __isset_bitfield = 0; public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.SUCCESS, new org.apache.thrift.meta_data.FieldMetaData("success", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.I32 , "ScannerID"))); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(scannerOpenWithStopTs_result.class, metaDataMap); } public scannerOpenWithStopTs_result() { } public scannerOpenWithStopTs_result( int success, IOError io) { this(); this.success = success; setSuccessIsSet(true); this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public scannerOpenWithStopTs_result(scannerOpenWithStopTs_result other) { __isset_bitfield = other.__isset_bitfield; this.success = other.success; if (other.isSetIo()) { this.io = new IOError(other.io); } } public scannerOpenWithStopTs_result deepCopy() { return new scannerOpenWithStopTs_result(this); } @Override public void clear() { setSuccessIsSet(false); this.success = 0; this.io = null; } public int getSuccess() { return this.success; } public scannerOpenWithStopTs_result setSuccess(int success) { this.success = success; setSuccessIsSet(true); return this; } public void unsetSuccess() { __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __SUCCESS_ISSET_ID); } /** Returns true if field success is set (has been assigned a value) and false otherwise */ public boolean isSetSuccess() { return EncodingUtils.testBit(__isset_bitfield, __SUCCESS_ISSET_ID); } public void setSuccessIsSet(boolean value) { __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __SUCCESS_ISSET_ID, value); } public IOError getIo() { return this.io; } public scannerOpenWithStopTs_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case SUCCESS: if (value == null) { unsetSuccess(); } else { setSuccess((Integer)value); } break; case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case SUCCESS: return getSuccess(); case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case SUCCESS: return isSetSuccess(); case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof scannerOpenWithStopTs_result) return this.equals((scannerOpenWithStopTs_result)that); return false; } public boolean equals(scannerOpenWithStopTs_result that) { if (that == null) return false; boolean this_present_success = true; boolean that_present_success = true; if (this_present_success || that_present_success) { if (!(this_present_success && that_present_success)) return false; if (this.success != that.success) return false; } boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_success = true; list.add(present_success); if (present_success) list.add(success); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(scannerOpenWithStopTs_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess()); if (lastComparison != 0) { return lastComparison; } if (isSetSuccess()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("scannerOpenWithStopTs_result("); boolean first = true; sb.append("success:"); sb.append(this.success); first = false; if (!first) sb.append(", "); sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { // it doesn't seem like you should have to do this, but java serialization is wacky, and doesn't call the default constructor. __isset_bitfield = 0; read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class scannerOpenWithStopTs_resultStandardSchemeFactory implements SchemeFactory { public scannerOpenWithStopTs_resultStandardScheme getScheme() { return new scannerOpenWithStopTs_resultStandardScheme(); } } private static class scannerOpenWithStopTs_resultStandardScheme extends StandardScheme<scannerOpenWithStopTs_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, scannerOpenWithStopTs_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.I32) { struct.success = iprot.readI32(); struct.setSuccessIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, scannerOpenWithStopTs_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.isSetSuccess()) { oprot.writeFieldBegin(SUCCESS_FIELD_DESC); oprot.writeI32(struct.success); oprot.writeFieldEnd(); } if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class scannerOpenWithStopTs_resultTupleSchemeFactory implements SchemeFactory { public scannerOpenWithStopTs_resultTupleScheme getScheme() { return new scannerOpenWithStopTs_resultTupleScheme(); } } private static class scannerOpenWithStopTs_resultTupleScheme extends TupleScheme<scannerOpenWithStopTs_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, scannerOpenWithStopTs_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetSuccess()) { optionals.set(0); } if (struct.isSetIo()) { optionals.set(1); } oprot.writeBitSet(optionals, 2); if (struct.isSetSuccess()) { oprot.writeI32(struct.success); } if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, scannerOpenWithStopTs_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { struct.success = iprot.readI32(); struct.setSuccessIsSet(true); } if (incoming.get(1)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class scannerGet_args implements org.apache.thrift.TBase<scannerGet_args, scannerGet_args._Fields>, java.io.Serializable, Cloneable, Comparable<scannerGet_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("scannerGet_args"); private static final org.apache.thrift.protocol.TField ID_FIELD_DESC = new org.apache.thrift.protocol.TField("id", org.apache.thrift.protocol.TType.I32, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new scannerGet_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new scannerGet_argsTupleSchemeFactory()); } /** * id of a scanner returned by scannerOpen */ public int id; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * id of a scanner returned by scannerOpen */ ID((short)1, "id"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // ID return ID; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments private static final int __ID_ISSET_ID = 0; private byte __isset_bitfield = 0; public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.ID, new org.apache.thrift.meta_data.FieldMetaData("id", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.I32 , "ScannerID"))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(scannerGet_args.class, metaDataMap); } public scannerGet_args() { } public scannerGet_args( int id) { this(); this.id = id; setIdIsSet(true); } /** * Performs a deep copy on <i>other</i>. */ public scannerGet_args(scannerGet_args other) { __isset_bitfield = other.__isset_bitfield; this.id = other.id; } public scannerGet_args deepCopy() { return new scannerGet_args(this); } @Override public void clear() { setIdIsSet(false); this.id = 0; } /** * id of a scanner returned by scannerOpen */ public int getId() { return this.id; } /** * id of a scanner returned by scannerOpen */ public scannerGet_args setId(int id) { this.id = id; setIdIsSet(true); return this; } public void unsetId() { __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __ID_ISSET_ID); } /** Returns true if field id is set (has been assigned a value) and false otherwise */ public boolean isSetId() { return EncodingUtils.testBit(__isset_bitfield, __ID_ISSET_ID); } public void setIdIsSet(boolean value) { __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __ID_ISSET_ID, value); } public void setFieldValue(_Fields field, Object value) { switch (field) { case ID: if (value == null) { unsetId(); } else { setId((Integer)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case ID: return getId(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case ID: return isSetId(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof scannerGet_args) return this.equals((scannerGet_args)that); return false; } public boolean equals(scannerGet_args that) { if (that == null) return false; boolean this_present_id = true; boolean that_present_id = true; if (this_present_id || that_present_id) { if (!(this_present_id && that_present_id)) return false; if (this.id != that.id) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_id = true; list.add(present_id); if (present_id) list.add(id); return list.hashCode(); } @Override public int compareTo(scannerGet_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetId()).compareTo(other.isSetId()); if (lastComparison != 0) { return lastComparison; } if (isSetId()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.id, other.id); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("scannerGet_args("); boolean first = true; sb.append("id:"); sb.append(this.id); first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { // it doesn't seem like you should have to do this, but java serialization is wacky, and doesn't call the default constructor. __isset_bitfield = 0; read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class scannerGet_argsStandardSchemeFactory implements SchemeFactory { public scannerGet_argsStandardScheme getScheme() { return new scannerGet_argsStandardScheme(); } } private static class scannerGet_argsStandardScheme extends StandardScheme<scannerGet_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, scannerGet_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // ID if (schemeField.type == org.apache.thrift.protocol.TType.I32) { struct.id = iprot.readI32(); struct.setIdIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, scannerGet_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); oprot.writeFieldBegin(ID_FIELD_DESC); oprot.writeI32(struct.id); oprot.writeFieldEnd(); oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class scannerGet_argsTupleSchemeFactory implements SchemeFactory { public scannerGet_argsTupleScheme getScheme() { return new scannerGet_argsTupleScheme(); } } private static class scannerGet_argsTupleScheme extends TupleScheme<scannerGet_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, scannerGet_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetId()) { optionals.set(0); } oprot.writeBitSet(optionals, 1); if (struct.isSetId()) { oprot.writeI32(struct.id); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, scannerGet_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(1); if (incoming.get(0)) { struct.id = iprot.readI32(); struct.setIdIsSet(true); } } } } public static class scannerGet_result implements org.apache.thrift.TBase<scannerGet_result, scannerGet_result._Fields>, java.io.Serializable, Cloneable, Comparable<scannerGet_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("scannerGet_result"); private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.LIST, (short)0); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final org.apache.thrift.protocol.TField IA_FIELD_DESC = new org.apache.thrift.protocol.TField("ia", org.apache.thrift.protocol.TType.STRUCT, (short)2); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new scannerGet_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new scannerGet_resultTupleSchemeFactory()); } public List<TRowResult> success; // required public IOError io; // required public IllegalArgument ia; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { SUCCESS((short)0, "success"), IO((short)1, "io"), IA((short)2, "ia"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 0: // SUCCESS return SUCCESS; case 1: // IO return IO; case 2: // IA return IA; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.SUCCESS, new org.apache.thrift.meta_data.FieldMetaData("success", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, TRowResult.class)))); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); tmpMap.put(_Fields.IA, new org.apache.thrift.meta_data.FieldMetaData("ia", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(scannerGet_result.class, metaDataMap); } public scannerGet_result() { } public scannerGet_result( List<TRowResult> success, IOError io, IllegalArgument ia) { this(); this.success = success; this.io = io; this.ia = ia; } /** * Performs a deep copy on <i>other</i>. */ public scannerGet_result(scannerGet_result other) { if (other.isSetSuccess()) { List<TRowResult> __this__success = new ArrayList<TRowResult>(other.success.size()); for (TRowResult other_element : other.success) { __this__success.add(new TRowResult(other_element)); } this.success = __this__success; } if (other.isSetIo()) { this.io = new IOError(other.io); } if (other.isSetIa()) { this.ia = new IllegalArgument(other.ia); } } public scannerGet_result deepCopy() { return new scannerGet_result(this); } @Override public void clear() { this.success = null; this.io = null; this.ia = null; } public int getSuccessSize() { return (this.success == null) ? 0 : this.success.size(); } public java.util.Iterator<TRowResult> getSuccessIterator() { return (this.success == null) ? null : this.success.iterator(); } public void addToSuccess(TRowResult elem) { if (this.success == null) { this.success = new ArrayList<TRowResult>(); } this.success.add(elem); } public List<TRowResult> getSuccess() { return this.success; } public scannerGet_result setSuccess(List<TRowResult> success) { this.success = success; return this; } public void unsetSuccess() { this.success = null; } /** Returns true if field success is set (has been assigned a value) and false otherwise */ public boolean isSetSuccess() { return this.success != null; } public void setSuccessIsSet(boolean value) { if (!value) { this.success = null; } } public IOError getIo() { return this.io; } public scannerGet_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public IllegalArgument getIa() { return this.ia; } public scannerGet_result setIa(IllegalArgument ia) { this.ia = ia; return this; } public void unsetIa() { this.ia = null; } /** Returns true if field ia is set (has been assigned a value) and false otherwise */ public boolean isSetIa() { return this.ia != null; } public void setIaIsSet(boolean value) { if (!value) { this.ia = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case SUCCESS: if (value == null) { unsetSuccess(); } else { setSuccess((List<TRowResult>)value); } break; case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; case IA: if (value == null) { unsetIa(); } else { setIa((IllegalArgument)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case SUCCESS: return getSuccess(); case IO: return getIo(); case IA: return getIa(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case SUCCESS: return isSetSuccess(); case IO: return isSetIo(); case IA: return isSetIa(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof scannerGet_result) return this.equals((scannerGet_result)that); return false; } public boolean equals(scannerGet_result that) { if (that == null) return false; boolean this_present_success = true && this.isSetSuccess(); boolean that_present_success = true && that.isSetSuccess(); if (this_present_success || that_present_success) { if (!(this_present_success && that_present_success)) return false; if (!this.success.equals(that.success)) return false; } boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } boolean this_present_ia = true && this.isSetIa(); boolean that_present_ia = true && that.isSetIa(); if (this_present_ia || that_present_ia) { if (!(this_present_ia && that_present_ia)) return false; if (!this.ia.equals(that.ia)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_success = true && (isSetSuccess()); list.add(present_success); if (present_success) list.add(success); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); boolean present_ia = true && (isSetIa()); list.add(present_ia); if (present_ia) list.add(ia); return list.hashCode(); } @Override public int compareTo(scannerGet_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess()); if (lastComparison != 0) { return lastComparison; } if (isSetSuccess()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIa()).compareTo(other.isSetIa()); if (lastComparison != 0) { return lastComparison; } if (isSetIa()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ia, other.ia); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("scannerGet_result("); boolean first = true; sb.append("success:"); if (this.success == null) { sb.append("null"); } else { sb.append(this.success); } first = false; if (!first) sb.append(", "); sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; if (!first) sb.append(", "); sb.append("ia:"); if (this.ia == null) { sb.append("null"); } else { sb.append(this.ia); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class scannerGet_resultStandardSchemeFactory implements SchemeFactory { public scannerGet_resultStandardScheme getScheme() { return new scannerGet_resultStandardScheme(); } } private static class scannerGet_resultStandardScheme extends StandardScheme<scannerGet_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, scannerGet_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list566 = iprot.readListBegin(); struct.success = new ArrayList<TRowResult>(_list566.size); TRowResult _elem567; for (int _i568 = 0; _i568 < _list566.size; ++_i568) { _elem567 = new TRowResult(); _elem567.read(iprot); struct.success.add(_elem567); } iprot.readListEnd(); } struct.setSuccessIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // IA if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.ia = new IllegalArgument(); struct.ia.read(iprot); struct.setIaIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, scannerGet_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.success != null) { oprot.writeFieldBegin(SUCCESS_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size())); for (TRowResult _iter569 : struct.success) { _iter569.write(oprot); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } if (struct.ia != null) { oprot.writeFieldBegin(IA_FIELD_DESC); struct.ia.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class scannerGet_resultTupleSchemeFactory implements SchemeFactory { public scannerGet_resultTupleScheme getScheme() { return new scannerGet_resultTupleScheme(); } } private static class scannerGet_resultTupleScheme extends TupleScheme<scannerGet_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, scannerGet_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetSuccess()) { optionals.set(0); } if (struct.isSetIo()) { optionals.set(1); } if (struct.isSetIa()) { optionals.set(2); } oprot.writeBitSet(optionals, 3); if (struct.isSetSuccess()) { { oprot.writeI32(struct.success.size()); for (TRowResult _iter570 : struct.success) { _iter570.write(oprot); } } } if (struct.isSetIo()) { struct.io.write(oprot); } if (struct.isSetIa()) { struct.ia.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, scannerGet_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(3); if (incoming.get(0)) { { org.apache.thrift.protocol.TList _list571 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32()); struct.success = new ArrayList<TRowResult>(_list571.size); TRowResult _elem572; for (int _i573 = 0; _i573 < _list571.size; ++_i573) { _elem572 = new TRowResult(); _elem572.read(iprot); struct.success.add(_elem572); } } struct.setSuccessIsSet(true); } if (incoming.get(1)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } if (incoming.get(2)) { struct.ia = new IllegalArgument(); struct.ia.read(iprot); struct.setIaIsSet(true); } } } } public static class scannerGetList_args implements org.apache.thrift.TBase<scannerGetList_args, scannerGetList_args._Fields>, java.io.Serializable, Cloneable, Comparable<scannerGetList_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("scannerGetList_args"); private static final org.apache.thrift.protocol.TField ID_FIELD_DESC = new org.apache.thrift.protocol.TField("id", org.apache.thrift.protocol.TType.I32, (short)1); private static final org.apache.thrift.protocol.TField NB_ROWS_FIELD_DESC = new org.apache.thrift.protocol.TField("nbRows", org.apache.thrift.protocol.TType.I32, (short)2); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new scannerGetList_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new scannerGetList_argsTupleSchemeFactory()); } /** * id of a scanner returned by scannerOpen */ public int id; // required /** * number of results to return */ public int nbRows; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * id of a scanner returned by scannerOpen */ ID((short)1, "id"), /** * number of results to return */ NB_ROWS((short)2, "nbRows"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // ID return ID; case 2: // NB_ROWS return NB_ROWS; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments private static final int __ID_ISSET_ID = 0; private static final int __NBROWS_ISSET_ID = 1; private byte __isset_bitfield = 0; public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.ID, new org.apache.thrift.meta_data.FieldMetaData("id", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.I32 , "ScannerID"))); tmpMap.put(_Fields.NB_ROWS, new org.apache.thrift.meta_data.FieldMetaData("nbRows", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.I32))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(scannerGetList_args.class, metaDataMap); } public scannerGetList_args() { } public scannerGetList_args( int id, int nbRows) { this(); this.id = id; setIdIsSet(true); this.nbRows = nbRows; setNbRowsIsSet(true); } /** * Performs a deep copy on <i>other</i>. */ public scannerGetList_args(scannerGetList_args other) { __isset_bitfield = other.__isset_bitfield; this.id = other.id; this.nbRows = other.nbRows; } public scannerGetList_args deepCopy() { return new scannerGetList_args(this); } @Override public void clear() { setIdIsSet(false); this.id = 0; setNbRowsIsSet(false); this.nbRows = 0; } /** * id of a scanner returned by scannerOpen */ public int getId() { return this.id; } /** * id of a scanner returned by scannerOpen */ public scannerGetList_args setId(int id) { this.id = id; setIdIsSet(true); return this; } public void unsetId() { __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __ID_ISSET_ID); } /** Returns true if field id is set (has been assigned a value) and false otherwise */ public boolean isSetId() { return EncodingUtils.testBit(__isset_bitfield, __ID_ISSET_ID); } public void setIdIsSet(boolean value) { __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __ID_ISSET_ID, value); } /** * number of results to return */ public int getNbRows() { return this.nbRows; } /** * number of results to return */ public scannerGetList_args setNbRows(int nbRows) { this.nbRows = nbRows; setNbRowsIsSet(true); return this; } public void unsetNbRows() { __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __NBROWS_ISSET_ID); } /** Returns true if field nbRows is set (has been assigned a value) and false otherwise */ public boolean isSetNbRows() { return EncodingUtils.testBit(__isset_bitfield, __NBROWS_ISSET_ID); } public void setNbRowsIsSet(boolean value) { __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __NBROWS_ISSET_ID, value); } public void setFieldValue(_Fields field, Object value) { switch (field) { case ID: if (value == null) { unsetId(); } else { setId((Integer)value); } break; case NB_ROWS: if (value == null) { unsetNbRows(); } else { setNbRows((Integer)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case ID: return getId(); case NB_ROWS: return getNbRows(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case ID: return isSetId(); case NB_ROWS: return isSetNbRows(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof scannerGetList_args) return this.equals((scannerGetList_args)that); return false; } public boolean equals(scannerGetList_args that) { if (that == null) return false; boolean this_present_id = true; boolean that_present_id = true; if (this_present_id || that_present_id) { if (!(this_present_id && that_present_id)) return false; if (this.id != that.id) return false; } boolean this_present_nbRows = true; boolean that_present_nbRows = true; if (this_present_nbRows || that_present_nbRows) { if (!(this_present_nbRows && that_present_nbRows)) return false; if (this.nbRows != that.nbRows) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_id = true; list.add(present_id); if (present_id) list.add(id); boolean present_nbRows = true; list.add(present_nbRows); if (present_nbRows) list.add(nbRows); return list.hashCode(); } @Override public int compareTo(scannerGetList_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetId()).compareTo(other.isSetId()); if (lastComparison != 0) { return lastComparison; } if (isSetId()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.id, other.id); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetNbRows()).compareTo(other.isSetNbRows()); if (lastComparison != 0) { return lastComparison; } if (isSetNbRows()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.nbRows, other.nbRows); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("scannerGetList_args("); boolean first = true; sb.append("id:"); sb.append(this.id); first = false; if (!first) sb.append(", "); sb.append("nbRows:"); sb.append(this.nbRows); first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { // it doesn't seem like you should have to do this, but java serialization is wacky, and doesn't call the default constructor. __isset_bitfield = 0; read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class scannerGetList_argsStandardSchemeFactory implements SchemeFactory { public scannerGetList_argsStandardScheme getScheme() { return new scannerGetList_argsStandardScheme(); } } private static class scannerGetList_argsStandardScheme extends StandardScheme<scannerGetList_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, scannerGetList_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // ID if (schemeField.type == org.apache.thrift.protocol.TType.I32) { struct.id = iprot.readI32(); struct.setIdIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // NB_ROWS if (schemeField.type == org.apache.thrift.protocol.TType.I32) { struct.nbRows = iprot.readI32(); struct.setNbRowsIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, scannerGetList_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); oprot.writeFieldBegin(ID_FIELD_DESC); oprot.writeI32(struct.id); oprot.writeFieldEnd(); oprot.writeFieldBegin(NB_ROWS_FIELD_DESC); oprot.writeI32(struct.nbRows); oprot.writeFieldEnd(); oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class scannerGetList_argsTupleSchemeFactory implements SchemeFactory { public scannerGetList_argsTupleScheme getScheme() { return new scannerGetList_argsTupleScheme(); } } private static class scannerGetList_argsTupleScheme extends TupleScheme<scannerGetList_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, scannerGetList_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetId()) { optionals.set(0); } if (struct.isSetNbRows()) { optionals.set(1); } oprot.writeBitSet(optionals, 2); if (struct.isSetId()) { oprot.writeI32(struct.id); } if (struct.isSetNbRows()) { oprot.writeI32(struct.nbRows); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, scannerGetList_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { struct.id = iprot.readI32(); struct.setIdIsSet(true); } if (incoming.get(1)) { struct.nbRows = iprot.readI32(); struct.setNbRowsIsSet(true); } } } } public static class scannerGetList_result implements org.apache.thrift.TBase<scannerGetList_result, scannerGetList_result._Fields>, java.io.Serializable, Cloneable, Comparable<scannerGetList_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("scannerGetList_result"); private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.LIST, (short)0); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final org.apache.thrift.protocol.TField IA_FIELD_DESC = new org.apache.thrift.protocol.TField("ia", org.apache.thrift.protocol.TType.STRUCT, (short)2); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new scannerGetList_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new scannerGetList_resultTupleSchemeFactory()); } public List<TRowResult> success; // required public IOError io; // required public IllegalArgument ia; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { SUCCESS((short)0, "success"), IO((short)1, "io"), IA((short)2, "ia"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 0: // SUCCESS return SUCCESS; case 1: // IO return IO; case 2: // IA return IA; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.SUCCESS, new org.apache.thrift.meta_data.FieldMetaData("success", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, TRowResult.class)))); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); tmpMap.put(_Fields.IA, new org.apache.thrift.meta_data.FieldMetaData("ia", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(scannerGetList_result.class, metaDataMap); } public scannerGetList_result() { } public scannerGetList_result( List<TRowResult> success, IOError io, IllegalArgument ia) { this(); this.success = success; this.io = io; this.ia = ia; } /** * Performs a deep copy on <i>other</i>. */ public scannerGetList_result(scannerGetList_result other) { if (other.isSetSuccess()) { List<TRowResult> __this__success = new ArrayList<TRowResult>(other.success.size()); for (TRowResult other_element : other.success) { __this__success.add(new TRowResult(other_element)); } this.success = __this__success; } if (other.isSetIo()) { this.io = new IOError(other.io); } if (other.isSetIa()) { this.ia = new IllegalArgument(other.ia); } } public scannerGetList_result deepCopy() { return new scannerGetList_result(this); } @Override public void clear() { this.success = null; this.io = null; this.ia = null; } public int getSuccessSize() { return (this.success == null) ? 0 : this.success.size(); } public java.util.Iterator<TRowResult> getSuccessIterator() { return (this.success == null) ? null : this.success.iterator(); } public void addToSuccess(TRowResult elem) { if (this.success == null) { this.success = new ArrayList<TRowResult>(); } this.success.add(elem); } public List<TRowResult> getSuccess() { return this.success; } public scannerGetList_result setSuccess(List<TRowResult> success) { this.success = success; return this; } public void unsetSuccess() { this.success = null; } /** Returns true if field success is set (has been assigned a value) and false otherwise */ public boolean isSetSuccess() { return this.success != null; } public void setSuccessIsSet(boolean value) { if (!value) { this.success = null; } } public IOError getIo() { return this.io; } public scannerGetList_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public IllegalArgument getIa() { return this.ia; } public scannerGetList_result setIa(IllegalArgument ia) { this.ia = ia; return this; } public void unsetIa() { this.ia = null; } /** Returns true if field ia is set (has been assigned a value) and false otherwise */ public boolean isSetIa() { return this.ia != null; } public void setIaIsSet(boolean value) { if (!value) { this.ia = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case SUCCESS: if (value == null) { unsetSuccess(); } else { setSuccess((List<TRowResult>)value); } break; case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; case IA: if (value == null) { unsetIa(); } else { setIa((IllegalArgument)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case SUCCESS: return getSuccess(); case IO: return getIo(); case IA: return getIa(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case SUCCESS: return isSetSuccess(); case IO: return isSetIo(); case IA: return isSetIa(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof scannerGetList_result) return this.equals((scannerGetList_result)that); return false; } public boolean equals(scannerGetList_result that) { if (that == null) return false; boolean this_present_success = true && this.isSetSuccess(); boolean that_present_success = true && that.isSetSuccess(); if (this_present_success || that_present_success) { if (!(this_present_success && that_present_success)) return false; if (!this.success.equals(that.success)) return false; } boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } boolean this_present_ia = true && this.isSetIa(); boolean that_present_ia = true && that.isSetIa(); if (this_present_ia || that_present_ia) { if (!(this_present_ia && that_present_ia)) return false; if (!this.ia.equals(that.ia)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_success = true && (isSetSuccess()); list.add(present_success); if (present_success) list.add(success); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); boolean present_ia = true && (isSetIa()); list.add(present_ia); if (present_ia) list.add(ia); return list.hashCode(); } @Override public int compareTo(scannerGetList_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess()); if (lastComparison != 0) { return lastComparison; } if (isSetSuccess()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIa()).compareTo(other.isSetIa()); if (lastComparison != 0) { return lastComparison; } if (isSetIa()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ia, other.ia); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("scannerGetList_result("); boolean first = true; sb.append("success:"); if (this.success == null) { sb.append("null"); } else { sb.append(this.success); } first = false; if (!first) sb.append(", "); sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; if (!first) sb.append(", "); sb.append("ia:"); if (this.ia == null) { sb.append("null"); } else { sb.append(this.ia); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class scannerGetList_resultStandardSchemeFactory implements SchemeFactory { public scannerGetList_resultStandardScheme getScheme() { return new scannerGetList_resultStandardScheme(); } } private static class scannerGetList_resultStandardScheme extends StandardScheme<scannerGetList_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, scannerGetList_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list574 = iprot.readListBegin(); struct.success = new ArrayList<TRowResult>(_list574.size); TRowResult _elem575; for (int _i576 = 0; _i576 < _list574.size; ++_i576) { _elem575 = new TRowResult(); _elem575.read(iprot); struct.success.add(_elem575); } iprot.readListEnd(); } struct.setSuccessIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // IA if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.ia = new IllegalArgument(); struct.ia.read(iprot); struct.setIaIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, scannerGetList_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.success != null) { oprot.writeFieldBegin(SUCCESS_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size())); for (TRowResult _iter577 : struct.success) { _iter577.write(oprot); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } if (struct.ia != null) { oprot.writeFieldBegin(IA_FIELD_DESC); struct.ia.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class scannerGetList_resultTupleSchemeFactory implements SchemeFactory { public scannerGetList_resultTupleScheme getScheme() { return new scannerGetList_resultTupleScheme(); } } private static class scannerGetList_resultTupleScheme extends TupleScheme<scannerGetList_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, scannerGetList_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetSuccess()) { optionals.set(0); } if (struct.isSetIo()) { optionals.set(1); } if (struct.isSetIa()) { optionals.set(2); } oprot.writeBitSet(optionals, 3); if (struct.isSetSuccess()) { { oprot.writeI32(struct.success.size()); for (TRowResult _iter578 : struct.success) { _iter578.write(oprot); } } } if (struct.isSetIo()) { struct.io.write(oprot); } if (struct.isSetIa()) { struct.ia.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, scannerGetList_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(3); if (incoming.get(0)) { { org.apache.thrift.protocol.TList _list579 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32()); struct.success = new ArrayList<TRowResult>(_list579.size); TRowResult _elem580; for (int _i581 = 0; _i581 < _list579.size; ++_i581) { _elem580 = new TRowResult(); _elem580.read(iprot); struct.success.add(_elem580); } } struct.setSuccessIsSet(true); } if (incoming.get(1)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } if (incoming.get(2)) { struct.ia = new IllegalArgument(); struct.ia.read(iprot); struct.setIaIsSet(true); } } } } public static class scannerClose_args implements org.apache.thrift.TBase<scannerClose_args, scannerClose_args._Fields>, java.io.Serializable, Cloneable, Comparable<scannerClose_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("scannerClose_args"); private static final org.apache.thrift.protocol.TField ID_FIELD_DESC = new org.apache.thrift.protocol.TField("id", org.apache.thrift.protocol.TType.I32, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new scannerClose_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new scannerClose_argsTupleSchemeFactory()); } /** * id of a scanner returned by scannerOpen */ public int id; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * id of a scanner returned by scannerOpen */ ID((short)1, "id"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // ID return ID; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments private static final int __ID_ISSET_ID = 0; private byte __isset_bitfield = 0; public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.ID, new org.apache.thrift.meta_data.FieldMetaData("id", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.I32 , "ScannerID"))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(scannerClose_args.class, metaDataMap); } public scannerClose_args() { } public scannerClose_args( int id) { this(); this.id = id; setIdIsSet(true); } /** * Performs a deep copy on <i>other</i>. */ public scannerClose_args(scannerClose_args other) { __isset_bitfield = other.__isset_bitfield; this.id = other.id; } public scannerClose_args deepCopy() { return new scannerClose_args(this); } @Override public void clear() { setIdIsSet(false); this.id = 0; } /** * id of a scanner returned by scannerOpen */ public int getId() { return this.id; } /** * id of a scanner returned by scannerOpen */ public scannerClose_args setId(int id) { this.id = id; setIdIsSet(true); return this; } public void unsetId() { __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __ID_ISSET_ID); } /** Returns true if field id is set (has been assigned a value) and false otherwise */ public boolean isSetId() { return EncodingUtils.testBit(__isset_bitfield, __ID_ISSET_ID); } public void setIdIsSet(boolean value) { __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __ID_ISSET_ID, value); } public void setFieldValue(_Fields field, Object value) { switch (field) { case ID: if (value == null) { unsetId(); } else { setId((Integer)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case ID: return getId(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case ID: return isSetId(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof scannerClose_args) return this.equals((scannerClose_args)that); return false; } public boolean equals(scannerClose_args that) { if (that == null) return false; boolean this_present_id = true; boolean that_present_id = true; if (this_present_id || that_present_id) { if (!(this_present_id && that_present_id)) return false; if (this.id != that.id) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_id = true; list.add(present_id); if (present_id) list.add(id); return list.hashCode(); } @Override public int compareTo(scannerClose_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetId()).compareTo(other.isSetId()); if (lastComparison != 0) { return lastComparison; } if (isSetId()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.id, other.id); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("scannerClose_args("); boolean first = true; sb.append("id:"); sb.append(this.id); first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { // it doesn't seem like you should have to do this, but java serialization is wacky, and doesn't call the default constructor. __isset_bitfield = 0; read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class scannerClose_argsStandardSchemeFactory implements SchemeFactory { public scannerClose_argsStandardScheme getScheme() { return new scannerClose_argsStandardScheme(); } } private static class scannerClose_argsStandardScheme extends StandardScheme<scannerClose_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, scannerClose_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // ID if (schemeField.type == org.apache.thrift.protocol.TType.I32) { struct.id = iprot.readI32(); struct.setIdIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, scannerClose_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); oprot.writeFieldBegin(ID_FIELD_DESC); oprot.writeI32(struct.id); oprot.writeFieldEnd(); oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class scannerClose_argsTupleSchemeFactory implements SchemeFactory { public scannerClose_argsTupleScheme getScheme() { return new scannerClose_argsTupleScheme(); } } private static class scannerClose_argsTupleScheme extends TupleScheme<scannerClose_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, scannerClose_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetId()) { optionals.set(0); } oprot.writeBitSet(optionals, 1); if (struct.isSetId()) { oprot.writeI32(struct.id); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, scannerClose_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(1); if (incoming.get(0)) { struct.id = iprot.readI32(); struct.setIdIsSet(true); } } } } public static class scannerClose_result implements org.apache.thrift.TBase<scannerClose_result, scannerClose_result._Fields>, java.io.Serializable, Cloneable, Comparable<scannerClose_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("scannerClose_result"); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final org.apache.thrift.protocol.TField IA_FIELD_DESC = new org.apache.thrift.protocol.TField("ia", org.apache.thrift.protocol.TType.STRUCT, (short)2); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new scannerClose_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new scannerClose_resultTupleSchemeFactory()); } public IOError io; // required public IllegalArgument ia; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { IO((short)1, "io"), IA((short)2, "ia"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // IO return IO; case 2: // IA return IA; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); tmpMap.put(_Fields.IA, new org.apache.thrift.meta_data.FieldMetaData("ia", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(scannerClose_result.class, metaDataMap); } public scannerClose_result() { } public scannerClose_result( IOError io, IllegalArgument ia) { this(); this.io = io; this.ia = ia; } /** * Performs a deep copy on <i>other</i>. */ public scannerClose_result(scannerClose_result other) { if (other.isSetIo()) { this.io = new IOError(other.io); } if (other.isSetIa()) { this.ia = new IllegalArgument(other.ia); } } public scannerClose_result deepCopy() { return new scannerClose_result(this); } @Override public void clear() { this.io = null; this.ia = null; } public IOError getIo() { return this.io; } public scannerClose_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public IllegalArgument getIa() { return this.ia; } public scannerClose_result setIa(IllegalArgument ia) { this.ia = ia; return this; } public void unsetIa() { this.ia = null; } /** Returns true if field ia is set (has been assigned a value) and false otherwise */ public boolean isSetIa() { return this.ia != null; } public void setIaIsSet(boolean value) { if (!value) { this.ia = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; case IA: if (value == null) { unsetIa(); } else { setIa((IllegalArgument)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case IO: return getIo(); case IA: return getIa(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case IO: return isSetIo(); case IA: return isSetIa(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof scannerClose_result) return this.equals((scannerClose_result)that); return false; } public boolean equals(scannerClose_result that) { if (that == null) return false; boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } boolean this_present_ia = true && this.isSetIa(); boolean that_present_ia = true && that.isSetIa(); if (this_present_ia || that_present_ia) { if (!(this_present_ia && that_present_ia)) return false; if (!this.ia.equals(that.ia)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); boolean present_ia = true && (isSetIa()); list.add(present_ia); if (present_ia) list.add(ia); return list.hashCode(); } @Override public int compareTo(scannerClose_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIa()).compareTo(other.isSetIa()); if (lastComparison != 0) { return lastComparison; } if (isSetIa()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ia, other.ia); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("scannerClose_result("); boolean first = true; sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; if (!first) sb.append(", "); sb.append("ia:"); if (this.ia == null) { sb.append("null"); } else { sb.append(this.ia); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class scannerClose_resultStandardSchemeFactory implements SchemeFactory { public scannerClose_resultStandardScheme getScheme() { return new scannerClose_resultStandardScheme(); } } private static class scannerClose_resultStandardScheme extends StandardScheme<scannerClose_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, scannerClose_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // IA if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.ia = new IllegalArgument(); struct.ia.read(iprot); struct.setIaIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, scannerClose_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } if (struct.ia != null) { oprot.writeFieldBegin(IA_FIELD_DESC); struct.ia.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class scannerClose_resultTupleSchemeFactory implements SchemeFactory { public scannerClose_resultTupleScheme getScheme() { return new scannerClose_resultTupleScheme(); } } private static class scannerClose_resultTupleScheme extends TupleScheme<scannerClose_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, scannerClose_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetIo()) { optionals.set(0); } if (struct.isSetIa()) { optionals.set(1); } oprot.writeBitSet(optionals, 2); if (struct.isSetIo()) { struct.io.write(oprot); } if (struct.isSetIa()) { struct.ia.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, scannerClose_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } if (incoming.get(1)) { struct.ia = new IllegalArgument(); struct.ia.read(iprot); struct.setIaIsSet(true); } } } } public static class getRegionInfo_args implements org.apache.thrift.TBase<getRegionInfo_args, getRegionInfo_args._Fields>, java.io.Serializable, Cloneable, Comparable<getRegionInfo_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getRegionInfo_args"); private static final org.apache.thrift.protocol.TField ROW_FIELD_DESC = new org.apache.thrift.protocol.TField("row", org.apache.thrift.protocol.TType.STRING, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new getRegionInfo_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new getRegionInfo_argsTupleSchemeFactory()); } /** * row key */ public ByteBuffer row; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * row key */ ROW((short)1, "row"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // ROW return ROW; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.ROW, new org.apache.thrift.meta_data.FieldMetaData("row", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(getRegionInfo_args.class, metaDataMap); } public getRegionInfo_args() { } public getRegionInfo_args( ByteBuffer row) { this(); this.row = org.apache.thrift.TBaseHelper.copyBinary(row); } /** * Performs a deep copy on <i>other</i>. */ public getRegionInfo_args(getRegionInfo_args other) { if (other.isSetRow()) { this.row = other.row; } } public getRegionInfo_args deepCopy() { return new getRegionInfo_args(this); } @Override public void clear() { this.row = null; } /** * row key */ public byte[] getRow() { setRow(org.apache.thrift.TBaseHelper.rightSize(row)); return row == null ? null : row.array(); } public ByteBuffer bufferForRow() { return org.apache.thrift.TBaseHelper.copyBinary(row); } /** * row key */ public getRegionInfo_args setRow(byte[] row) { this.row = row == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(row, row.length)); return this; } public getRegionInfo_args setRow(ByteBuffer row) { this.row = org.apache.thrift.TBaseHelper.copyBinary(row); return this; } public void unsetRow() { this.row = null; } /** Returns true if field row is set (has been assigned a value) and false otherwise */ public boolean isSetRow() { return this.row != null; } public void setRowIsSet(boolean value) { if (!value) { this.row = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case ROW: if (value == null) { unsetRow(); } else { setRow((ByteBuffer)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case ROW: return getRow(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case ROW: return isSetRow(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof getRegionInfo_args) return this.equals((getRegionInfo_args)that); return false; } public boolean equals(getRegionInfo_args that) { if (that == null) return false; boolean this_present_row = true && this.isSetRow(); boolean that_present_row = true && that.isSetRow(); if (this_present_row || that_present_row) { if (!(this_present_row && that_present_row)) return false; if (!this.row.equals(that.row)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_row = true && (isSetRow()); list.add(present_row); if (present_row) list.add(row); return list.hashCode(); } @Override public int compareTo(getRegionInfo_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetRow()).compareTo(other.isSetRow()); if (lastComparison != 0) { return lastComparison; } if (isSetRow()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.row, other.row); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("getRegionInfo_args("); boolean first = true; sb.append("row:"); if (this.row == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.row, sb); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class getRegionInfo_argsStandardSchemeFactory implements SchemeFactory { public getRegionInfo_argsStandardScheme getScheme() { return new getRegionInfo_argsStandardScheme(); } } private static class getRegionInfo_argsStandardScheme extends StandardScheme<getRegionInfo_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, getRegionInfo_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // ROW if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.row = iprot.readBinary(); struct.setRowIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, getRegionInfo_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.row != null) { oprot.writeFieldBegin(ROW_FIELD_DESC); oprot.writeBinary(struct.row); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class getRegionInfo_argsTupleSchemeFactory implements SchemeFactory { public getRegionInfo_argsTupleScheme getScheme() { return new getRegionInfo_argsTupleScheme(); } } private static class getRegionInfo_argsTupleScheme extends TupleScheme<getRegionInfo_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, getRegionInfo_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetRow()) { optionals.set(0); } oprot.writeBitSet(optionals, 1); if (struct.isSetRow()) { oprot.writeBinary(struct.row); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, getRegionInfo_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(1); if (incoming.get(0)) { struct.row = iprot.readBinary(); struct.setRowIsSet(true); } } } } public static class getRegionInfo_result implements org.apache.thrift.TBase<getRegionInfo_result, getRegionInfo_result._Fields>, java.io.Serializable, Cloneable, Comparable<getRegionInfo_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getRegionInfo_result"); private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.STRUCT, (short)0); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new getRegionInfo_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new getRegionInfo_resultTupleSchemeFactory()); } public TRegionInfo success; // required public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { SUCCESS((short)0, "success"), IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 0: // SUCCESS return SUCCESS; case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.SUCCESS, new org.apache.thrift.meta_data.FieldMetaData("success", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, TRegionInfo.class))); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(getRegionInfo_result.class, metaDataMap); } public getRegionInfo_result() { } public getRegionInfo_result( TRegionInfo success, IOError io) { this(); this.success = success; this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public getRegionInfo_result(getRegionInfo_result other) { if (other.isSetSuccess()) { this.success = new TRegionInfo(other.success); } if (other.isSetIo()) { this.io = new IOError(other.io); } } public getRegionInfo_result deepCopy() { return new getRegionInfo_result(this); } @Override public void clear() { this.success = null; this.io = null; } public TRegionInfo getSuccess() { return this.success; } public getRegionInfo_result setSuccess(TRegionInfo success) { this.success = success; return this; } public void unsetSuccess() { this.success = null; } /** Returns true if field success is set (has been assigned a value) and false otherwise */ public boolean isSetSuccess() { return this.success != null; } public void setSuccessIsSet(boolean value) { if (!value) { this.success = null; } } public IOError getIo() { return this.io; } public getRegionInfo_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case SUCCESS: if (value == null) { unsetSuccess(); } else { setSuccess((TRegionInfo)value); } break; case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case SUCCESS: return getSuccess(); case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case SUCCESS: return isSetSuccess(); case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof getRegionInfo_result) return this.equals((getRegionInfo_result)that); return false; } public boolean equals(getRegionInfo_result that) { if (that == null) return false; boolean this_present_success = true && this.isSetSuccess(); boolean that_present_success = true && that.isSetSuccess(); if (this_present_success || that_present_success) { if (!(this_present_success && that_present_success)) return false; if (!this.success.equals(that.success)) return false; } boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_success = true && (isSetSuccess()); list.add(present_success); if (present_success) list.add(success); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(getRegionInfo_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess()); if (lastComparison != 0) { return lastComparison; } if (isSetSuccess()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("getRegionInfo_result("); boolean first = true; sb.append("success:"); if (this.success == null) { sb.append("null"); } else { sb.append(this.success); } first = false; if (!first) sb.append(", "); sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity if (success != null) { success.validate(); } } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class getRegionInfo_resultStandardSchemeFactory implements SchemeFactory { public getRegionInfo_resultStandardScheme getScheme() { return new getRegionInfo_resultStandardScheme(); } } private static class getRegionInfo_resultStandardScheme extends StandardScheme<getRegionInfo_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, getRegionInfo_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.success = new TRegionInfo(); struct.success.read(iprot); struct.setSuccessIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, getRegionInfo_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.success != null) { oprot.writeFieldBegin(SUCCESS_FIELD_DESC); struct.success.write(oprot); oprot.writeFieldEnd(); } if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class getRegionInfo_resultTupleSchemeFactory implements SchemeFactory { public getRegionInfo_resultTupleScheme getScheme() { return new getRegionInfo_resultTupleScheme(); } } private static class getRegionInfo_resultTupleScheme extends TupleScheme<getRegionInfo_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, getRegionInfo_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetSuccess()) { optionals.set(0); } if (struct.isSetIo()) { optionals.set(1); } oprot.writeBitSet(optionals, 2); if (struct.isSetSuccess()) { struct.success.write(oprot); } if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, getRegionInfo_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { struct.success = new TRegionInfo(); struct.success.read(iprot); struct.setSuccessIsSet(true); } if (incoming.get(1)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class append_args implements org.apache.thrift.TBase<append_args, append_args._Fields>, java.io.Serializable, Cloneable, Comparable<append_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("append_args"); private static final org.apache.thrift.protocol.TField APPEND_FIELD_DESC = new org.apache.thrift.protocol.TField("append", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new append_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new append_argsTupleSchemeFactory()); } /** * The single append operation to apply */ public TAppend append; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * The single append operation to apply */ APPEND((short)1, "append"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // APPEND return APPEND; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.APPEND, new org.apache.thrift.meta_data.FieldMetaData("append", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, TAppend.class))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(append_args.class, metaDataMap); } public append_args() { } public append_args( TAppend append) { this(); this.append = append; } /** * Performs a deep copy on <i>other</i>. */ public append_args(append_args other) { if (other.isSetAppend()) { this.append = new TAppend(other.append); } } public append_args deepCopy() { return new append_args(this); } @Override public void clear() { this.append = null; } /** * The single append operation to apply */ public TAppend getAppend() { return this.append; } /** * The single append operation to apply */ public append_args setAppend(TAppend append) { this.append = append; return this; } public void unsetAppend() { this.append = null; } /** Returns true if field append is set (has been assigned a value) and false otherwise */ public boolean isSetAppend() { return this.append != null; } public void setAppendIsSet(boolean value) { if (!value) { this.append = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case APPEND: if (value == null) { unsetAppend(); } else { setAppend((TAppend)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case APPEND: return getAppend(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case APPEND: return isSetAppend(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof append_args) return this.equals((append_args)that); return false; } public boolean equals(append_args that) { if (that == null) return false; boolean this_present_append = true && this.isSetAppend(); boolean that_present_append = true && that.isSetAppend(); if (this_present_append || that_present_append) { if (!(this_present_append && that_present_append)) return false; if (!this.append.equals(that.append)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_append = true && (isSetAppend()); list.add(present_append); if (present_append) list.add(append); return list.hashCode(); } @Override public int compareTo(append_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetAppend()).compareTo(other.isSetAppend()); if (lastComparison != 0) { return lastComparison; } if (isSetAppend()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.append, other.append); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("append_args("); boolean first = true; sb.append("append:"); if (this.append == null) { sb.append("null"); } else { sb.append(this.append); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity if (append != null) { append.validate(); } } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class append_argsStandardSchemeFactory implements SchemeFactory { public append_argsStandardScheme getScheme() { return new append_argsStandardScheme(); } } private static class append_argsStandardScheme extends StandardScheme<append_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, append_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // APPEND if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.append = new TAppend(); struct.append.read(iprot); struct.setAppendIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, append_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.append != null) { oprot.writeFieldBegin(APPEND_FIELD_DESC); struct.append.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class append_argsTupleSchemeFactory implements SchemeFactory { public append_argsTupleScheme getScheme() { return new append_argsTupleScheme(); } } private static class append_argsTupleScheme extends TupleScheme<append_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, append_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetAppend()) { optionals.set(0); } oprot.writeBitSet(optionals, 1); if (struct.isSetAppend()) { struct.append.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, append_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(1); if (incoming.get(0)) { struct.append = new TAppend(); struct.append.read(iprot); struct.setAppendIsSet(true); } } } } public static class append_result implements org.apache.thrift.TBase<append_result, append_result._Fields>, java.io.Serializable, Cloneable, Comparable<append_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("append_result"); private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.LIST, (short)0); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new append_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new append_resultTupleSchemeFactory()); } public List<TCell> success; // required public IOError io; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { SUCCESS((short)0, "success"), IO((short)1, "io"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 0: // SUCCESS return SUCCESS; case 1: // IO return IO; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.SUCCESS, new org.apache.thrift.meta_data.FieldMetaData("success", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, TCell.class)))); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(append_result.class, metaDataMap); } public append_result() { } public append_result( List<TCell> success, IOError io) { this(); this.success = success; this.io = io; } /** * Performs a deep copy on <i>other</i>. */ public append_result(append_result other) { if (other.isSetSuccess()) { List<TCell> __this__success = new ArrayList<TCell>(other.success.size()); for (TCell other_element : other.success) { __this__success.add(new TCell(other_element)); } this.success = __this__success; } if (other.isSetIo()) { this.io = new IOError(other.io); } } public append_result deepCopy() { return new append_result(this); } @Override public void clear() { this.success = null; this.io = null; } public int getSuccessSize() { return (this.success == null) ? 0 : this.success.size(); } public java.util.Iterator<TCell> getSuccessIterator() { return (this.success == null) ? null : this.success.iterator(); } public void addToSuccess(TCell elem) { if (this.success == null) { this.success = new ArrayList<TCell>(); } this.success.add(elem); } public List<TCell> getSuccess() { return this.success; } public append_result setSuccess(List<TCell> success) { this.success = success; return this; } public void unsetSuccess() { this.success = null; } /** Returns true if field success is set (has been assigned a value) and false otherwise */ public boolean isSetSuccess() { return this.success != null; } public void setSuccessIsSet(boolean value) { if (!value) { this.success = null; } } public IOError getIo() { return this.io; } public append_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case SUCCESS: if (value == null) { unsetSuccess(); } else { setSuccess((List<TCell>)value); } break; case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case SUCCESS: return getSuccess(); case IO: return getIo(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case SUCCESS: return isSetSuccess(); case IO: return isSetIo(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof append_result) return this.equals((append_result)that); return false; } public boolean equals(append_result that) { if (that == null) return false; boolean this_present_success = true && this.isSetSuccess(); boolean that_present_success = true && that.isSetSuccess(); if (this_present_success || that_present_success) { if (!(this_present_success && that_present_success)) return false; if (!this.success.equals(that.success)) return false; } boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_success = true && (isSetSuccess()); list.add(present_success); if (present_success) list.add(success); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); return list.hashCode(); } @Override public int compareTo(append_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess()); if (lastComparison != 0) { return lastComparison; } if (isSetSuccess()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("append_result("); boolean first = true; sb.append("success:"); if (this.success == null) { sb.append("null"); } else { sb.append(this.success); } first = false; if (!first) sb.append(", "); sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class append_resultStandardSchemeFactory implements SchemeFactory { public append_resultStandardScheme getScheme() { return new append_resultStandardScheme(); } } private static class append_resultStandardScheme extends StandardScheme<append_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, append_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { org.apache.thrift.protocol.TList _list582 = iprot.readListBegin(); struct.success = new ArrayList<TCell>(_list582.size); TCell _elem583; for (int _i584 = 0; _i584 < _list582.size; ++_i584) { _elem583 = new TCell(); _elem583.read(iprot); struct.success.add(_elem583); } iprot.readListEnd(); } struct.setSuccessIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, append_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.success != null) { oprot.writeFieldBegin(SUCCESS_FIELD_DESC); { oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size())); for (TCell _iter585 : struct.success) { _iter585.write(oprot); } oprot.writeListEnd(); } oprot.writeFieldEnd(); } if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class append_resultTupleSchemeFactory implements SchemeFactory { public append_resultTupleScheme getScheme() { return new append_resultTupleScheme(); } } private static class append_resultTupleScheme extends TupleScheme<append_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, append_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetSuccess()) { optionals.set(0); } if (struct.isSetIo()) { optionals.set(1); } oprot.writeBitSet(optionals, 2); if (struct.isSetSuccess()) { { oprot.writeI32(struct.success.size()); for (TCell _iter586 : struct.success) { _iter586.write(oprot); } } } if (struct.isSetIo()) { struct.io.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, append_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { { org.apache.thrift.protocol.TList _list587 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32()); struct.success = new ArrayList<TCell>(_list587.size); TCell _elem588; for (int _i589 = 0; _i589 < _list587.size; ++_i589) { _elem588 = new TCell(); _elem588.read(iprot); struct.success.add(_elem588); } } struct.setSuccessIsSet(true); } if (incoming.get(1)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } } } } public static class checkAndPut_args implements org.apache.thrift.TBase<checkAndPut_args, checkAndPut_args._Fields>, java.io.Serializable, Cloneable, Comparable<checkAndPut_args> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("checkAndPut_args"); private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1); private static final org.apache.thrift.protocol.TField ROW_FIELD_DESC = new org.apache.thrift.protocol.TField("row", org.apache.thrift.protocol.TType.STRING, (short)2); private static final org.apache.thrift.protocol.TField COLUMN_FIELD_DESC = new org.apache.thrift.protocol.TField("column", org.apache.thrift.protocol.TType.STRING, (short)3); private static final org.apache.thrift.protocol.TField VALUE_FIELD_DESC = new org.apache.thrift.protocol.TField("value", org.apache.thrift.protocol.TType.STRING, (short)5); private static final org.apache.thrift.protocol.TField MPUT_FIELD_DESC = new org.apache.thrift.protocol.TField("mput", org.apache.thrift.protocol.TType.STRUCT, (short)6); private static final org.apache.thrift.protocol.TField ATTRIBUTES_FIELD_DESC = new org.apache.thrift.protocol.TField("attributes", org.apache.thrift.protocol.TType.MAP, (short)7); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new checkAndPut_argsStandardSchemeFactory()); schemes.put(TupleScheme.class, new checkAndPut_argsTupleSchemeFactory()); } /** * name of table */ public ByteBuffer tableName; // required /** * row key */ public ByteBuffer row; // required /** * column name */ public ByteBuffer column; // required /** * the expected value for the column parameter, if not * provided the check is for the non-existence of the * column in question */ public ByteBuffer value; // required /** * mutation for the put */ public Mutation mput; // required /** * Mutation attributes */ public Map<ByteBuffer,ByteBuffer> attributes; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { /** * name of table */ TABLE_NAME((short)1, "tableName"), /** * row key */ ROW((short)2, "row"), /** * column name */ COLUMN((short)3, "column"), /** * the expected value for the column parameter, if not * provided the check is for the non-existence of the * column in question */ VALUE((short)5, "value"), /** * mutation for the put */ MPUT((short)6, "mput"), /** * Mutation attributes */ ATTRIBUTES((short)7, "attributes"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 1: // TABLE_NAME return TABLE_NAME; case 2: // ROW return ROW; case 3: // COLUMN return COLUMN; case 5: // VALUE return VALUE; case 6: // MPUT return MPUT; case 7: // ATTRIBUTES return ATTRIBUTES; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.ROW, new org.apache.thrift.meta_data.FieldMetaData("row", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.COLUMN, new org.apache.thrift.meta_data.FieldMetaData("column", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.VALUE, new org.apache.thrift.meta_data.FieldMetaData("value", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"))); tmpMap.put(_Fields.MPUT, new org.apache.thrift.meta_data.FieldMetaData("mput", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, Mutation.class))); tmpMap.put(_Fields.ATTRIBUTES, new org.apache.thrift.meta_data.FieldMetaData("attributes", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.MapMetaData(org.apache.thrift.protocol.TType.MAP, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text"), new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING , "Text")))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(checkAndPut_args.class, metaDataMap); } public checkAndPut_args() { } public checkAndPut_args( ByteBuffer tableName, ByteBuffer row, ByteBuffer column, ByteBuffer value, Mutation mput, Map<ByteBuffer,ByteBuffer> attributes) { this(); this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); this.row = org.apache.thrift.TBaseHelper.copyBinary(row); this.column = org.apache.thrift.TBaseHelper.copyBinary(column); this.value = org.apache.thrift.TBaseHelper.copyBinary(value); this.mput = mput; this.attributes = attributes; } /** * Performs a deep copy on <i>other</i>. */ public checkAndPut_args(checkAndPut_args other) { if (other.isSetTableName()) { this.tableName = other.tableName; } if (other.isSetRow()) { this.row = other.row; } if (other.isSetColumn()) { this.column = other.column; } if (other.isSetValue()) { this.value = other.value; } if (other.isSetMput()) { this.mput = new Mutation(other.mput); } if (other.isSetAttributes()) { Map<ByteBuffer,ByteBuffer> __this__attributes = new HashMap<ByteBuffer,ByteBuffer>(other.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> other_element : other.attributes.entrySet()) { ByteBuffer other_element_key = other_element.getKey(); ByteBuffer other_element_value = other_element.getValue(); ByteBuffer __this__attributes_copy_key = other_element_key; ByteBuffer __this__attributes_copy_value = other_element_value; __this__attributes.put(__this__attributes_copy_key, __this__attributes_copy_value); } this.attributes = __this__attributes; } } public checkAndPut_args deepCopy() { return new checkAndPut_args(this); } @Override public void clear() { this.tableName = null; this.row = null; this.column = null; this.value = null; this.mput = null; this.attributes = null; } /** * name of table */ public byte[] getTableName() { setTableName(org.apache.thrift.TBaseHelper.rightSize(tableName)); return tableName == null ? null : tableName.array(); } public ByteBuffer bufferForTableName() { return org.apache.thrift.TBaseHelper.copyBinary(tableName); } /** * name of table */ public checkAndPut_args setTableName(byte[] tableName) { this.tableName = tableName == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(tableName, tableName.length)); return this; } public checkAndPut_args setTableName(ByteBuffer tableName) { this.tableName = org.apache.thrift.TBaseHelper.copyBinary(tableName); return this; } public void unsetTableName() { this.tableName = null; } /** Returns true if field tableName is set (has been assigned a value) and false otherwise */ public boolean isSetTableName() { return this.tableName != null; } public void setTableNameIsSet(boolean value) { if (!value) { this.tableName = null; } } /** * row key */ public byte[] getRow() { setRow(org.apache.thrift.TBaseHelper.rightSize(row)); return row == null ? null : row.array(); } public ByteBuffer bufferForRow() { return org.apache.thrift.TBaseHelper.copyBinary(row); } /** * row key */ public checkAndPut_args setRow(byte[] row) { this.row = row == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(row, row.length)); return this; } public checkAndPut_args setRow(ByteBuffer row) { this.row = org.apache.thrift.TBaseHelper.copyBinary(row); return this; } public void unsetRow() { this.row = null; } /** Returns true if field row is set (has been assigned a value) and false otherwise */ public boolean isSetRow() { return this.row != null; } public void setRowIsSet(boolean value) { if (!value) { this.row = null; } } /** * column name */ public byte[] getColumn() { setColumn(org.apache.thrift.TBaseHelper.rightSize(column)); return column == null ? null : column.array(); } public ByteBuffer bufferForColumn() { return org.apache.thrift.TBaseHelper.copyBinary(column); } /** * column name */ public checkAndPut_args setColumn(byte[] column) { this.column = column == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(column, column.length)); return this; } public checkAndPut_args setColumn(ByteBuffer column) { this.column = org.apache.thrift.TBaseHelper.copyBinary(column); return this; } public void unsetColumn() { this.column = null; } /** Returns true if field column is set (has been assigned a value) and false otherwise */ public boolean isSetColumn() { return this.column != null; } public void setColumnIsSet(boolean value) { if (!value) { this.column = null; } } /** * the expected value for the column parameter, if not * provided the check is for the non-existence of the * column in question */ public byte[] getValue() { setValue(org.apache.thrift.TBaseHelper.rightSize(value)); return value == null ? null : value.array(); } public ByteBuffer bufferForValue() { return org.apache.thrift.TBaseHelper.copyBinary(value); } /** * the expected value for the column parameter, if not * provided the check is for the non-existence of the * column in question */ public checkAndPut_args setValue(byte[] value) { this.value = value == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(value, value.length)); return this; } public checkAndPut_args setValue(ByteBuffer value) { this.value = org.apache.thrift.TBaseHelper.copyBinary(value); return this; } public void unsetValue() { this.value = null; } /** Returns true if field value is set (has been assigned a value) and false otherwise */ public boolean isSetValue() { return this.value != null; } public void setValueIsSet(boolean value) { if (!value) { this.value = null; } } /** * mutation for the put */ public Mutation getMput() { return this.mput; } /** * mutation for the put */ public checkAndPut_args setMput(Mutation mput) { this.mput = mput; return this; } public void unsetMput() { this.mput = null; } /** Returns true if field mput is set (has been assigned a value) and false otherwise */ public boolean isSetMput() { return this.mput != null; } public void setMputIsSet(boolean value) { if (!value) { this.mput = null; } } public int getAttributesSize() { return (this.attributes == null) ? 0 : this.attributes.size(); } public void putToAttributes(ByteBuffer key, ByteBuffer val) { if (this.attributes == null) { this.attributes = new HashMap<ByteBuffer,ByteBuffer>(); } this.attributes.put(key, val); } /** * Mutation attributes */ public Map<ByteBuffer,ByteBuffer> getAttributes() { return this.attributes; } /** * Mutation attributes */ public checkAndPut_args setAttributes(Map<ByteBuffer,ByteBuffer> attributes) { this.attributes = attributes; return this; } public void unsetAttributes() { this.attributes = null; } /** Returns true if field attributes is set (has been assigned a value) and false otherwise */ public boolean isSetAttributes() { return this.attributes != null; } public void setAttributesIsSet(boolean value) { if (!value) { this.attributes = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case TABLE_NAME: if (value == null) { unsetTableName(); } else { setTableName((ByteBuffer)value); } break; case ROW: if (value == null) { unsetRow(); } else { setRow((ByteBuffer)value); } break; case COLUMN: if (value == null) { unsetColumn(); } else { setColumn((ByteBuffer)value); } break; case VALUE: if (value == null) { unsetValue(); } else { setValue((ByteBuffer)value); } break; case MPUT: if (value == null) { unsetMput(); } else { setMput((Mutation)value); } break; case ATTRIBUTES: if (value == null) { unsetAttributes(); } else { setAttributes((Map<ByteBuffer,ByteBuffer>)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case TABLE_NAME: return getTableName(); case ROW: return getRow(); case COLUMN: return getColumn(); case VALUE: return getValue(); case MPUT: return getMput(); case ATTRIBUTES: return getAttributes(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case TABLE_NAME: return isSetTableName(); case ROW: return isSetRow(); case COLUMN: return isSetColumn(); case VALUE: return isSetValue(); case MPUT: return isSetMput(); case ATTRIBUTES: return isSetAttributes(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof checkAndPut_args) return this.equals((checkAndPut_args)that); return false; } public boolean equals(checkAndPut_args that) { if (that == null) return false; boolean this_present_tableName = true && this.isSetTableName(); boolean that_present_tableName = true && that.isSetTableName(); if (this_present_tableName || that_present_tableName) { if (!(this_present_tableName && that_present_tableName)) return false; if (!this.tableName.equals(that.tableName)) return false; } boolean this_present_row = true && this.isSetRow(); boolean that_present_row = true && that.isSetRow(); if (this_present_row || that_present_row) { if (!(this_present_row && that_present_row)) return false; if (!this.row.equals(that.row)) return false; } boolean this_present_column = true && this.isSetColumn(); boolean that_present_column = true && that.isSetColumn(); if (this_present_column || that_present_column) { if (!(this_present_column && that_present_column)) return false; if (!this.column.equals(that.column)) return false; } boolean this_present_value = true && this.isSetValue(); boolean that_present_value = true && that.isSetValue(); if (this_present_value || that_present_value) { if (!(this_present_value && that_present_value)) return false; if (!this.value.equals(that.value)) return false; } boolean this_present_mput = true && this.isSetMput(); boolean that_present_mput = true && that.isSetMput(); if (this_present_mput || that_present_mput) { if (!(this_present_mput && that_present_mput)) return false; if (!this.mput.equals(that.mput)) return false; } boolean this_present_attributes = true && this.isSetAttributes(); boolean that_present_attributes = true && that.isSetAttributes(); if (this_present_attributes || that_present_attributes) { if (!(this_present_attributes && that_present_attributes)) return false; if (!this.attributes.equals(that.attributes)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_tableName = true && (isSetTableName()); list.add(present_tableName); if (present_tableName) list.add(tableName); boolean present_row = true && (isSetRow()); list.add(present_row); if (present_row) list.add(row); boolean present_column = true && (isSetColumn()); list.add(present_column); if (present_column) list.add(column); boolean present_value = true && (isSetValue()); list.add(present_value); if (present_value) list.add(value); boolean present_mput = true && (isSetMput()); list.add(present_mput); if (present_mput) list.add(mput); boolean present_attributes = true && (isSetAttributes()); list.add(present_attributes); if (present_attributes) list.add(attributes); return list.hashCode(); } @Override public int compareTo(checkAndPut_args other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName()); if (lastComparison != 0) { return lastComparison; } if (isSetTableName()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetRow()).compareTo(other.isSetRow()); if (lastComparison != 0) { return lastComparison; } if (isSetRow()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.row, other.row); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetColumn()).compareTo(other.isSetColumn()); if (lastComparison != 0) { return lastComparison; } if (isSetColumn()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.column, other.column); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetValue()).compareTo(other.isSetValue()); if (lastComparison != 0) { return lastComparison; } if (isSetValue()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.value, other.value); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetMput()).compareTo(other.isSetMput()); if (lastComparison != 0) { return lastComparison; } if (isSetMput()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.mput, other.mput); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetAttributes()).compareTo(other.isSetAttributes()); if (lastComparison != 0) { return lastComparison; } if (isSetAttributes()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.attributes, other.attributes); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("checkAndPut_args("); boolean first = true; sb.append("tableName:"); if (this.tableName == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.tableName, sb); } first = false; if (!first) sb.append(", "); sb.append("row:"); if (this.row == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.row, sb); } first = false; if (!first) sb.append(", "); sb.append("column:"); if (this.column == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.column, sb); } first = false; if (!first) sb.append(", "); sb.append("value:"); if (this.value == null) { sb.append("null"); } else { org.apache.thrift.TBaseHelper.toString(this.value, sb); } first = false; if (!first) sb.append(", "); sb.append("mput:"); if (this.mput == null) { sb.append("null"); } else { sb.append(this.mput); } first = false; if (!first) sb.append(", "); sb.append("attributes:"); if (this.attributes == null) { sb.append("null"); } else { sb.append(this.attributes); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity if (mput != null) { mput.validate(); } } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class checkAndPut_argsStandardSchemeFactory implements SchemeFactory { public checkAndPut_argsStandardScheme getScheme() { return new checkAndPut_argsStandardScheme(); } } private static class checkAndPut_argsStandardScheme extends StandardScheme<checkAndPut_args> { public void read(org.apache.thrift.protocol.TProtocol iprot, checkAndPut_args struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 1: // TABLE_NAME if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // ROW if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.row = iprot.readBinary(); struct.setRowIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 3: // COLUMN if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.column = iprot.readBinary(); struct.setColumnIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 5: // VALUE if (schemeField.type == org.apache.thrift.protocol.TType.STRING) { struct.value = iprot.readBinary(); struct.setValueIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 6: // MPUT if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.mput = new Mutation(); struct.mput.read(iprot); struct.setMputIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 7: // ATTRIBUTES if (schemeField.type == org.apache.thrift.protocol.TType.MAP) { { org.apache.thrift.protocol.TMap _map590 = iprot.readMapBegin(); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map590.size); ByteBuffer _key591; ByteBuffer _val592; for (int _i593 = 0; _i593 < _map590.size; ++_i593) { _key591 = iprot.readBinary(); _val592 = iprot.readBinary(); struct.attributes.put(_key591, _val592); } iprot.readMapEnd(); } struct.setAttributesIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, checkAndPut_args struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.tableName != null) { oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC); oprot.writeBinary(struct.tableName); oprot.writeFieldEnd(); } if (struct.row != null) { oprot.writeFieldBegin(ROW_FIELD_DESC); oprot.writeBinary(struct.row); oprot.writeFieldEnd(); } if (struct.column != null) { oprot.writeFieldBegin(COLUMN_FIELD_DESC); oprot.writeBinary(struct.column); oprot.writeFieldEnd(); } if (struct.value != null) { oprot.writeFieldBegin(VALUE_FIELD_DESC); oprot.writeBinary(struct.value); oprot.writeFieldEnd(); } if (struct.mput != null) { oprot.writeFieldBegin(MPUT_FIELD_DESC); struct.mput.write(oprot); oprot.writeFieldEnd(); } if (struct.attributes != null) { oprot.writeFieldBegin(ATTRIBUTES_FIELD_DESC); { oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, struct.attributes.size())); for (Map.Entry<ByteBuffer, ByteBuffer> _iter594 : struct.attributes.entrySet()) { oprot.writeBinary(_iter594.getKey()); oprot.writeBinary(_iter594.getValue()); } oprot.writeMapEnd(); } oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class checkAndPut_argsTupleSchemeFactory implements SchemeFactory { public checkAndPut_argsTupleScheme getScheme() { return new checkAndPut_argsTupleScheme(); } } private static class checkAndPut_argsTupleScheme extends TupleScheme<checkAndPut_args> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, checkAndPut_args struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetTableName()) { optionals.set(0); } if (struct.isSetRow()) { optionals.set(1); } if (struct.isSetColumn()) { optionals.set(2); } if (struct.isSetValue()) { optionals.set(3); } if (struct.isSetMput()) { optionals.set(4); } if (struct.isSetAttributes()) { optionals.set(5); } oprot.writeBitSet(optionals, 6); if (struct.isSetTableName()) { oprot.writeBinary(struct.tableName); } if (struct.isSetRow()) { oprot.writeBinary(struct.row); } if (struct.isSetColumn()) { oprot.writeBinary(struct.column); } if (struct.isSetValue()) { oprot.writeBinary(struct.value); } if (struct.isSetMput()) { struct.mput.write(oprot); } if (struct.isSetAttributes()) { { oprot.writeI32(struct.attributes.size()); for (Map.Entry<ByteBuffer, ByteBuffer> _iter595 : struct.attributes.entrySet()) { oprot.writeBinary(_iter595.getKey()); oprot.writeBinary(_iter595.getValue()); } } } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, checkAndPut_args struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(6); if (incoming.get(0)) { struct.tableName = iprot.readBinary(); struct.setTableNameIsSet(true); } if (incoming.get(1)) { struct.row = iprot.readBinary(); struct.setRowIsSet(true); } if (incoming.get(2)) { struct.column = iprot.readBinary(); struct.setColumnIsSet(true); } if (incoming.get(3)) { struct.value = iprot.readBinary(); struct.setValueIsSet(true); } if (incoming.get(4)) { struct.mput = new Mutation(); struct.mput.read(iprot); struct.setMputIsSet(true); } if (incoming.get(5)) { { org.apache.thrift.protocol.TMap _map596 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32()); struct.attributes = new HashMap<ByteBuffer,ByteBuffer>(2*_map596.size); ByteBuffer _key597; ByteBuffer _val598; for (int _i599 = 0; _i599 < _map596.size; ++_i599) { _key597 = iprot.readBinary(); _val598 = iprot.readBinary(); struct.attributes.put(_key597, _val598); } } struct.setAttributesIsSet(true); } } } } public static class checkAndPut_result implements org.apache.thrift.TBase<checkAndPut_result, checkAndPut_result._Fields>, java.io.Serializable, Cloneable, Comparable<checkAndPut_result> { private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("checkAndPut_result"); private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.BOOL, (short)0); private static final org.apache.thrift.protocol.TField IO_FIELD_DESC = new org.apache.thrift.protocol.TField("io", org.apache.thrift.protocol.TType.STRUCT, (short)1); private static final org.apache.thrift.protocol.TField IA_FIELD_DESC = new org.apache.thrift.protocol.TField("ia", org.apache.thrift.protocol.TType.STRUCT, (short)2); private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>(); static { schemes.put(StandardScheme.class, new checkAndPut_resultStandardSchemeFactory()); schemes.put(TupleScheme.class, new checkAndPut_resultTupleSchemeFactory()); } public boolean success; // required public IOError io; // required public IllegalArgument ia; // required /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */ public enum _Fields implements org.apache.thrift.TFieldIdEnum { SUCCESS((short)0, "success"), IO((short)1, "io"), IA((short)2, "ia"); private static final Map<String, _Fields> byName = new HashMap<String, _Fields>(); static { for (_Fields field : EnumSet.allOf(_Fields.class)) { byName.put(field.getFieldName(), field); } } /** * Find the _Fields constant that matches fieldId, or null if its not found. */ public static _Fields findByThriftId(int fieldId) { switch(fieldId) { case 0: // SUCCESS return SUCCESS; case 1: // IO return IO; case 2: // IA return IA; default: return null; } } /** * Find the _Fields constant that matches fieldId, throwing an exception * if it is not found. */ public static _Fields findByThriftIdOrThrow(int fieldId) { _Fields fields = findByThriftId(fieldId); if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!"); return fields; } /** * Find the _Fields constant that matches name, or null if its not found. */ public static _Fields findByName(String name) { return byName.get(name); } private final short _thriftId; private final String _fieldName; _Fields(short thriftId, String fieldName) { _thriftId = thriftId; _fieldName = fieldName; } public short getThriftFieldId() { return _thriftId; } public String getFieldName() { return _fieldName; } } // isset id assignments private static final int __SUCCESS_ISSET_ID = 0; private byte __isset_bitfield = 0; public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap; static { Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class); tmpMap.put(_Fields.SUCCESS, new org.apache.thrift.meta_data.FieldMetaData("success", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.BOOL))); tmpMap.put(_Fields.IO, new org.apache.thrift.meta_data.FieldMetaData("io", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); tmpMap.put(_Fields.IA, new org.apache.thrift.meta_data.FieldMetaData("ia", org.apache.thrift.TFieldRequirementType.DEFAULT, new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRUCT))); metaDataMap = Collections.unmodifiableMap(tmpMap); org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(checkAndPut_result.class, metaDataMap); } public checkAndPut_result() { } public checkAndPut_result( boolean success, IOError io, IllegalArgument ia) { this(); this.success = success; setSuccessIsSet(true); this.io = io; this.ia = ia; } /** * Performs a deep copy on <i>other</i>. */ public checkAndPut_result(checkAndPut_result other) { __isset_bitfield = other.__isset_bitfield; this.success = other.success; if (other.isSetIo()) { this.io = new IOError(other.io); } if (other.isSetIa()) { this.ia = new IllegalArgument(other.ia); } } public checkAndPut_result deepCopy() { return new checkAndPut_result(this); } @Override public void clear() { setSuccessIsSet(false); this.success = false; this.io = null; this.ia = null; } public boolean isSuccess() { return this.success; } public checkAndPut_result setSuccess(boolean success) { this.success = success; setSuccessIsSet(true); return this; } public void unsetSuccess() { __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __SUCCESS_ISSET_ID); } /** Returns true if field success is set (has been assigned a value) and false otherwise */ public boolean isSetSuccess() { return EncodingUtils.testBit(__isset_bitfield, __SUCCESS_ISSET_ID); } public void setSuccessIsSet(boolean value) { __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __SUCCESS_ISSET_ID, value); } public IOError getIo() { return this.io; } public checkAndPut_result setIo(IOError io) { this.io = io; return this; } public void unsetIo() { this.io = null; } /** Returns true if field io is set (has been assigned a value) and false otherwise */ public boolean isSetIo() { return this.io != null; } public void setIoIsSet(boolean value) { if (!value) { this.io = null; } } public IllegalArgument getIa() { return this.ia; } public checkAndPut_result setIa(IllegalArgument ia) { this.ia = ia; return this; } public void unsetIa() { this.ia = null; } /** Returns true if field ia is set (has been assigned a value) and false otherwise */ public boolean isSetIa() { return this.ia != null; } public void setIaIsSet(boolean value) { if (!value) { this.ia = null; } } public void setFieldValue(_Fields field, Object value) { switch (field) { case SUCCESS: if (value == null) { unsetSuccess(); } else { setSuccess((Boolean)value); } break; case IO: if (value == null) { unsetIo(); } else { setIo((IOError)value); } break; case IA: if (value == null) { unsetIa(); } else { setIa((IllegalArgument)value); } break; } } public Object getFieldValue(_Fields field) { switch (field) { case SUCCESS: return isSuccess(); case IO: return getIo(); case IA: return getIa(); } throw new IllegalStateException(); } /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */ public boolean isSet(_Fields field) { if (field == null) { throw new IllegalArgumentException(); } switch (field) { case SUCCESS: return isSetSuccess(); case IO: return isSetIo(); case IA: return isSetIa(); } throw new IllegalStateException(); } @Override public boolean equals(Object that) { if (that == null) return false; if (that instanceof checkAndPut_result) return this.equals((checkAndPut_result)that); return false; } public boolean equals(checkAndPut_result that) { if (that == null) return false; boolean this_present_success = true; boolean that_present_success = true; if (this_present_success || that_present_success) { if (!(this_present_success && that_present_success)) return false; if (this.success != that.success) return false; } boolean this_present_io = true && this.isSetIo(); boolean that_present_io = true && that.isSetIo(); if (this_present_io || that_present_io) { if (!(this_present_io && that_present_io)) return false; if (!this.io.equals(that.io)) return false; } boolean this_present_ia = true && this.isSetIa(); boolean that_present_ia = true && that.isSetIa(); if (this_present_ia || that_present_ia) { if (!(this_present_ia && that_present_ia)) return false; if (!this.ia.equals(that.ia)) return false; } return true; } @Override public int hashCode() { List<Object> list = new ArrayList<Object>(); boolean present_success = true; list.add(present_success); if (present_success) list.add(success); boolean present_io = true && (isSetIo()); list.add(present_io); if (present_io) list.add(io); boolean present_ia = true && (isSetIa()); list.add(present_ia); if (present_ia) list.add(ia); return list.hashCode(); } @Override public int compareTo(checkAndPut_result other) { if (!getClass().equals(other.getClass())) { return getClass().getName().compareTo(other.getClass().getName()); } int lastComparison = 0; lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess()); if (lastComparison != 0) { return lastComparison; } if (isSetSuccess()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIo()).compareTo(other.isSetIo()); if (lastComparison != 0) { return lastComparison; } if (isSetIo()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.io, other.io); if (lastComparison != 0) { return lastComparison; } } lastComparison = Boolean.valueOf(isSetIa()).compareTo(other.isSetIa()); if (lastComparison != 0) { return lastComparison; } if (isSetIa()) { lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ia, other.ia); if (lastComparison != 0) { return lastComparison; } } return 0; } public _Fields fieldForId(int fieldId) { return _Fields.findByThriftId(fieldId); } public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException { schemes.get(iprot.getScheme()).getScheme().read(iprot, this); } public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException { schemes.get(oprot.getScheme()).getScheme().write(oprot, this); } @Override public String toString() { StringBuilder sb = new StringBuilder("checkAndPut_result("); boolean first = true; sb.append("success:"); sb.append(this.success); first = false; if (!first) sb.append(", "); sb.append("io:"); if (this.io == null) { sb.append("null"); } else { sb.append(this.io); } first = false; if (!first) sb.append(", "); sb.append("ia:"); if (this.ia == null) { sb.append("null"); } else { sb.append(this.ia); } first = false; sb.append(")"); return sb.toString(); } public void validate() throws org.apache.thrift.TException { // check for required fields // check for sub-struct validity } private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException { try { write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException { try { // it doesn't seem like you should have to do this, but java serialization is wacky, and doesn't call the default constructor. __isset_bitfield = 0; read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in))); } catch (org.apache.thrift.TException te) { throw new java.io.IOException(te); } } private static class checkAndPut_resultStandardSchemeFactory implements SchemeFactory { public checkAndPut_resultStandardScheme getScheme() { return new checkAndPut_resultStandardScheme(); } } private static class checkAndPut_resultStandardScheme extends StandardScheme<checkAndPut_result> { public void read(org.apache.thrift.protocol.TProtocol iprot, checkAndPut_result struct) throws org.apache.thrift.TException { org.apache.thrift.protocol.TField schemeField; iprot.readStructBegin(); while (true) { schemeField = iprot.readFieldBegin(); if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { break; } switch (schemeField.id) { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.BOOL) { struct.success = iprot.readBool(); struct.setSuccessIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 1: // IO if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; case 2: // IA if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) { struct.ia = new IllegalArgument(); struct.ia.read(iprot); struct.setIaIsSet(true); } else { org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } break; default: org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type); } iprot.readFieldEnd(); } iprot.readStructEnd(); // check for required fields of primitive type, which can't be checked in the validate method struct.validate(); } public void write(org.apache.thrift.protocol.TProtocol oprot, checkAndPut_result struct) throws org.apache.thrift.TException { struct.validate(); oprot.writeStructBegin(STRUCT_DESC); if (struct.isSetSuccess()) { oprot.writeFieldBegin(SUCCESS_FIELD_DESC); oprot.writeBool(struct.success); oprot.writeFieldEnd(); } if (struct.io != null) { oprot.writeFieldBegin(IO_FIELD_DESC); struct.io.write(oprot); oprot.writeFieldEnd(); } if (struct.ia != null) { oprot.writeFieldBegin(IA_FIELD_DESC); struct.ia.write(oprot); oprot.writeFieldEnd(); } oprot.writeFieldStop(); oprot.writeStructEnd(); } } private static class checkAndPut_resultTupleSchemeFactory implements SchemeFactory { public checkAndPut_resultTupleScheme getScheme() { return new checkAndPut_resultTupleScheme(); } } private static class checkAndPut_resultTupleScheme extends TupleScheme<checkAndPut_result> { @Override public void write(org.apache.thrift.protocol.TProtocol prot, checkAndPut_result struct) throws org.apache.thrift.TException { TTupleProtocol oprot = (TTupleProtocol) prot; BitSet optionals = new BitSet(); if (struct.isSetSuccess()) { optionals.set(0); } if (struct.isSetIo()) { optionals.set(1); } if (struct.isSetIa()) { optionals.set(2); } oprot.writeBitSet(optionals, 3); if (struct.isSetSuccess()) { oprot.writeBool(struct.success); } if (struct.isSetIo()) { struct.io.write(oprot); } if (struct.isSetIa()) { struct.ia.write(oprot); } } @Override public void read(org.apache.thrift.protocol.TProtocol prot, checkAndPut_result struct) throws org.apache.thrift.TException { TTupleProtocol iprot = (TTupleProtocol) prot; BitSet incoming = iprot.readBitSet(3); if (incoming.get(0)) { struct.success = iprot.readBool(); struct.setSuccessIsSet(true); } if (incoming.get(1)) { struct.io = new IOError(); struct.io.read(iprot); struct.setIoIsSet(true); } if (incoming.get(2)) { struct.ia = new IllegalArgument(); struct.ia.read(iprot); struct.setIaIsSet(true); } } } } }