You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@cassandra.apache.org by sl...@apache.org on 2016/12/13 09:27:47 UTC

[23/26] cassandra git commit: Thrift removal

http://git-wip-us.apache.org/repos/asf/cassandra/blob/4881d9c3/interface/thrift/gen-java/org/apache/cassandra/thrift/Cassandra.java
----------------------------------------------------------------------
diff --git a/interface/thrift/gen-java/org/apache/cassandra/thrift/Cassandra.java b/interface/thrift/gen-java/org/apache/cassandra/thrift/Cassandra.java
deleted file mode 100644
index cd4314b..0000000
--- a/interface/thrift/gen-java/org/apache/cassandra/thrift/Cassandra.java
+++ /dev/null
@@ -1,55794 +0,0 @@
-/**
- * Autogenerated by Thrift Compiler (0.9.1)
- *
- * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
- *  @generated
- */
-package org.apache.cassandra.thrift;
-/*
- * 
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- * 
- *   http://www.apache.org/licenses/LICENSE-2.0
- * 
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- * 
- */
-
-
-import org.apache.commons.lang3.builder.HashCodeBuilder;
-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 org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-public class Cassandra {
-
-  public interface Iface {
-
-    public void login(AuthenticationRequest auth_request) throws AuthenticationException, AuthorizationException, org.apache.thrift.TException;
-
-    public void set_keyspace(String keyspace) throws InvalidRequestException, org.apache.thrift.TException;
-
-    /**
-     * Get the Column or SuperColumn at the given column_path. If no value is present, NotFoundException is thrown. (This is
-     * the only method that can throw an exception under non-failure conditions.)
-     * 
-     * @param key
-     * @param column_path
-     * @param consistency_level
-     */
-    public ColumnOrSuperColumn get(ByteBuffer key, ColumnPath column_path, ConsistencyLevel consistency_level) throws InvalidRequestException, NotFoundException, UnavailableException, TimedOutException, org.apache.thrift.TException;
-
-    /**
-     * Get the group of columns contained by column_parent (either a ColumnFamily name or a ColumnFamily/SuperColumn name
-     * pair) specified by the given SlicePredicate. If no matching values are found, an empty list is returned.
-     * 
-     * @param key
-     * @param column_parent
-     * @param predicate
-     * @param consistency_level
-     */
-    public List<ColumnOrSuperColumn> get_slice(ByteBuffer key, ColumnParent column_parent, SlicePredicate predicate, ConsistencyLevel consistency_level) throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException;
-
-    /**
-     * returns the number of columns matching <code>predicate</code> for a particular <code>key</code>,
-     * <code>ColumnFamily</code> and optionally <code>SuperColumn</code>.
-     * 
-     * @param key
-     * @param column_parent
-     * @param predicate
-     * @param consistency_level
-     */
-    public int get_count(ByteBuffer key, ColumnParent column_parent, SlicePredicate predicate, ConsistencyLevel consistency_level) throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException;
-
-    /**
-     * Performs a get_slice for column_parent and predicate for the given keys in parallel.
-     * 
-     * @param keys
-     * @param column_parent
-     * @param predicate
-     * @param consistency_level
-     */
-    public Map<ByteBuffer,List<ColumnOrSuperColumn>> multiget_slice(List<ByteBuffer> keys, ColumnParent column_parent, SlicePredicate predicate, ConsistencyLevel consistency_level) throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException;
-
-    /**
-     * Perform a get_count in parallel on the given list<binary> keys. The return value maps keys to the count found.
-     * 
-     * @param keys
-     * @param column_parent
-     * @param predicate
-     * @param consistency_level
-     */
-    public Map<ByteBuffer,Integer> multiget_count(List<ByteBuffer> keys, ColumnParent column_parent, SlicePredicate predicate, ConsistencyLevel consistency_level) throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException;
-
-    /**
-     * returns a subset of columns for a contiguous range of keys.
-     * 
-     * @param column_parent
-     * @param predicate
-     * @param range
-     * @param consistency_level
-     */
-    public List<KeySlice> get_range_slices(ColumnParent column_parent, SlicePredicate predicate, KeyRange range, ConsistencyLevel consistency_level) throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException;
-
-    /**
-     * returns a range of columns, wrapping to the next rows if necessary to collect max_results.
-     * 
-     * @param column_family
-     * @param range
-     * @param start_column
-     * @param consistency_level
-     */
-    public List<KeySlice> get_paged_slice(String column_family, KeyRange range, ByteBuffer start_column, ConsistencyLevel consistency_level) throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException;
-
-    /**
-     * Returns the subset of columns specified in SlicePredicate for the rows matching the IndexClause
-     * @deprecated use get_range_slices instead with range.row_filter specified
-     * 
-     * @param column_parent
-     * @param index_clause
-     * @param column_predicate
-     * @param consistency_level
-     */
-    public List<KeySlice> get_indexed_slices(ColumnParent column_parent, IndexClause index_clause, SlicePredicate column_predicate, ConsistencyLevel consistency_level) throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException;
-
-    /**
-     * Insert a Column at the given column_parent.column_family and optional column_parent.super_column.
-     * 
-     * @param key
-     * @param column_parent
-     * @param column
-     * @param consistency_level
-     */
-    public void insert(ByteBuffer key, ColumnParent column_parent, Column column, ConsistencyLevel consistency_level) throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException;
-
-    /**
-     * Increment or decrement a counter.
-     * 
-     * @param key
-     * @param column_parent
-     * @param column
-     * @param consistency_level
-     */
-    public void add(ByteBuffer key, ColumnParent column_parent, CounterColumn column, ConsistencyLevel consistency_level) throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException;
-
-    /**
-     * Atomic compare and set.
-     * 
-     * If the cas is successfull, the success boolean in CASResult will be true and there will be no current_values.
-     * Otherwise, success will be false and current_values will contain the current values for the columns in
-     * expected (that, by definition of compare-and-set, will differ from the values in expected).
-     * 
-     * A cas operation takes 2 consistency level. The first one, serial_consistency_level, simply indicates the
-     * level of serialization required. This can be either ConsistencyLevel.SERIAL or ConsistencyLevel.LOCAL_SERIAL.
-     * The second one, commit_consistency_level, defines the consistency level for the commit phase of the cas. This
-     * is a more traditional consistency level (the same CL than for traditional writes are accepted) that impact
-     * the visibility for reads of the operation. For instance, if commit_consistency_level is QUORUM, then it is
-     * guaranteed that a followup QUORUM read will see the cas write (if that one was successful obviously). If
-     * commit_consistency_level is ANY, you will need to use a SERIAL/LOCAL_SERIAL read to be guaranteed to see
-     * the write.
-     * 
-     * @param key
-     * @param column_family
-     * @param expected
-     * @param updates
-     * @param serial_consistency_level
-     * @param commit_consistency_level
-     */
-    public CASResult cas(ByteBuffer key, String column_family, List<Column> expected, List<Column> updates, ConsistencyLevel serial_consistency_level, ConsistencyLevel commit_consistency_level) throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException;
-
-    /**
-     * Remove data from the row specified by key at the granularity specified by column_path, and the given timestamp. Note
-     * that all the values in column_path besides column_path.column_family are truly optional: you can remove the entire
-     * row by just specifying the ColumnFamily, or you can remove a SuperColumn or a single Column by specifying those levels too.
-     * 
-     * @param key
-     * @param column_path
-     * @param timestamp
-     * @param consistency_level
-     */
-    public void remove(ByteBuffer key, ColumnPath column_path, long timestamp, ConsistencyLevel consistency_level) throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException;
-
-    /**
-     * Remove a counter at the specified location.
-     * Note that counters have limited support for deletes: if you remove a counter, you must wait to issue any following update
-     * until the delete has reached all the nodes and all of them have been fully compacted.
-     * 
-     * @param key
-     * @param path
-     * @param consistency_level
-     */
-    public void remove_counter(ByteBuffer key, ColumnPath path, ConsistencyLevel consistency_level) throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException;
-
-    /**
-     *   Mutate many columns or super columns for many row keys. See also: Mutation.
-     * 
-     *   mutation_map maps key to column family to a list of Mutation objects to take place at that scope.
-     * *
-     * 
-     * @param mutation_map
-     * @param consistency_level
-     */
-    public void batch_mutate(Map<ByteBuffer,Map<String,List<Mutation>>> mutation_map, ConsistencyLevel consistency_level) throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException;
-
-    /**
-     *   Atomically mutate many columns or super columns for many row keys. See also: Mutation.
-     * 
-     *   mutation_map maps key to column family to a list of Mutation objects to take place at that scope.
-     * *
-     * 
-     * @param mutation_map
-     * @param consistency_level
-     */
-    public void atomic_batch_mutate(Map<ByteBuffer,Map<String,List<Mutation>>> mutation_map, ConsistencyLevel consistency_level) throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException;
-
-    /**
-     * Truncate will mark and entire column family as deleted.
-     * From the user's perspective a successful call to truncate will result complete data deletion from cfname.
-     * Internally, however, disk space will not be immediatily released, as with all deletes in cassandra, this one
-     * only marks the data as deleted.
-     * The operation succeeds only if all hosts in the cluster at available and will throw an UnavailableException if
-     * some hosts are down.
-     * 
-     * @param cfname
-     */
-    public void truncate(String cfname) throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException;
-
-    /**
-     * Select multiple slices of a key in a single RPC operation
-     * 
-     * @param request
-     */
-    public List<ColumnOrSuperColumn> get_multi_slice(MultiSliceRequest request) throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException;
-
-    /**
-     * for each schema version present in the cluster, returns a list of nodes at that version.
-     * hosts that do not respond will be under the key DatabaseDescriptor.INITIAL_VERSION.
-     * the cluster is all on the same version if the size of the map is 1.
-     */
-    public Map<String,List<String>> describe_schema_versions() throws InvalidRequestException, org.apache.thrift.TException;
-
-    /**
-     * list the defined keyspaces in this cluster
-     */
-    public List<KsDef> describe_keyspaces() throws InvalidRequestException, org.apache.thrift.TException;
-
-    /**
-     * get the cluster name
-     */
-    public String describe_cluster_name() throws org.apache.thrift.TException;
-
-    /**
-     * get the thrift api version
-     */
-    public String describe_version() throws org.apache.thrift.TException;
-
-    /**
-     * get the token ring: a map of ranges to host addresses,
-     * represented as a set of TokenRange instead of a map from range
-     * to list of endpoints, because you can't use Thrift structs as
-     * map keys:
-     * https://issues.apache.org/jira/browse/THRIFT-162
-     * 
-     * for the same reason, we can't return a set here, even though
-     * order is neither important nor predictable.
-     * 
-     * @param keyspace
-     */
-    public List<TokenRange> describe_ring(String keyspace) throws InvalidRequestException, org.apache.thrift.TException;
-
-    /**
-     * same as describe_ring, but considers only nodes in the local DC
-     * 
-     * @param keyspace
-     */
-    public List<TokenRange> describe_local_ring(String keyspace) throws InvalidRequestException, org.apache.thrift.TException;
-
-    /**
-     * get the mapping between token->node ip
-     * without taking replication into consideration
-     * https://issues.apache.org/jira/browse/CASSANDRA-4092
-     */
-    public Map<String,String> describe_token_map() throws InvalidRequestException, org.apache.thrift.TException;
-
-    /**
-     * returns the partitioner used by this cluster
-     */
-    public String describe_partitioner() throws org.apache.thrift.TException;
-
-    /**
-     * returns the snitch used by this cluster
-     */
-    public String describe_snitch() throws org.apache.thrift.TException;
-
-    /**
-     * describe specified keyspace
-     * 
-     * @param keyspace
-     */
-    public KsDef describe_keyspace(String keyspace) throws NotFoundException, InvalidRequestException, org.apache.thrift.TException;
-
-    /**
-     * experimental API for hadoop/parallel query support.
-     * may change violently and without warning.
-     * 
-     * returns list of token strings such that first subrange is (list[0], list[1]],
-     * next is (list[1], list[2]], etc.
-     * 
-     * @param cfName
-     * @param start_token
-     * @param end_token
-     * @param keys_per_split
-     */
-    public List<String> describe_splits(String cfName, String start_token, String end_token, int keys_per_split) throws InvalidRequestException, org.apache.thrift.TException;
-
-    /**
-     * Enables tracing for the next query in this connection and returns the UUID for that trace session
-     * The next query will be traced idependently of trace probability and the returned UUID can be used to query the trace keyspace
-     */
-    public ByteBuffer trace_next_query() throws org.apache.thrift.TException;
-
-    public List<CfSplit> describe_splits_ex(String cfName, String start_token, String end_token, int keys_per_split) throws InvalidRequestException, org.apache.thrift.TException;
-
-    /**
-     * adds a column family. returns the new schema id.
-     * 
-     * @param cf_def
-     */
-    public String system_add_column_family(CfDef cf_def) throws InvalidRequestException, SchemaDisagreementException, org.apache.thrift.TException;
-
-    /**
-     * drops a column family. returns the new schema id.
-     * 
-     * @param column_family
-     */
-    public String system_drop_column_family(String column_family) throws InvalidRequestException, SchemaDisagreementException, org.apache.thrift.TException;
-
-    /**
-     * adds a keyspace and any column families that are part of it. returns the new schema id.
-     * 
-     * @param ks_def
-     */
-    public String system_add_keyspace(KsDef ks_def) throws InvalidRequestException, SchemaDisagreementException, org.apache.thrift.TException;
-
-    /**
-     * drops a keyspace and any column families that are part of it. returns the new schema id.
-     * 
-     * @param keyspace
-     */
-    public String system_drop_keyspace(String keyspace) throws InvalidRequestException, SchemaDisagreementException, org.apache.thrift.TException;
-
-    /**
-     * updates properties of a keyspace. returns the new schema id.
-     * 
-     * @param ks_def
-     */
-    public String system_update_keyspace(KsDef ks_def) throws InvalidRequestException, SchemaDisagreementException, org.apache.thrift.TException;
-
-    /**
-     * updates properties of a column family. returns the new schema id.
-     * 
-     * @param cf_def
-     */
-    public String system_update_column_family(CfDef cf_def) throws InvalidRequestException, SchemaDisagreementException, org.apache.thrift.TException;
-
-    /**
-     * @deprecated Throws InvalidRequestException since 2.2. Please use the CQL3 version instead.
-     * 
-     * @param query
-     * @param compression
-     */
-    public CqlResult execute_cql_query(ByteBuffer query, Compression compression) throws InvalidRequestException, UnavailableException, TimedOutException, SchemaDisagreementException, org.apache.thrift.TException;
-
-    /**
-     * Executes a CQL3 (Cassandra Query Language) statement and returns a
-     * CqlResult containing the results.
-     * 
-     * @param query
-     * @param compression
-     * @param consistency
-     */
-    public CqlResult execute_cql3_query(ByteBuffer query, Compression compression, ConsistencyLevel consistency) throws InvalidRequestException, UnavailableException, TimedOutException, SchemaDisagreementException, org.apache.thrift.TException;
-
-    /**
-     * @deprecated Throws InvalidRequestException since 2.2. Please use the CQL3 version instead.
-     * 
-     * @param query
-     * @param compression
-     */
-    public CqlPreparedResult prepare_cql_query(ByteBuffer query, Compression compression) throws InvalidRequestException, org.apache.thrift.TException;
-
-    /**
-     * Prepare a CQL3 (Cassandra Query Language) statement by compiling and returning
-     * - the type of CQL statement
-     * - an id token of the compiled CQL stored on the server side.
-     * - a count of the discovered bound markers in the statement
-     * 
-     * @param query
-     * @param compression
-     */
-    public CqlPreparedResult prepare_cql3_query(ByteBuffer query, Compression compression) throws InvalidRequestException, org.apache.thrift.TException;
-
-    /**
-     * @deprecated Throws InvalidRequestException since 2.2. Please use the CQL3 version instead.
-     * 
-     * @param itemId
-     * @param values
-     */
-    public CqlResult execute_prepared_cql_query(int itemId, List<ByteBuffer> values) throws InvalidRequestException, UnavailableException, TimedOutException, SchemaDisagreementException, org.apache.thrift.TException;
-
-    /**
-     * Executes a prepared CQL3 (Cassandra Query Language) statement by passing an id token, a list of variables
-     * to bind, and the consistency level, and returns a CqlResult containing the results.
-     * 
-     * @param itemId
-     * @param values
-     * @param consistency
-     */
-    public CqlResult execute_prepared_cql3_query(int itemId, List<ByteBuffer> values, ConsistencyLevel consistency) throws InvalidRequestException, UnavailableException, TimedOutException, SchemaDisagreementException, org.apache.thrift.TException;
-
-    /**
-     * @deprecated This is now a no-op. Please use the CQL3 specific methods instead.
-     * 
-     * @param version
-     */
-    public void set_cql_version(String version) throws InvalidRequestException, org.apache.thrift.TException;
-
-  }
-
-  public interface AsyncIface {
-
-    public void login(AuthenticationRequest auth_request, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void set_keyspace(String keyspace, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void get(ByteBuffer key, ColumnPath column_path, ConsistencyLevel consistency_level, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void get_slice(ByteBuffer key, ColumnParent column_parent, SlicePredicate predicate, ConsistencyLevel consistency_level, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void get_count(ByteBuffer key, ColumnParent column_parent, SlicePredicate predicate, ConsistencyLevel consistency_level, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void multiget_slice(List<ByteBuffer> keys, ColumnParent column_parent, SlicePredicate predicate, ConsistencyLevel consistency_level, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void multiget_count(List<ByteBuffer> keys, ColumnParent column_parent, SlicePredicate predicate, ConsistencyLevel consistency_level, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void get_range_slices(ColumnParent column_parent, SlicePredicate predicate, KeyRange range, ConsistencyLevel consistency_level, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void get_paged_slice(String column_family, KeyRange range, ByteBuffer start_column, ConsistencyLevel consistency_level, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void get_indexed_slices(ColumnParent column_parent, IndexClause index_clause, SlicePredicate column_predicate, ConsistencyLevel consistency_level, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void insert(ByteBuffer key, ColumnParent column_parent, Column column, ConsistencyLevel consistency_level, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void add(ByteBuffer key, ColumnParent column_parent, CounterColumn column, ConsistencyLevel consistency_level, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void cas(ByteBuffer key, String column_family, List<Column> expected, List<Column> updates, ConsistencyLevel serial_consistency_level, ConsistencyLevel commit_consistency_level, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void remove(ByteBuffer key, ColumnPath column_path, long timestamp, ConsistencyLevel consistency_level, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void remove_counter(ByteBuffer key, ColumnPath path, ConsistencyLevel consistency_level, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void batch_mutate(Map<ByteBuffer,Map<String,List<Mutation>>> mutation_map, ConsistencyLevel consistency_level, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void atomic_batch_mutate(Map<ByteBuffer,Map<String,List<Mutation>>> mutation_map, ConsistencyLevel consistency_level, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void truncate(String cfname, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void get_multi_slice(MultiSliceRequest request, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void describe_schema_versions(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void describe_keyspaces(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void describe_cluster_name(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void describe_version(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void describe_ring(String keyspace, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void describe_local_ring(String keyspace, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void describe_token_map(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void describe_partitioner(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void describe_snitch(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void describe_keyspace(String keyspace, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void describe_splits(String cfName, String start_token, String end_token, int keys_per_split, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void trace_next_query(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void describe_splits_ex(String cfName, String start_token, String end_token, int keys_per_split, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void system_add_column_family(CfDef cf_def, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void system_drop_column_family(String column_family, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void system_add_keyspace(KsDef ks_def, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void system_drop_keyspace(String keyspace, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void system_update_keyspace(KsDef ks_def, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void system_update_column_family(CfDef cf_def, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void execute_cql_query(ByteBuffer query, Compression compression, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void execute_cql3_query(ByteBuffer query, Compression compression, ConsistencyLevel consistency, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void prepare_cql_query(ByteBuffer query, Compression compression, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void prepare_cql3_query(ByteBuffer query, Compression compression, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void execute_prepared_cql_query(int itemId, List<ByteBuffer> values, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void execute_prepared_cql3_query(int itemId, List<ByteBuffer> values, ConsistencyLevel consistency, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
-    public void set_cql_version(String version, 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 login(AuthenticationRequest auth_request) throws AuthenticationException, AuthorizationException, org.apache.thrift.TException
-    {
-      send_login(auth_request);
-      recv_login();
-    }
-
-    public void send_login(AuthenticationRequest auth_request) throws org.apache.thrift.TException
-    {
-      login_args args = new login_args();
-      args.setAuth_request(auth_request);
-      sendBase("login", args);
-    }
-
-    public void recv_login() throws AuthenticationException, AuthorizationException, org.apache.thrift.TException
-    {
-      login_result result = new login_result();
-      receiveBase(result, "login");
-      if (result.authnx != null) {
-        throw result.authnx;
-      }
-      if (result.authzx != null) {
-        throw result.authzx;
-      }
-      return;
-    }
-
-    public void set_keyspace(String keyspace) throws InvalidRequestException, org.apache.thrift.TException
-    {
-      send_set_keyspace(keyspace);
-      recv_set_keyspace();
-    }
-
-    public void send_set_keyspace(String keyspace) throws org.apache.thrift.TException
-    {
-      set_keyspace_args args = new set_keyspace_args();
-      args.setKeyspace(keyspace);
-      sendBase("set_keyspace", args);
-    }
-
-    public void recv_set_keyspace() throws InvalidRequestException, org.apache.thrift.TException
-    {
-      set_keyspace_result result = new set_keyspace_result();
-      receiveBase(result, "set_keyspace");
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      return;
-    }
-
-    public ColumnOrSuperColumn get(ByteBuffer key, ColumnPath column_path, ConsistencyLevel consistency_level) throws InvalidRequestException, NotFoundException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      send_get(key, column_path, consistency_level);
-      return recv_get();
-    }
-
-    public void send_get(ByteBuffer key, ColumnPath column_path, ConsistencyLevel consistency_level) throws org.apache.thrift.TException
-    {
-      get_args args = new get_args();
-      args.setKey(key);
-      args.setColumn_path(column_path);
-      args.setConsistency_level(consistency_level);
-      sendBase("get", args);
-    }
-
-    public ColumnOrSuperColumn recv_get() throws InvalidRequestException, NotFoundException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      get_result result = new get_result();
-      receiveBase(result, "get");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      if (result.nfe != null) {
-        throw result.nfe;
-      }
-      if (result.ue != null) {
-        throw result.ue;
-      }
-      if (result.te != null) {
-        throw result.te;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "get failed: unknown result");
-    }
-
-    public List<ColumnOrSuperColumn> get_slice(ByteBuffer key, ColumnParent column_parent, SlicePredicate predicate, ConsistencyLevel consistency_level) throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      send_get_slice(key, column_parent, predicate, consistency_level);
-      return recv_get_slice();
-    }
-
-    public void send_get_slice(ByteBuffer key, ColumnParent column_parent, SlicePredicate predicate, ConsistencyLevel consistency_level) throws org.apache.thrift.TException
-    {
-      get_slice_args args = new get_slice_args();
-      args.setKey(key);
-      args.setColumn_parent(column_parent);
-      args.setPredicate(predicate);
-      args.setConsistency_level(consistency_level);
-      sendBase("get_slice", args);
-    }
-
-    public List<ColumnOrSuperColumn> recv_get_slice() throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      get_slice_result result = new get_slice_result();
-      receiveBase(result, "get_slice");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      if (result.ue != null) {
-        throw result.ue;
-      }
-      if (result.te != null) {
-        throw result.te;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "get_slice failed: unknown result");
-    }
-
-    public int get_count(ByteBuffer key, ColumnParent column_parent, SlicePredicate predicate, ConsistencyLevel consistency_level) throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      send_get_count(key, column_parent, predicate, consistency_level);
-      return recv_get_count();
-    }
-
-    public void send_get_count(ByteBuffer key, ColumnParent column_parent, SlicePredicate predicate, ConsistencyLevel consistency_level) throws org.apache.thrift.TException
-    {
-      get_count_args args = new get_count_args();
-      args.setKey(key);
-      args.setColumn_parent(column_parent);
-      args.setPredicate(predicate);
-      args.setConsistency_level(consistency_level);
-      sendBase("get_count", args);
-    }
-
-    public int recv_get_count() throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      get_count_result result = new get_count_result();
-      receiveBase(result, "get_count");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      if (result.ue != null) {
-        throw result.ue;
-      }
-      if (result.te != null) {
-        throw result.te;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "get_count failed: unknown result");
-    }
-
-    public Map<ByteBuffer,List<ColumnOrSuperColumn>> multiget_slice(List<ByteBuffer> keys, ColumnParent column_parent, SlicePredicate predicate, ConsistencyLevel consistency_level) throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      send_multiget_slice(keys, column_parent, predicate, consistency_level);
-      return recv_multiget_slice();
-    }
-
-    public void send_multiget_slice(List<ByteBuffer> keys, ColumnParent column_parent, SlicePredicate predicate, ConsistencyLevel consistency_level) throws org.apache.thrift.TException
-    {
-      multiget_slice_args args = new multiget_slice_args();
-      args.setKeys(keys);
-      args.setColumn_parent(column_parent);
-      args.setPredicate(predicate);
-      args.setConsistency_level(consistency_level);
-      sendBase("multiget_slice", args);
-    }
-
-    public Map<ByteBuffer,List<ColumnOrSuperColumn>> recv_multiget_slice() throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      multiget_slice_result result = new multiget_slice_result();
-      receiveBase(result, "multiget_slice");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      if (result.ue != null) {
-        throw result.ue;
-      }
-      if (result.te != null) {
-        throw result.te;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "multiget_slice failed: unknown result");
-    }
-
-    public Map<ByteBuffer,Integer> multiget_count(List<ByteBuffer> keys, ColumnParent column_parent, SlicePredicate predicate, ConsistencyLevel consistency_level) throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      send_multiget_count(keys, column_parent, predicate, consistency_level);
-      return recv_multiget_count();
-    }
-
-    public void send_multiget_count(List<ByteBuffer> keys, ColumnParent column_parent, SlicePredicate predicate, ConsistencyLevel consistency_level) throws org.apache.thrift.TException
-    {
-      multiget_count_args args = new multiget_count_args();
-      args.setKeys(keys);
-      args.setColumn_parent(column_parent);
-      args.setPredicate(predicate);
-      args.setConsistency_level(consistency_level);
-      sendBase("multiget_count", args);
-    }
-
-    public Map<ByteBuffer,Integer> recv_multiget_count() throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      multiget_count_result result = new multiget_count_result();
-      receiveBase(result, "multiget_count");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      if (result.ue != null) {
-        throw result.ue;
-      }
-      if (result.te != null) {
-        throw result.te;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "multiget_count failed: unknown result");
-    }
-
-    public List<KeySlice> get_range_slices(ColumnParent column_parent, SlicePredicate predicate, KeyRange range, ConsistencyLevel consistency_level) throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      send_get_range_slices(column_parent, predicate, range, consistency_level);
-      return recv_get_range_slices();
-    }
-
-    public void send_get_range_slices(ColumnParent column_parent, SlicePredicate predicate, KeyRange range, ConsistencyLevel consistency_level) throws org.apache.thrift.TException
-    {
-      get_range_slices_args args = new get_range_slices_args();
-      args.setColumn_parent(column_parent);
-      args.setPredicate(predicate);
-      args.setRange(range);
-      args.setConsistency_level(consistency_level);
-      sendBase("get_range_slices", args);
-    }
-
-    public List<KeySlice> recv_get_range_slices() throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      get_range_slices_result result = new get_range_slices_result();
-      receiveBase(result, "get_range_slices");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      if (result.ue != null) {
-        throw result.ue;
-      }
-      if (result.te != null) {
-        throw result.te;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "get_range_slices failed: unknown result");
-    }
-
-    public List<KeySlice> get_paged_slice(String column_family, KeyRange range, ByteBuffer start_column, ConsistencyLevel consistency_level) throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      send_get_paged_slice(column_family, range, start_column, consistency_level);
-      return recv_get_paged_slice();
-    }
-
-    public void send_get_paged_slice(String column_family, KeyRange range, ByteBuffer start_column, ConsistencyLevel consistency_level) throws org.apache.thrift.TException
-    {
-      get_paged_slice_args args = new get_paged_slice_args();
-      args.setColumn_family(column_family);
-      args.setRange(range);
-      args.setStart_column(start_column);
-      args.setConsistency_level(consistency_level);
-      sendBase("get_paged_slice", args);
-    }
-
-    public List<KeySlice> recv_get_paged_slice() throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      get_paged_slice_result result = new get_paged_slice_result();
-      receiveBase(result, "get_paged_slice");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      if (result.ue != null) {
-        throw result.ue;
-      }
-      if (result.te != null) {
-        throw result.te;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "get_paged_slice failed: unknown result");
-    }
-
-    public List<KeySlice> get_indexed_slices(ColumnParent column_parent, IndexClause index_clause, SlicePredicate column_predicate, ConsistencyLevel consistency_level) throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      send_get_indexed_slices(column_parent, index_clause, column_predicate, consistency_level);
-      return recv_get_indexed_slices();
-    }
-
-    public void send_get_indexed_slices(ColumnParent column_parent, IndexClause index_clause, SlicePredicate column_predicate, ConsistencyLevel consistency_level) throws org.apache.thrift.TException
-    {
-      get_indexed_slices_args args = new get_indexed_slices_args();
-      args.setColumn_parent(column_parent);
-      args.setIndex_clause(index_clause);
-      args.setColumn_predicate(column_predicate);
-      args.setConsistency_level(consistency_level);
-      sendBase("get_indexed_slices", args);
-    }
-
-    public List<KeySlice> recv_get_indexed_slices() throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      get_indexed_slices_result result = new get_indexed_slices_result();
-      receiveBase(result, "get_indexed_slices");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      if (result.ue != null) {
-        throw result.ue;
-      }
-      if (result.te != null) {
-        throw result.te;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "get_indexed_slices failed: unknown result");
-    }
-
-    public void insert(ByteBuffer key, ColumnParent column_parent, Column column, ConsistencyLevel consistency_level) throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      send_insert(key, column_parent, column, consistency_level);
-      recv_insert();
-    }
-
-    public void send_insert(ByteBuffer key, ColumnParent column_parent, Column column, ConsistencyLevel consistency_level) throws org.apache.thrift.TException
-    {
-      insert_args args = new insert_args();
-      args.setKey(key);
-      args.setColumn_parent(column_parent);
-      args.setColumn(column);
-      args.setConsistency_level(consistency_level);
-      sendBase("insert", args);
-    }
-
-    public void recv_insert() throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      insert_result result = new insert_result();
-      receiveBase(result, "insert");
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      if (result.ue != null) {
-        throw result.ue;
-      }
-      if (result.te != null) {
-        throw result.te;
-      }
-      return;
-    }
-
-    public void add(ByteBuffer key, ColumnParent column_parent, CounterColumn column, ConsistencyLevel consistency_level) throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      send_add(key, column_parent, column, consistency_level);
-      recv_add();
-    }
-
-    public void send_add(ByteBuffer key, ColumnParent column_parent, CounterColumn column, ConsistencyLevel consistency_level) throws org.apache.thrift.TException
-    {
-      add_args args = new add_args();
-      args.setKey(key);
-      args.setColumn_parent(column_parent);
-      args.setColumn(column);
-      args.setConsistency_level(consistency_level);
-      sendBase("add", args);
-    }
-
-    public void recv_add() throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      add_result result = new add_result();
-      receiveBase(result, "add");
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      if (result.ue != null) {
-        throw result.ue;
-      }
-      if (result.te != null) {
-        throw result.te;
-      }
-      return;
-    }
-
-    public CASResult cas(ByteBuffer key, String column_family, List<Column> expected, List<Column> updates, ConsistencyLevel serial_consistency_level, ConsistencyLevel commit_consistency_level) throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      send_cas(key, column_family, expected, updates, serial_consistency_level, commit_consistency_level);
-      return recv_cas();
-    }
-
-    public void send_cas(ByteBuffer key, String column_family, List<Column> expected, List<Column> updates, ConsistencyLevel serial_consistency_level, ConsistencyLevel commit_consistency_level) throws org.apache.thrift.TException
-    {
-      cas_args args = new cas_args();
-      args.setKey(key);
-      args.setColumn_family(column_family);
-      args.setExpected(expected);
-      args.setUpdates(updates);
-      args.setSerial_consistency_level(serial_consistency_level);
-      args.setCommit_consistency_level(commit_consistency_level);
-      sendBase("cas", args);
-    }
-
-    public CASResult recv_cas() throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      cas_result result = new cas_result();
-      receiveBase(result, "cas");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      if (result.ue != null) {
-        throw result.ue;
-      }
-      if (result.te != null) {
-        throw result.te;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "cas failed: unknown result");
-    }
-
-    public void remove(ByteBuffer key, ColumnPath column_path, long timestamp, ConsistencyLevel consistency_level) throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      send_remove(key, column_path, timestamp, consistency_level);
-      recv_remove();
-    }
-
-    public void send_remove(ByteBuffer key, ColumnPath column_path, long timestamp, ConsistencyLevel consistency_level) throws org.apache.thrift.TException
-    {
-      remove_args args = new remove_args();
-      args.setKey(key);
-      args.setColumn_path(column_path);
-      args.setTimestamp(timestamp);
-      args.setConsistency_level(consistency_level);
-      sendBase("remove", args);
-    }
-
-    public void recv_remove() throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      remove_result result = new remove_result();
-      receiveBase(result, "remove");
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      if (result.ue != null) {
-        throw result.ue;
-      }
-      if (result.te != null) {
-        throw result.te;
-      }
-      return;
-    }
-
-    public void remove_counter(ByteBuffer key, ColumnPath path, ConsistencyLevel consistency_level) throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      send_remove_counter(key, path, consistency_level);
-      recv_remove_counter();
-    }
-
-    public void send_remove_counter(ByteBuffer key, ColumnPath path, ConsistencyLevel consistency_level) throws org.apache.thrift.TException
-    {
-      remove_counter_args args = new remove_counter_args();
-      args.setKey(key);
-      args.setPath(path);
-      args.setConsistency_level(consistency_level);
-      sendBase("remove_counter", args);
-    }
-
-    public void recv_remove_counter() throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      remove_counter_result result = new remove_counter_result();
-      receiveBase(result, "remove_counter");
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      if (result.ue != null) {
-        throw result.ue;
-      }
-      if (result.te != null) {
-        throw result.te;
-      }
-      return;
-    }
-
-    public void batch_mutate(Map<ByteBuffer,Map<String,List<Mutation>>> mutation_map, ConsistencyLevel consistency_level) throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      send_batch_mutate(mutation_map, consistency_level);
-      recv_batch_mutate();
-    }
-
-    public void send_batch_mutate(Map<ByteBuffer,Map<String,List<Mutation>>> mutation_map, ConsistencyLevel consistency_level) throws org.apache.thrift.TException
-    {
-      batch_mutate_args args = new batch_mutate_args();
-      args.setMutation_map(mutation_map);
-      args.setConsistency_level(consistency_level);
-      sendBase("batch_mutate", args);
-    }
-
-    public void recv_batch_mutate() throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      batch_mutate_result result = new batch_mutate_result();
-      receiveBase(result, "batch_mutate");
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      if (result.ue != null) {
-        throw result.ue;
-      }
-      if (result.te != null) {
-        throw result.te;
-      }
-      return;
-    }
-
-    public void atomic_batch_mutate(Map<ByteBuffer,Map<String,List<Mutation>>> mutation_map, ConsistencyLevel consistency_level) throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      send_atomic_batch_mutate(mutation_map, consistency_level);
-      recv_atomic_batch_mutate();
-    }
-
-    public void send_atomic_batch_mutate(Map<ByteBuffer,Map<String,List<Mutation>>> mutation_map, ConsistencyLevel consistency_level) throws org.apache.thrift.TException
-    {
-      atomic_batch_mutate_args args = new atomic_batch_mutate_args();
-      args.setMutation_map(mutation_map);
-      args.setConsistency_level(consistency_level);
-      sendBase("atomic_batch_mutate", args);
-    }
-
-    public void recv_atomic_batch_mutate() throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      atomic_batch_mutate_result result = new atomic_batch_mutate_result();
-      receiveBase(result, "atomic_batch_mutate");
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      if (result.ue != null) {
-        throw result.ue;
-      }
-      if (result.te != null) {
-        throw result.te;
-      }
-      return;
-    }
-
-    public void truncate(String cfname) throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      send_truncate(cfname);
-      recv_truncate();
-    }
-
-    public void send_truncate(String cfname) throws org.apache.thrift.TException
-    {
-      truncate_args args = new truncate_args();
-      args.setCfname(cfname);
-      sendBase("truncate", args);
-    }
-
-    public void recv_truncate() throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      truncate_result result = new truncate_result();
-      receiveBase(result, "truncate");
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      if (result.ue != null) {
-        throw result.ue;
-      }
-      if (result.te != null) {
-        throw result.te;
-      }
-      return;
-    }
-
-    public List<ColumnOrSuperColumn> get_multi_slice(MultiSliceRequest request) throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      send_get_multi_slice(request);
-      return recv_get_multi_slice();
-    }
-
-    public void send_get_multi_slice(MultiSliceRequest request) throws org.apache.thrift.TException
-    {
-      get_multi_slice_args args = new get_multi_slice_args();
-      args.setRequest(request);
-      sendBase("get_multi_slice", args);
-    }
-
-    public List<ColumnOrSuperColumn> recv_get_multi_slice() throws InvalidRequestException, UnavailableException, TimedOutException, org.apache.thrift.TException
-    {
-      get_multi_slice_result result = new get_multi_slice_result();
-      receiveBase(result, "get_multi_slice");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      if (result.ue != null) {
-        throw result.ue;
-      }
-      if (result.te != null) {
-        throw result.te;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "get_multi_slice failed: unknown result");
-    }
-
-    public Map<String,List<String>> describe_schema_versions() throws InvalidRequestException, org.apache.thrift.TException
-    {
-      send_describe_schema_versions();
-      return recv_describe_schema_versions();
-    }
-
-    public void send_describe_schema_versions() throws org.apache.thrift.TException
-    {
-      describe_schema_versions_args args = new describe_schema_versions_args();
-      sendBase("describe_schema_versions", args);
-    }
-
-    public Map<String,List<String>> recv_describe_schema_versions() throws InvalidRequestException, org.apache.thrift.TException
-    {
-      describe_schema_versions_result result = new describe_schema_versions_result();
-      receiveBase(result, "describe_schema_versions");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "describe_schema_versions failed: unknown result");
-    }
-
-    public List<KsDef> describe_keyspaces() throws InvalidRequestException, org.apache.thrift.TException
-    {
-      send_describe_keyspaces();
-      return recv_describe_keyspaces();
-    }
-
-    public void send_describe_keyspaces() throws org.apache.thrift.TException
-    {
-      describe_keyspaces_args args = new describe_keyspaces_args();
-      sendBase("describe_keyspaces", args);
-    }
-
-    public List<KsDef> recv_describe_keyspaces() throws InvalidRequestException, org.apache.thrift.TException
-    {
-      describe_keyspaces_result result = new describe_keyspaces_result();
-      receiveBase(result, "describe_keyspaces");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "describe_keyspaces failed: unknown result");
-    }
-
-    public String describe_cluster_name() throws org.apache.thrift.TException
-    {
-      send_describe_cluster_name();
-      return recv_describe_cluster_name();
-    }
-
-    public void send_describe_cluster_name() throws org.apache.thrift.TException
-    {
-      describe_cluster_name_args args = new describe_cluster_name_args();
-      sendBase("describe_cluster_name", args);
-    }
-
-    public String recv_describe_cluster_name() throws org.apache.thrift.TException
-    {
-      describe_cluster_name_result result = new describe_cluster_name_result();
-      receiveBase(result, "describe_cluster_name");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "describe_cluster_name failed: unknown result");
-    }
-
-    public String describe_version() throws org.apache.thrift.TException
-    {
-      send_describe_version();
-      return recv_describe_version();
-    }
-
-    public void send_describe_version() throws org.apache.thrift.TException
-    {
-      describe_version_args args = new describe_version_args();
-      sendBase("describe_version", args);
-    }
-
-    public String recv_describe_version() throws org.apache.thrift.TException
-    {
-      describe_version_result result = new describe_version_result();
-      receiveBase(result, "describe_version");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "describe_version failed: unknown result");
-    }
-
-    public List<TokenRange> describe_ring(String keyspace) throws InvalidRequestException, org.apache.thrift.TException
-    {
-      send_describe_ring(keyspace);
-      return recv_describe_ring();
-    }
-
-    public void send_describe_ring(String keyspace) throws org.apache.thrift.TException
-    {
-      describe_ring_args args = new describe_ring_args();
-      args.setKeyspace(keyspace);
-      sendBase("describe_ring", args);
-    }
-
-    public List<TokenRange> recv_describe_ring() throws InvalidRequestException, org.apache.thrift.TException
-    {
-      describe_ring_result result = new describe_ring_result();
-      receiveBase(result, "describe_ring");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "describe_ring failed: unknown result");
-    }
-
-    public List<TokenRange> describe_local_ring(String keyspace) throws InvalidRequestException, org.apache.thrift.TException
-    {
-      send_describe_local_ring(keyspace);
-      return recv_describe_local_ring();
-    }
-
-    public void send_describe_local_ring(String keyspace) throws org.apache.thrift.TException
-    {
-      describe_local_ring_args args = new describe_local_ring_args();
-      args.setKeyspace(keyspace);
-      sendBase("describe_local_ring", args);
-    }
-
-    public List<TokenRange> recv_describe_local_ring() throws InvalidRequestException, org.apache.thrift.TException
-    {
-      describe_local_ring_result result = new describe_local_ring_result();
-      receiveBase(result, "describe_local_ring");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "describe_local_ring failed: unknown result");
-    }
-
-    public Map<String,String> describe_token_map() throws InvalidRequestException, org.apache.thrift.TException
-    {
-      send_describe_token_map();
-      return recv_describe_token_map();
-    }
-
-    public void send_describe_token_map() throws org.apache.thrift.TException
-    {
-      describe_token_map_args args = new describe_token_map_args();
-      sendBase("describe_token_map", args);
-    }
-
-    public Map<String,String> recv_describe_token_map() throws InvalidRequestException, org.apache.thrift.TException
-    {
-      describe_token_map_result result = new describe_token_map_result();
-      receiveBase(result, "describe_token_map");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "describe_token_map failed: unknown result");
-    }
-
-    public String describe_partitioner() throws org.apache.thrift.TException
-    {
-      send_describe_partitioner();
-      return recv_describe_partitioner();
-    }
-
-    public void send_describe_partitioner() throws org.apache.thrift.TException
-    {
-      describe_partitioner_args args = new describe_partitioner_args();
-      sendBase("describe_partitioner", args);
-    }
-
-    public String recv_describe_partitioner() throws org.apache.thrift.TException
-    {
-      describe_partitioner_result result = new describe_partitioner_result();
-      receiveBase(result, "describe_partitioner");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "describe_partitioner failed: unknown result");
-    }
-
-    public String describe_snitch() throws org.apache.thrift.TException
-    {
-      send_describe_snitch();
-      return recv_describe_snitch();
-    }
-
-    public void send_describe_snitch() throws org.apache.thrift.TException
-    {
-      describe_snitch_args args = new describe_snitch_args();
-      sendBase("describe_snitch", args);
-    }
-
-    public String recv_describe_snitch() throws org.apache.thrift.TException
-    {
-      describe_snitch_result result = new describe_snitch_result();
-      receiveBase(result, "describe_snitch");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "describe_snitch failed: unknown result");
-    }
-
-    public KsDef describe_keyspace(String keyspace) throws NotFoundException, InvalidRequestException, org.apache.thrift.TException
-    {
-      send_describe_keyspace(keyspace);
-      return recv_describe_keyspace();
-    }
-
-    public void send_describe_keyspace(String keyspace) throws org.apache.thrift.TException
-    {
-      describe_keyspace_args args = new describe_keyspace_args();
-      args.setKeyspace(keyspace);
-      sendBase("describe_keyspace", args);
-    }
-
-    public KsDef recv_describe_keyspace() throws NotFoundException, InvalidRequestException, org.apache.thrift.TException
-    {
-      describe_keyspace_result result = new describe_keyspace_result();
-      receiveBase(result, "describe_keyspace");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      if (result.nfe != null) {
-        throw result.nfe;
-      }
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "describe_keyspace failed: unknown result");
-    }
-
-    public List<String> describe_splits(String cfName, String start_token, String end_token, int keys_per_split) throws InvalidRequestException, org.apache.thrift.TException
-    {
-      send_describe_splits(cfName, start_token, end_token, keys_per_split);
-      return recv_describe_splits();
-    }
-
-    public void send_describe_splits(String cfName, String start_token, String end_token, int keys_per_split) throws org.apache.thrift.TException
-    {
-      describe_splits_args args = new describe_splits_args();
-      args.setCfName(cfName);
-      args.setStart_token(start_token);
-      args.setEnd_token(end_token);
-      args.setKeys_per_split(keys_per_split);
-      sendBase("describe_splits", args);
-    }
-
-    public List<String> recv_describe_splits() throws InvalidRequestException, org.apache.thrift.TException
-    {
-      describe_splits_result result = new describe_splits_result();
-      receiveBase(result, "describe_splits");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "describe_splits failed: unknown result");
-    }
-
-    public ByteBuffer trace_next_query() throws org.apache.thrift.TException
-    {
-      send_trace_next_query();
-      return recv_trace_next_query();
-    }
-
-    public void send_trace_next_query() throws org.apache.thrift.TException
-    {
-      trace_next_query_args args = new trace_next_query_args();
-      sendBase("trace_next_query", args);
-    }
-
-    public ByteBuffer recv_trace_next_query() throws org.apache.thrift.TException
-    {
-      trace_next_query_result result = new trace_next_query_result();
-      receiveBase(result, "trace_next_query");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "trace_next_query failed: unknown result");
-    }
-
-    public List<CfSplit> describe_splits_ex(String cfName, String start_token, String end_token, int keys_per_split) throws InvalidRequestException, org.apache.thrift.TException
-    {
-      send_describe_splits_ex(cfName, start_token, end_token, keys_per_split);
-      return recv_describe_splits_ex();
-    }
-
-    public void send_describe_splits_ex(String cfName, String start_token, String end_token, int keys_per_split) throws org.apache.thrift.TException
-    {
-      describe_splits_ex_args args = new describe_splits_ex_args();
-      args.setCfName(cfName);
-      args.setStart_token(start_token);
-      args.setEnd_token(end_token);
-      args.setKeys_per_split(keys_per_split);
-      sendBase("describe_splits_ex", args);
-    }
-
-    public List<CfSplit> recv_describe_splits_ex() throws InvalidRequestException, org.apache.thrift.TException
-    {
-      describe_splits_ex_result result = new describe_splits_ex_result();
-      receiveBase(result, "describe_splits_ex");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "describe_splits_ex failed: unknown result");
-    }
-
-    public String system_add_column_family(CfDef cf_def) throws InvalidRequestException, SchemaDisagreementException, org.apache.thrift.TException
-    {
-      send_system_add_column_family(cf_def);
-      return recv_system_add_column_family();
-    }
-
-    public void send_system_add_column_family(CfDef cf_def) throws org.apache.thrift.TException
-    {
-      system_add_column_family_args args = new system_add_column_family_args();
-      args.setCf_def(cf_def);
-      sendBase("system_add_column_family", args);
-    }
-
-    public String recv_system_add_column_family() throws InvalidRequestException, SchemaDisagreementException, org.apache.thrift.TException
-    {
-      system_add_column_family_result result = new system_add_column_family_result();
-      receiveBase(result, "system_add_column_family");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      if (result.sde != null) {
-        throw result.sde;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "system_add_column_family failed: unknown result");
-    }
-
-    public String system_drop_column_family(String column_family) throws InvalidRequestException, SchemaDisagreementException, org.apache.thrift.TException
-    {
-      send_system_drop_column_family(column_family);
-      return recv_system_drop_column_family();
-    }
-
-    public void send_system_drop_column_family(String column_family) throws org.apache.thrift.TException
-    {
-      system_drop_column_family_args args = new system_drop_column_family_args();
-      args.setColumn_family(column_family);
-      sendBase("system_drop_column_family", args);
-    }
-
-    public String recv_system_drop_column_family() throws InvalidRequestException, SchemaDisagreementException, org.apache.thrift.TException
-    {
-      system_drop_column_family_result result = new system_drop_column_family_result();
-      receiveBase(result, "system_drop_column_family");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      if (result.sde != null) {
-        throw result.sde;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "system_drop_column_family failed: unknown result");
-    }
-
-    public String system_add_keyspace(KsDef ks_def) throws InvalidRequestException, SchemaDisagreementException, org.apache.thrift.TException
-    {
-      send_system_add_keyspace(ks_def);
-      return recv_system_add_keyspace();
-    }
-
-    public void send_system_add_keyspace(KsDef ks_def) throws org.apache.thrift.TException
-    {
-      system_add_keyspace_args args = new system_add_keyspace_args();
-      args.setKs_def(ks_def);
-      sendBase("system_add_keyspace", args);
-    }
-
-    public String recv_system_add_keyspace() throws InvalidRequestException, SchemaDisagreementException, org.apache.thrift.TException
-    {
-      system_add_keyspace_result result = new system_add_keyspace_result();
-      receiveBase(result, "system_add_keyspace");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      if (result.sde != null) {
-        throw result.sde;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "system_add_keyspace failed: unknown result");
-    }
-
-    public String system_drop_keyspace(String keyspace) throws InvalidRequestException, SchemaDisagreementException, org.apache.thrift.TException
-    {
-      send_system_drop_keyspace(keyspace);
-      return recv_system_drop_keyspace();
-    }
-
-    public void send_system_drop_keyspace(String keyspace) throws org.apache.thrift.TException
-    {
-      system_drop_keyspace_args args = new system_drop_keyspace_args();
-      args.setKeyspace(keyspace);
-      sendBase("system_drop_keyspace", args);
-    }
-
-    public String recv_system_drop_keyspace() throws InvalidRequestException, SchemaDisagreementException, org.apache.thrift.TException
-    {
-      system_drop_keyspace_result result = new system_drop_keyspace_result();
-      receiveBase(result, "system_drop_keyspace");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      if (result.sde != null) {
-        throw result.sde;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "system_drop_keyspace failed: unknown result");
-    }
-
-    public String system_update_keyspace(KsDef ks_def) throws InvalidRequestException, SchemaDisagreementException, org.apache.thrift.TException
-    {
-      send_system_update_keyspace(ks_def);
-      return recv_system_update_keyspace();
-    }
-
-    public void send_system_update_keyspace(KsDef ks_def) throws org.apache.thrift.TException
-    {
-      system_update_keyspace_args args = new system_update_keyspace_args();
-      args.setKs_def(ks_def);
-      sendBase("system_update_keyspace", args);
-    }
-
-    public String recv_system_update_keyspace() throws InvalidRequestException, SchemaDisagreementException, org.apache.thrift.TException
-    {
-      system_update_keyspace_result result = new system_update_keyspace_result();
-      receiveBase(result, "system_update_keyspace");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      if (result.sde != null) {
-        throw result.sde;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "system_update_keyspace failed: unknown result");
-    }
-
-    public String system_update_column_family(CfDef cf_def) throws InvalidRequestException, SchemaDisagreementException, org.apache.thrift.TException
-    {
-      send_system_update_column_family(cf_def);
-      return recv_system_update_column_family();
-    }
-
-    public void send_system_update_column_family(CfDef cf_def) throws org.apache.thrift.TException
-    {
-      system_update_column_family_args args = new system_update_column_family_args();
-      args.setCf_def(cf_def);
-      sendBase("system_update_column_family", args);
-    }
-
-    public String recv_system_update_column_family() throws InvalidRequestException, SchemaDisagreementException, org.apache.thrift.TException
-    {
-      system_update_column_family_result result = new system_update_column_family_result();
-      receiveBase(result, "system_update_column_family");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      if (result.sde != null) {
-        throw result.sde;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "system_update_column_family failed: unknown result");
-    }
-
-    public CqlResult execute_cql_query(ByteBuffer query, Compression compression) throws InvalidRequestException, UnavailableException, TimedOutException, SchemaDisagreementException, org.apache.thrift.TException
-    {
-      send_execute_cql_query(query, compression);
-      return recv_execute_cql_query();
-    }
-
-    public void send_execute_cql_query(ByteBuffer query, Compression compression) throws org.apache.thrift.TException
-    {
-      execute_cql_query_args args = new execute_cql_query_args();
-      args.setQuery(query);
-      args.setCompression(compression);
-      sendBase("execute_cql_query", args);
-    }
-
-    public CqlResult recv_execute_cql_query() throws InvalidRequestException, UnavailableException, TimedOutException, SchemaDisagreementException, org.apache.thrift.TException
-    {
-      execute_cql_query_result result = new execute_cql_query_result();
-      receiveBase(result, "execute_cql_query");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      if (result.ue != null) {
-        throw result.ue;
-      }
-      if (result.te != null) {
-        throw result.te;
-      }
-      if (result.sde != null) {
-        throw result.sde;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "execute_cql_query failed: unknown result");
-    }
-
-    public CqlResult execute_cql3_query(ByteBuffer query, Compression compression, ConsistencyLevel consistency) throws InvalidRequestException, UnavailableException, TimedOutException, SchemaDisagreementException, org.apache.thrift.TException
-    {
-      send_execute_cql3_query(query, compression, consistency);
-      return recv_execute_cql3_query();
-    }
-
-    public void send_execute_cql3_query(ByteBuffer query, Compression compression, ConsistencyLevel consistency) throws org.apache.thrift.TException
-    {
-      execute_cql3_query_args args = new execute_cql3_query_args();
-      args.setQuery(query);
-      args.setCompression(compression);
-      args.setConsistency(consistency);
-      sendBase("execute_cql3_query", args);
-    }
-
-    public CqlResult recv_execute_cql3_query() throws InvalidRequestException, UnavailableException, TimedOutException, SchemaDisagreementException, org.apache.thrift.TException
-    {
-      execute_cql3_query_result result = new execute_cql3_query_result();
-      receiveBase(result, "execute_cql3_query");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      if (result.ue != null) {
-        throw result.ue;
-      }
-      if (result.te != null) {
-        throw result.te;
-      }
-      if (result.sde != null) {
-        throw result.sde;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "execute_cql3_query failed: unknown result");
-    }
-
-    public CqlPreparedResult prepare_cql_query(ByteBuffer query, Compression compression) throws InvalidRequestException, org.apache.thrift.TException
-    {
-      send_prepare_cql_query(query, compression);
-      return recv_prepare_cql_query();
-    }
-
-    public void send_prepare_cql_query(ByteBuffer query, Compression compression) throws org.apache.thrift.TException
-    {
-      prepare_cql_query_args args = new prepare_cql_query_args();
-      args.setQuery(query);
-      args.setCompression(compression);
-      sendBase("prepare_cql_query", args);
-    }
-
-    public CqlPreparedResult recv_prepare_cql_query() throws InvalidRequestException, org.apache.thrift.TException
-    {
-      prepare_cql_query_result result = new prepare_cql_query_result();
-      receiveBase(result, "prepare_cql_query");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "prepare_cql_query failed: unknown result");
-    }
-
-    public CqlPreparedResult prepare_cql3_query(ByteBuffer query, Compression compression) throws InvalidRequestException, org.apache.thrift.TException
-    {
-      send_prepare_cql3_query(query, compression);
-      return recv_prepare_cql3_query();
-    }
-
-    public void send_prepare_cql3_query(ByteBuffer query, Compression compression) throws org.apache.thrift.TException
-    {
-      prepare_cql3_query_args args = new prepare_cql3_query_args();
-      args.setQuery(query);
-      args.setCompression(compression);
-      sendBase("prepare_cql3_query", args);
-    }
-
-    public CqlPreparedResult recv_prepare_cql3_query() throws InvalidRequestException, org.apache.thrift.TException
-    {
-      prepare_cql3_query_result result = new prepare_cql3_query_result();
-      receiveBase(result, "prepare_cql3_query");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "prepare_cql3_query failed: unknown result");
-    }
-
-    public CqlResult execute_prepared_cql_query(int itemId, List<ByteBuffer> values) throws InvalidRequestException, UnavailableException, TimedOutException, SchemaDisagreementException, org.apache.thrift.TException
-    {
-      send_execute_prepared_cql_query(itemId, values);
-      return recv_execute_prepared_cql_query();
-    }
-
-    public void send_execute_prepared_cql_query(int itemId, List<ByteBuffer> values) throws org.apache.thrift.TException
-    {
-      execute_prepared_cql_query_args args = new execute_prepared_cql_query_args();
-      args.setItemId(itemId);
-      args.setValues(values);
-      sendBase("execute_prepared_cql_query", args);
-    }
-
-    public CqlResult recv_execute_prepared_cql_query() throws InvalidRequestException, UnavailableException, TimedOutException, SchemaDisagreementException, org.apache.thrift.TException
-    {
-      execute_prepared_cql_query_result result = new execute_prepared_cql_query_result();
-      receiveBase(result, "execute_prepared_cql_query");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      if (result.ue != null) {
-        throw result.ue;
-      }
-      if (result.te != null) {
-        throw result.te;
-      }
-      if (result.sde != null) {
-        throw result.sde;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "execute_prepared_cql_query failed: unknown result");
-    }
-
-    public CqlResult execute_prepared_cql3_query(int itemId, List<ByteBuffer> values, ConsistencyLevel consistency) throws InvalidRequestException, UnavailableException, TimedOutException, SchemaDisagreementException, org.apache.thrift.TException
-    {
-      send_execute_prepared_cql3_query(itemId, values, consistency);
-      return recv_execute_prepared_cql3_query();
-    }
-
-    public void send_execute_prepared_cql3_query(int itemId, List<ByteBuffer> values, ConsistencyLevel consistency) throws org.apache.thrift.TException
-    {
-      execute_prepared_cql3_query_args args = new execute_prepared_cql3_query_args();
-      args.setItemId(itemId);
-      args.setValues(values);
-      args.setConsistency(consistency);
-      sendBase("execute_prepared_cql3_query", args);
-    }
-
-    public CqlResult recv_execute_prepared_cql3_query() throws InvalidRequestException, UnavailableException, TimedOutException, SchemaDisagreementException, org.apache.thrift.TException
-    {
-      execute_prepared_cql3_query_result result = new execute_prepared_cql3_query_result();
-      receiveBase(result, "execute_prepared_cql3_query");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      if (result.ue != null) {
-        throw result.ue;
-      }
-      if (result.te != null) {
-        throw result.te;
-      }
-      if (result.sde != null) {
-        throw result.sde;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "execute_prepared_cql3_query failed: unknown result");
-    }
-
-    public void set_cql_version(String version) throws InvalidRequestException, org.apache.thrift.TException
-    {
-      send_set_cql_version(version);
-      recv_set_cql_version();
-    }
-
-    public void send_set_cql_version(String version) throws org.apache.thrift.TException
-    {
-      set_cql_version_args args = new set_cql_version_args();
-      args.setVersion(version);
-      sendBase("set_cql_version", args);
-    }
-
-    public void recv_set_cql_version() throws InvalidRequestException, org.apache.thrift.TException
-    {
-      set_cql_version_result result = new set_cql_version_result();
-      receiveBase(result, "set_cql_version");
-      if (result.ire != null) {
-        throw result.ire;
-      }
-      return;
-    }
-
-  }
-  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 login(AuthenticationRequest auth_request, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
-      checkReady();
-      login_call method_call = new login_call(auth_request, resultHandler, this, ___protocolFactory, ___transport);
-      this.___currentMethod = method_call;
-      ___manager.call(method_call);
-    }
-
-    public static class login_call extends org.apache.thrift.async.TAsyncMethodCall {
-      private AuthenticationRequest auth_request;
-      public login_call(AuthenticationRequest auth_request, 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.auth_request = auth_request;
-      }
-
-      public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
-        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("login", org.apache.thrift.protocol.TMessageType.CALL, 0));
-        login_args args = new login_args();
-        args.setAuth_request(auth_request);
-        args.write(prot);
-        prot.writeMessageEnd();
-      }
-
-      public void getResult() throws AuthenticationException, AuthorizationException, 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_login();
-      }
-    }
-
-    public void set_keyspace(String keyspace, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
-      checkReady();
-      set_keyspace_call method_call = new set_keyspace_call(keyspace, resultHandler, this, ___protocolFactory, ___transport);
-      this.___currentMethod = method_call;
-      ___manager.call(method_call);
-    }
-
-    public static class set_keyspace_call extends org.apache.thrift.async.TAsyncMethodCall {
-      private String keyspace;
-      public set_keyspace_call(String keyspace, 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.keyspace = keyspace;
-      }
-
-      public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
-        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("set_keyspace", org.apache.thrift.protocol.TMessageType.CALL, 0));
-        set_keyspace_args args = new set_keyspace_args();
-        args.setKeyspace(keyspace);
-        args.write(prot);
-        prot.writeMessageEnd();
-      }
-
-      public void getResult() throws InvalidRequestException, 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 pr

<TRUNCATED>