You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@storm.apache.org by bo...@apache.org on 2015/12/04 16:04:01 UTC

[06/17] storm git commit: Blobstore API STORM- 876

http://git-wip-us.apache.org/repos/asf/storm/blob/7029aee5/storm-core/src/jvm/backtype/storm/generated/Nimbus.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/generated/Nimbus.java b/storm-core/src/jvm/backtype/storm/generated/Nimbus.java
index 98d2d1c..042ef0e 100644
--- a/storm-core/src/jvm/backtype/storm/generated/Nimbus.java
+++ b/storm-core/src/jvm/backtype/storm/generated/Nimbus.java
@@ -94,6 +94,34 @@ public class Nimbus {
 
     public void uploadNewCredentials(String name, Credentials creds) throws NotAliveException, InvalidTopologyException, AuthorizationException, org.apache.thrift.TException;
 
+    public String beginCreateBlob(String key, SettableBlobMeta meta) throws AuthorizationException, KeyAlreadyExistsException, org.apache.thrift.TException;
+
+    public String beginUpdateBlob(String key) throws AuthorizationException, KeyNotFoundException, org.apache.thrift.TException;
+
+    public void uploadBlobChunk(String session, ByteBuffer chunk) throws AuthorizationException, org.apache.thrift.TException;
+
+    public void finishBlobUpload(String session) throws AuthorizationException, org.apache.thrift.TException;
+
+    public void cancelBlobUpload(String session) throws AuthorizationException, org.apache.thrift.TException;
+
+    public ReadableBlobMeta getBlobMeta(String key) throws AuthorizationException, KeyNotFoundException, org.apache.thrift.TException;
+
+    public void setBlobMeta(String key, SettableBlobMeta meta) throws AuthorizationException, KeyNotFoundException, org.apache.thrift.TException;
+
+    public BeginDownloadResult beginBlobDownload(String key) throws AuthorizationException, KeyNotFoundException, org.apache.thrift.TException;
+
+    public ByteBuffer downloadBlobChunk(String session) throws AuthorizationException, org.apache.thrift.TException;
+
+    public void deleteBlob(String key) throws AuthorizationException, KeyNotFoundException, org.apache.thrift.TException;
+
+    public ListBlobsResult listBlobs(String session) throws org.apache.thrift.TException;
+
+    public int getBlobReplication(String key) throws AuthorizationException, KeyNotFoundException, org.apache.thrift.TException;
+
+    public int updateBlobReplication(String key, int replication) throws AuthorizationException, KeyNotFoundException, org.apache.thrift.TException;
+
+    public void createStateInZookeeper(String key) throws org.apache.thrift.TException;
+
     public String beginFileUpload() throws AuthorizationException, org.apache.thrift.TException;
 
     public void uploadChunk(String location, ByteBuffer chunk) throws AuthorizationException, org.apache.thrift.TException;
@@ -164,6 +192,34 @@ public class Nimbus {
 
     public void uploadNewCredentials(String name, Credentials creds, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
+    public void beginCreateBlob(String key, SettableBlobMeta meta, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
+
+    public void beginUpdateBlob(String key, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
+
+    public void uploadBlobChunk(String session, ByteBuffer chunk, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
+
+    public void finishBlobUpload(String session, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
+
+    public void cancelBlobUpload(String session, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
+
+    public void getBlobMeta(String key, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
+
+    public void setBlobMeta(String key, SettableBlobMeta meta, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
+
+    public void beginBlobDownload(String key, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
+
+    public void downloadBlobChunk(String session, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
+
+    public void deleteBlob(String key, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
+
+    public void listBlobs(String session, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
+
+    public void getBlobReplication(String key, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
+
+    public void updateBlobReplication(String key, int replication, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
+
+    public void createStateInZookeeper(String key, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
+
     public void beginFileUpload(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
     public void uploadChunk(String location, ByteBuffer chunk, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
@@ -565,6 +621,374 @@ public class Nimbus {
       return;
     }
 
+    public String beginCreateBlob(String key, SettableBlobMeta meta) throws AuthorizationException, KeyAlreadyExistsException, org.apache.thrift.TException
+    {
+      send_beginCreateBlob(key, meta);
+      return recv_beginCreateBlob();
+    }
+
+    public void send_beginCreateBlob(String key, SettableBlobMeta meta) throws org.apache.thrift.TException
+    {
+      beginCreateBlob_args args = new beginCreateBlob_args();
+      args.set_key(key);
+      args.set_meta(meta);
+      sendBase("beginCreateBlob", args);
+    }
+
+    public String recv_beginCreateBlob() throws AuthorizationException, KeyAlreadyExistsException, org.apache.thrift.TException
+    {
+      beginCreateBlob_result result = new beginCreateBlob_result();
+      receiveBase(result, "beginCreateBlob");
+      if (result.is_set_success()) {
+        return result.success;
+      }
+      if (result.aze != null) {
+        throw result.aze;
+      }
+      if (result.kae != null) {
+        throw result.kae;
+      }
+      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "beginCreateBlob failed: unknown result");
+    }
+
+    public String beginUpdateBlob(String key) throws AuthorizationException, KeyNotFoundException, org.apache.thrift.TException
+    {
+      send_beginUpdateBlob(key);
+      return recv_beginUpdateBlob();
+    }
+
+    public void send_beginUpdateBlob(String key) throws org.apache.thrift.TException
+    {
+      beginUpdateBlob_args args = new beginUpdateBlob_args();
+      args.set_key(key);
+      sendBase("beginUpdateBlob", args);
+    }
+
+    public String recv_beginUpdateBlob() throws AuthorizationException, KeyNotFoundException, org.apache.thrift.TException
+    {
+      beginUpdateBlob_result result = new beginUpdateBlob_result();
+      receiveBase(result, "beginUpdateBlob");
+      if (result.is_set_success()) {
+        return result.success;
+      }
+      if (result.aze != null) {
+        throw result.aze;
+      }
+      if (result.knf != null) {
+        throw result.knf;
+      }
+      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "beginUpdateBlob failed: unknown result");
+    }
+
+    public void uploadBlobChunk(String session, ByteBuffer chunk) throws AuthorizationException, org.apache.thrift.TException
+    {
+      send_uploadBlobChunk(session, chunk);
+      recv_uploadBlobChunk();
+    }
+
+    public void send_uploadBlobChunk(String session, ByteBuffer chunk) throws org.apache.thrift.TException
+    {
+      uploadBlobChunk_args args = new uploadBlobChunk_args();
+      args.set_session(session);
+      args.set_chunk(chunk);
+      sendBase("uploadBlobChunk", args);
+    }
+
+    public void recv_uploadBlobChunk() throws AuthorizationException, org.apache.thrift.TException
+    {
+      uploadBlobChunk_result result = new uploadBlobChunk_result();
+      receiveBase(result, "uploadBlobChunk");
+      if (result.aze != null) {
+        throw result.aze;
+      }
+      return;
+    }
+
+    public void finishBlobUpload(String session) throws AuthorizationException, org.apache.thrift.TException
+    {
+      send_finishBlobUpload(session);
+      recv_finishBlobUpload();
+    }
+
+    public void send_finishBlobUpload(String session) throws org.apache.thrift.TException
+    {
+      finishBlobUpload_args args = new finishBlobUpload_args();
+      args.set_session(session);
+      sendBase("finishBlobUpload", args);
+    }
+
+    public void recv_finishBlobUpload() throws AuthorizationException, org.apache.thrift.TException
+    {
+      finishBlobUpload_result result = new finishBlobUpload_result();
+      receiveBase(result, "finishBlobUpload");
+      if (result.aze != null) {
+        throw result.aze;
+      }
+      return;
+    }
+
+    public void cancelBlobUpload(String session) throws AuthorizationException, org.apache.thrift.TException
+    {
+      send_cancelBlobUpload(session);
+      recv_cancelBlobUpload();
+    }
+
+    public void send_cancelBlobUpload(String session) throws org.apache.thrift.TException
+    {
+      cancelBlobUpload_args args = new cancelBlobUpload_args();
+      args.set_session(session);
+      sendBase("cancelBlobUpload", args);
+    }
+
+    public void recv_cancelBlobUpload() throws AuthorizationException, org.apache.thrift.TException
+    {
+      cancelBlobUpload_result result = new cancelBlobUpload_result();
+      receiveBase(result, "cancelBlobUpload");
+      if (result.aze != null) {
+        throw result.aze;
+      }
+      return;
+    }
+
+    public ReadableBlobMeta getBlobMeta(String key) throws AuthorizationException, KeyNotFoundException, org.apache.thrift.TException
+    {
+      send_getBlobMeta(key);
+      return recv_getBlobMeta();
+    }
+
+    public void send_getBlobMeta(String key) throws org.apache.thrift.TException
+    {
+      getBlobMeta_args args = new getBlobMeta_args();
+      args.set_key(key);
+      sendBase("getBlobMeta", args);
+    }
+
+    public ReadableBlobMeta recv_getBlobMeta() throws AuthorizationException, KeyNotFoundException, org.apache.thrift.TException
+    {
+      getBlobMeta_result result = new getBlobMeta_result();
+      receiveBase(result, "getBlobMeta");
+      if (result.is_set_success()) {
+        return result.success;
+      }
+      if (result.aze != null) {
+        throw result.aze;
+      }
+      if (result.knf != null) {
+        throw result.knf;
+      }
+      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "getBlobMeta failed: unknown result");
+    }
+
+    public void setBlobMeta(String key, SettableBlobMeta meta) throws AuthorizationException, KeyNotFoundException, org.apache.thrift.TException
+    {
+      send_setBlobMeta(key, meta);
+      recv_setBlobMeta();
+    }
+
+    public void send_setBlobMeta(String key, SettableBlobMeta meta) throws org.apache.thrift.TException
+    {
+      setBlobMeta_args args = new setBlobMeta_args();
+      args.set_key(key);
+      args.set_meta(meta);
+      sendBase("setBlobMeta", args);
+    }
+
+    public void recv_setBlobMeta() throws AuthorizationException, KeyNotFoundException, org.apache.thrift.TException
+    {
+      setBlobMeta_result result = new setBlobMeta_result();
+      receiveBase(result, "setBlobMeta");
+      if (result.aze != null) {
+        throw result.aze;
+      }
+      if (result.knf != null) {
+        throw result.knf;
+      }
+      return;
+    }
+
+    public BeginDownloadResult beginBlobDownload(String key) throws AuthorizationException, KeyNotFoundException, org.apache.thrift.TException
+    {
+      send_beginBlobDownload(key);
+      return recv_beginBlobDownload();
+    }
+
+    public void send_beginBlobDownload(String key) throws org.apache.thrift.TException
+    {
+      beginBlobDownload_args args = new beginBlobDownload_args();
+      args.set_key(key);
+      sendBase("beginBlobDownload", args);
+    }
+
+    public BeginDownloadResult recv_beginBlobDownload() throws AuthorizationException, KeyNotFoundException, org.apache.thrift.TException
+    {
+      beginBlobDownload_result result = new beginBlobDownload_result();
+      receiveBase(result, "beginBlobDownload");
+      if (result.is_set_success()) {
+        return result.success;
+      }
+      if (result.aze != null) {
+        throw result.aze;
+      }
+      if (result.knf != null) {
+        throw result.knf;
+      }
+      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "beginBlobDownload failed: unknown result");
+    }
+
+    public ByteBuffer downloadBlobChunk(String session) throws AuthorizationException, org.apache.thrift.TException
+    {
+      send_downloadBlobChunk(session);
+      return recv_downloadBlobChunk();
+    }
+
+    public void send_downloadBlobChunk(String session) throws org.apache.thrift.TException
+    {
+      downloadBlobChunk_args args = new downloadBlobChunk_args();
+      args.set_session(session);
+      sendBase("downloadBlobChunk", args);
+    }
+
+    public ByteBuffer recv_downloadBlobChunk() throws AuthorizationException, org.apache.thrift.TException
+    {
+      downloadBlobChunk_result result = new downloadBlobChunk_result();
+      receiveBase(result, "downloadBlobChunk");
+      if (result.is_set_success()) {
+        return result.success;
+      }
+      if (result.aze != null) {
+        throw result.aze;
+      }
+      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "downloadBlobChunk failed: unknown result");
+    }
+
+    public void deleteBlob(String key) throws AuthorizationException, KeyNotFoundException, org.apache.thrift.TException
+    {
+      send_deleteBlob(key);
+      recv_deleteBlob();
+    }
+
+    public void send_deleteBlob(String key) throws org.apache.thrift.TException
+    {
+      deleteBlob_args args = new deleteBlob_args();
+      args.set_key(key);
+      sendBase("deleteBlob", args);
+    }
+
+    public void recv_deleteBlob() throws AuthorizationException, KeyNotFoundException, org.apache.thrift.TException
+    {
+      deleteBlob_result result = new deleteBlob_result();
+      receiveBase(result, "deleteBlob");
+      if (result.aze != null) {
+        throw result.aze;
+      }
+      if (result.knf != null) {
+        throw result.knf;
+      }
+      return;
+    }
+
+    public ListBlobsResult listBlobs(String session) throws org.apache.thrift.TException
+    {
+      send_listBlobs(session);
+      return recv_listBlobs();
+    }
+
+    public void send_listBlobs(String session) throws org.apache.thrift.TException
+    {
+      listBlobs_args args = new listBlobs_args();
+      args.set_session(session);
+      sendBase("listBlobs", args);
+    }
+
+    public ListBlobsResult recv_listBlobs() throws org.apache.thrift.TException
+    {
+      listBlobs_result result = new listBlobs_result();
+      receiveBase(result, "listBlobs");
+      if (result.is_set_success()) {
+        return result.success;
+      }
+      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "listBlobs failed: unknown result");
+    }
+
+    public int getBlobReplication(String key) throws AuthorizationException, KeyNotFoundException, org.apache.thrift.TException
+    {
+      send_getBlobReplication(key);
+      return recv_getBlobReplication();
+    }
+
+    public void send_getBlobReplication(String key) throws org.apache.thrift.TException
+    {
+      getBlobReplication_args args = new getBlobReplication_args();
+      args.set_key(key);
+      sendBase("getBlobReplication", args);
+    }
+
+    public int recv_getBlobReplication() throws AuthorizationException, KeyNotFoundException, org.apache.thrift.TException
+    {
+      getBlobReplication_result result = new getBlobReplication_result();
+      receiveBase(result, "getBlobReplication");
+      if (result.is_set_success()) {
+        return result.success;
+      }
+      if (result.aze != null) {
+        throw result.aze;
+      }
+      if (result.knf != null) {
+        throw result.knf;
+      }
+      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "getBlobReplication failed: unknown result");
+    }
+
+    public int updateBlobReplication(String key, int replication) throws AuthorizationException, KeyNotFoundException, org.apache.thrift.TException
+    {
+      send_updateBlobReplication(key, replication);
+      return recv_updateBlobReplication();
+    }
+
+    public void send_updateBlobReplication(String key, int replication) throws org.apache.thrift.TException
+    {
+      updateBlobReplication_args args = new updateBlobReplication_args();
+      args.set_key(key);
+      args.set_replication(replication);
+      sendBase("updateBlobReplication", args);
+    }
+
+    public int recv_updateBlobReplication() throws AuthorizationException, KeyNotFoundException, org.apache.thrift.TException
+    {
+      updateBlobReplication_result result = new updateBlobReplication_result();
+      receiveBase(result, "updateBlobReplication");
+      if (result.is_set_success()) {
+        return result.success;
+      }
+      if (result.aze != null) {
+        throw result.aze;
+      }
+      if (result.knf != null) {
+        throw result.knf;
+      }
+      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "updateBlobReplication failed: unknown result");
+    }
+
+    public void createStateInZookeeper(String key) throws org.apache.thrift.TException
+    {
+      send_createStateInZookeeper(key);
+      recv_createStateInZookeeper();
+    }
+
+    public void send_createStateInZookeeper(String key) throws org.apache.thrift.TException
+    {
+      createStateInZookeeper_args args = new createStateInZookeeper_args();
+      args.set_key(key);
+      sendBase("createStateInZookeeper", args);
+    }
+
+    public void recv_createStateInZookeeper() throws org.apache.thrift.TException
+    {
+      createStateInZookeeper_result result = new createStateInZookeeper_result();
+      receiveBase(result, "createStateInZookeeper");
+      return;
+    }
+
     public String beginFileUpload() throws AuthorizationException, org.apache.thrift.TException
     {
       send_beginFileUpload();
@@ -1459,88 +1883,94 @@ public class Nimbus {
       }
     }
 
-    public void beginFileUpload(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
+    public void beginCreateBlob(String key, SettableBlobMeta meta, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
-      beginFileUpload_call method_call = new beginFileUpload_call(resultHandler, this, ___protocolFactory, ___transport);
+      beginCreateBlob_call method_call = new beginCreateBlob_call(key, meta, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
       ___manager.call(method_call);
     }
 
-    public static class beginFileUpload_call extends org.apache.thrift.async.TAsyncMethodCall {
-      public beginFileUpload_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 {
+    public static class beginCreateBlob_call extends org.apache.thrift.async.TAsyncMethodCall {
+      private String key;
+      private SettableBlobMeta meta;
+      public beginCreateBlob_call(String key, SettableBlobMeta meta, 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.key = key;
+        this.meta = meta;
       }
 
       public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
-        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("beginFileUpload", org.apache.thrift.protocol.TMessageType.CALL, 0));
-        beginFileUpload_args args = new beginFileUpload_args();
+        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("beginCreateBlob", org.apache.thrift.protocol.TMessageType.CALL, 0));
+        beginCreateBlob_args args = new beginCreateBlob_args();
+        args.set_key(key);
+        args.set_meta(meta);
         args.write(prot);
         prot.writeMessageEnd();
       }
 
-      public String getResult() throws AuthorizationException, org.apache.thrift.TException {
+      public String getResult() throws AuthorizationException, KeyAlreadyExistsException, 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_beginFileUpload();
+        return (new Client(prot)).recv_beginCreateBlob();
       }
     }
 
-    public void uploadChunk(String location, ByteBuffer chunk, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
+    public void beginUpdateBlob(String key, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
-      uploadChunk_call method_call = new uploadChunk_call(location, chunk, resultHandler, this, ___protocolFactory, ___transport);
+      beginUpdateBlob_call method_call = new beginUpdateBlob_call(key, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
       ___manager.call(method_call);
     }
 
-    public static class uploadChunk_call extends org.apache.thrift.async.TAsyncMethodCall {
-      private String location;
-      private ByteBuffer chunk;
-      public uploadChunk_call(String location, ByteBuffer chunk, 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 {
+    public static class beginUpdateBlob_call extends org.apache.thrift.async.TAsyncMethodCall {
+      private String key;
+      public beginUpdateBlob_call(String key, 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.location = location;
-        this.chunk = chunk;
+        this.key = key;
       }
 
       public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
-        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("uploadChunk", org.apache.thrift.protocol.TMessageType.CALL, 0));
-        uploadChunk_args args = new uploadChunk_args();
-        args.set_location(location);
-        args.set_chunk(chunk);
+        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("beginUpdateBlob", org.apache.thrift.protocol.TMessageType.CALL, 0));
+        beginUpdateBlob_args args = new beginUpdateBlob_args();
+        args.set_key(key);
         args.write(prot);
         prot.writeMessageEnd();
       }
 
-      public void getResult() throws AuthorizationException, org.apache.thrift.TException {
+      public String getResult() throws AuthorizationException, KeyNotFoundException, 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_uploadChunk();
+        return (new Client(prot)).recv_beginUpdateBlob();
       }
     }
 
-    public void finishFileUpload(String location, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
+    public void uploadBlobChunk(String session, ByteBuffer chunk, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
-      finishFileUpload_call method_call = new finishFileUpload_call(location, resultHandler, this, ___protocolFactory, ___transport);
+      uploadBlobChunk_call method_call = new uploadBlobChunk_call(session, chunk, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
       ___manager.call(method_call);
     }
 
-    public static class finishFileUpload_call extends org.apache.thrift.async.TAsyncMethodCall {
-      private String location;
-      public finishFileUpload_call(String location, 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 {
+    public static class uploadBlobChunk_call extends org.apache.thrift.async.TAsyncMethodCall {
+      private String session;
+      private ByteBuffer chunk;
+      public uploadBlobChunk_call(String session, ByteBuffer chunk, 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.location = location;
+        this.session = session;
+        this.chunk = chunk;
       }
 
       public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
-        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("finishFileUpload", org.apache.thrift.protocol.TMessageType.CALL, 0));
-        finishFileUpload_args args = new finishFileUpload_args();
-        args.set_location(location);
+        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("uploadBlobChunk", org.apache.thrift.protocol.TMessageType.CALL, 0));
+        uploadBlobChunk_args args = new uploadBlobChunk_args();
+        args.set_session(session);
+        args.set_chunk(chunk);
         args.write(prot);
         prot.writeMessageEnd();
       }
@@ -1551,813 +1981,939 @@ public class Nimbus {
         }
         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_finishFileUpload();
+        (new Client(prot)).recv_uploadBlobChunk();
       }
     }
 
-    public void beginFileDownload(String file, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
+    public void finishBlobUpload(String session, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
-      beginFileDownload_call method_call = new beginFileDownload_call(file, resultHandler, this, ___protocolFactory, ___transport);
+      finishBlobUpload_call method_call = new finishBlobUpload_call(session, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
       ___manager.call(method_call);
     }
 
-    public static class beginFileDownload_call extends org.apache.thrift.async.TAsyncMethodCall {
-      private String file;
-      public beginFileDownload_call(String file, 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 {
+    public static class finishBlobUpload_call extends org.apache.thrift.async.TAsyncMethodCall {
+      private String session;
+      public finishBlobUpload_call(String session, 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.file = file;
+        this.session = session;
       }
 
       public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
-        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("beginFileDownload", org.apache.thrift.protocol.TMessageType.CALL, 0));
-        beginFileDownload_args args = new beginFileDownload_args();
-        args.set_file(file);
+        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("finishBlobUpload", org.apache.thrift.protocol.TMessageType.CALL, 0));
+        finishBlobUpload_args args = new finishBlobUpload_args();
+        args.set_session(session);
         args.write(prot);
         prot.writeMessageEnd();
       }
 
-      public String getResult() throws AuthorizationException, org.apache.thrift.TException {
+      public void getResult() throws 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);
-        return (new Client(prot)).recv_beginFileDownload();
+        (new Client(prot)).recv_finishBlobUpload();
       }
     }
 
-    public void downloadChunk(String id, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
+    public void cancelBlobUpload(String session, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
-      downloadChunk_call method_call = new downloadChunk_call(id, resultHandler, this, ___protocolFactory, ___transport);
+      cancelBlobUpload_call method_call = new cancelBlobUpload_call(session, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
       ___manager.call(method_call);
     }
 
-    public static class downloadChunk_call extends org.apache.thrift.async.TAsyncMethodCall {
-      private String id;
-      public downloadChunk_call(String 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 {
+    public static class cancelBlobUpload_call extends org.apache.thrift.async.TAsyncMethodCall {
+      private String session;
+      public cancelBlobUpload_call(String session, 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.session = session;
       }
 
       public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
-        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("downloadChunk", org.apache.thrift.protocol.TMessageType.CALL, 0));
-        downloadChunk_args args = new downloadChunk_args();
-        args.set_id(id);
+        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("cancelBlobUpload", org.apache.thrift.protocol.TMessageType.CALL, 0));
+        cancelBlobUpload_args args = new cancelBlobUpload_args();
+        args.set_session(session);
         args.write(prot);
         prot.writeMessageEnd();
       }
 
-      public ByteBuffer getResult() throws AuthorizationException, org.apache.thrift.TException {
+      public void getResult() throws 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);
-        return (new Client(prot)).recv_downloadChunk();
+        (new Client(prot)).recv_cancelBlobUpload();
       }
     }
 
-    public void getNimbusConf(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
+    public void getBlobMeta(String key, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
-      getNimbusConf_call method_call = new getNimbusConf_call(resultHandler, this, ___protocolFactory, ___transport);
+      getBlobMeta_call method_call = new getBlobMeta_call(key, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
       ___manager.call(method_call);
     }
 
-    public static class getNimbusConf_call extends org.apache.thrift.async.TAsyncMethodCall {
-      public getNimbusConf_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 {
+    public static class getBlobMeta_call extends org.apache.thrift.async.TAsyncMethodCall {
+      private String key;
+      public getBlobMeta_call(String key, 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.key = key;
       }
 
       public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
-        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("getNimbusConf", org.apache.thrift.protocol.TMessageType.CALL, 0));
-        getNimbusConf_args args = new getNimbusConf_args();
+        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("getBlobMeta", org.apache.thrift.protocol.TMessageType.CALL, 0));
+        getBlobMeta_args args = new getBlobMeta_args();
+        args.set_key(key);
         args.write(prot);
         prot.writeMessageEnd();
       }
 
-      public String getResult() throws AuthorizationException, org.apache.thrift.TException {
+      public ReadableBlobMeta getResult() throws AuthorizationException, KeyNotFoundException, 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_getNimbusConf();
+        return (new Client(prot)).recv_getBlobMeta();
       }
     }
 
-    public void getClusterInfo(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
+    public void setBlobMeta(String key, SettableBlobMeta meta, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
-      getClusterInfo_call method_call = new getClusterInfo_call(resultHandler, this, ___protocolFactory, ___transport);
+      setBlobMeta_call method_call = new setBlobMeta_call(key, meta, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
       ___manager.call(method_call);
     }
 
-    public static class getClusterInfo_call extends org.apache.thrift.async.TAsyncMethodCall {
-      public getClusterInfo_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 {
+    public static class setBlobMeta_call extends org.apache.thrift.async.TAsyncMethodCall {
+      private String key;
+      private SettableBlobMeta meta;
+      public setBlobMeta_call(String key, SettableBlobMeta meta, 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.key = key;
+        this.meta = meta;
       }
 
       public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
-        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("getClusterInfo", org.apache.thrift.protocol.TMessageType.CALL, 0));
-        getClusterInfo_args args = new getClusterInfo_args();
+        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("setBlobMeta", org.apache.thrift.protocol.TMessageType.CALL, 0));
+        setBlobMeta_args args = new setBlobMeta_args();
+        args.set_key(key);
+        args.set_meta(meta);
         args.write(prot);
         prot.writeMessageEnd();
       }
 
-      public ClusterSummary getResult() throws AuthorizationException, org.apache.thrift.TException {
+      public void getResult() throws AuthorizationException, KeyNotFoundException, 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_getClusterInfo();
+        (new Client(prot)).recv_setBlobMeta();
       }
     }
 
-    public void getTopologyInfo(String id, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
+    public void beginBlobDownload(String key, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
-      getTopologyInfo_call method_call = new getTopologyInfo_call(id, resultHandler, this, ___protocolFactory, ___transport);
+      beginBlobDownload_call method_call = new beginBlobDownload_call(key, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
       ___manager.call(method_call);
     }
 
-    public static class getTopologyInfo_call extends org.apache.thrift.async.TAsyncMethodCall {
-      private String id;
-      public getTopologyInfo_call(String 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 {
+    public static class beginBlobDownload_call extends org.apache.thrift.async.TAsyncMethodCall {
+      private String key;
+      public beginBlobDownload_call(String key, 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.key = key;
       }
 
       public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
-        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("getTopologyInfo", org.apache.thrift.protocol.TMessageType.CALL, 0));
-        getTopologyInfo_args args = new getTopologyInfo_args();
-        args.set_id(id);
+        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("beginBlobDownload", org.apache.thrift.protocol.TMessageType.CALL, 0));
+        beginBlobDownload_args args = new beginBlobDownload_args();
+        args.set_key(key);
         args.write(prot);
         prot.writeMessageEnd();
       }
 
-      public TopologyInfo getResult() throws NotAliveException, AuthorizationException, org.apache.thrift.TException {
+      public BeginDownloadResult getResult() throws AuthorizationException, KeyNotFoundException, 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_getTopologyInfo();
+        return (new Client(prot)).recv_beginBlobDownload();
       }
     }
 
-    public void getTopologyInfoWithOpts(String id, GetInfoOptions options, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
+    public void downloadBlobChunk(String session, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
-      getTopologyInfoWithOpts_call method_call = new getTopologyInfoWithOpts_call(id, options, resultHandler, this, ___protocolFactory, ___transport);
+      downloadBlobChunk_call method_call = new downloadBlobChunk_call(session, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
       ___manager.call(method_call);
     }
 
-    public static class getTopologyInfoWithOpts_call extends org.apache.thrift.async.TAsyncMethodCall {
-      private String id;
-      private GetInfoOptions options;
-      public getTopologyInfoWithOpts_call(String id, GetInfoOptions options, 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 {
+    public static class downloadBlobChunk_call extends org.apache.thrift.async.TAsyncMethodCall {
+      private String session;
+      public downloadBlobChunk_call(String session, 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.options = options;
+        this.session = session;
       }
 
       public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
-        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("getTopologyInfoWithOpts", org.apache.thrift.protocol.TMessageType.CALL, 0));
-        getTopologyInfoWithOpts_args args = new getTopologyInfoWithOpts_args();
-        args.set_id(id);
-        args.set_options(options);
+        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("downloadBlobChunk", org.apache.thrift.protocol.TMessageType.CALL, 0));
+        downloadBlobChunk_args args = new downloadBlobChunk_args();
+        args.set_session(session);
         args.write(prot);
         prot.writeMessageEnd();
       }
 
-      public TopologyInfo getResult() throws NotAliveException, AuthorizationException, org.apache.thrift.TException {
+      public ByteBuffer getResult() throws 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);
-        return (new Client(prot)).recv_getTopologyInfoWithOpts();
+        return (new Client(prot)).recv_downloadBlobChunk();
       }
     }
 
-    public void getTopologyPageInfo(String id, String window, boolean is_include_sys, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
+    public void deleteBlob(String key, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
-      getTopologyPageInfo_call method_call = new getTopologyPageInfo_call(id, window, is_include_sys, resultHandler, this, ___protocolFactory, ___transport);
+      deleteBlob_call method_call = new deleteBlob_call(key, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
       ___manager.call(method_call);
     }
 
-    public static class getTopologyPageInfo_call extends org.apache.thrift.async.TAsyncMethodCall {
-      private String id;
-      private String window;
-      private boolean is_include_sys;
-      public getTopologyPageInfo_call(String id, String window, boolean is_include_sys, 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 {
+    public static class deleteBlob_call extends org.apache.thrift.async.TAsyncMethodCall {
+      private String key;
+      public deleteBlob_call(String key, 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.window = window;
-        this.is_include_sys = is_include_sys;
+        this.key = key;
       }
 
       public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
-        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("getTopologyPageInfo", org.apache.thrift.protocol.TMessageType.CALL, 0));
-        getTopologyPageInfo_args args = new getTopologyPageInfo_args();
-        args.set_id(id);
-        args.set_window(window);
-        args.set_is_include_sys(is_include_sys);
+        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("deleteBlob", org.apache.thrift.protocol.TMessageType.CALL, 0));
+        deleteBlob_args args = new deleteBlob_args();
+        args.set_key(key);
         args.write(prot);
         prot.writeMessageEnd();
       }
 
-      public TopologyPageInfo getResult() throws NotAliveException, AuthorizationException, org.apache.thrift.TException {
+      public void getResult() throws AuthorizationException, KeyNotFoundException, 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_getTopologyPageInfo();
+        (new Client(prot)).recv_deleteBlob();
       }
     }
 
-    public void getComponentPageInfo(String topology_id, String component_id, String window, boolean is_include_sys, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
+    public void listBlobs(String session, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
-      getComponentPageInfo_call method_call = new getComponentPageInfo_call(topology_id, component_id, window, is_include_sys, resultHandler, this, ___protocolFactory, ___transport);
+      listBlobs_call method_call = new listBlobs_call(session, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
       ___manager.call(method_call);
     }
 
-    public static class getComponentPageInfo_call extends org.apache.thrift.async.TAsyncMethodCall {
-      private String topology_id;
-      private String component_id;
-      private String window;
-      private boolean is_include_sys;
-      public getComponentPageInfo_call(String topology_id, String component_id, String window, boolean is_include_sys, 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 {
+    public static class listBlobs_call extends org.apache.thrift.async.TAsyncMethodCall {
+      private String session;
+      public listBlobs_call(String session, 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.topology_id = topology_id;
-        this.component_id = component_id;
-        this.window = window;
-        this.is_include_sys = is_include_sys;
+        this.session = session;
       }
 
       public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
-        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("getComponentPageInfo", org.apache.thrift.protocol.TMessageType.CALL, 0));
-        getComponentPageInfo_args args = new getComponentPageInfo_args();
-        args.set_topology_id(topology_id);
-        args.set_component_id(component_id);
-        args.set_window(window);
-        args.set_is_include_sys(is_include_sys);
+        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("listBlobs", org.apache.thrift.protocol.TMessageType.CALL, 0));
+        listBlobs_args args = new listBlobs_args();
+        args.set_session(session);
         args.write(prot);
         prot.writeMessageEnd();
       }
 
-      public ComponentPageInfo getResult() throws NotAliveException, AuthorizationException, org.apache.thrift.TException {
+      public ListBlobsResult getResult() throws 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_getComponentPageInfo();
+        return (new Client(prot)).recv_listBlobs();
       }
     }
 
-    public void getTopologyConf(String id, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
+    public void getBlobReplication(String key, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
-      getTopologyConf_call method_call = new getTopologyConf_call(id, resultHandler, this, ___protocolFactory, ___transport);
+      getBlobReplication_call method_call = new getBlobReplication_call(key, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
       ___manager.call(method_call);
     }
 
-    public static class getTopologyConf_call extends org.apache.thrift.async.TAsyncMethodCall {
-      private String id;
-      public getTopologyConf_call(String 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 {
+    public static class getBlobReplication_call extends org.apache.thrift.async.TAsyncMethodCall {
+      private String key;
+      public getBlobReplication_call(String key, 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.key = key;
       }
 
       public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
-        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("getTopologyConf", org.apache.thrift.protocol.TMessageType.CALL, 0));
-        getTopologyConf_args args = new getTopologyConf_args();
-        args.set_id(id);
+        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("getBlobReplication", org.apache.thrift.protocol.TMessageType.CALL, 0));
+        getBlobReplication_args args = new getBlobReplication_args();
+        args.set_key(key);
         args.write(prot);
         prot.writeMessageEnd();
       }
 
-      public String getResult() throws NotAliveException, AuthorizationException, org.apache.thrift.TException {
+      public int getResult() throws AuthorizationException, KeyNotFoundException, 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_getTopologyConf();
+        return (new Client(prot)).recv_getBlobReplication();
       }
     }
 
-    public void getTopology(String id, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
+    public void updateBlobReplication(String key, int replication, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
-      getTopology_call method_call = new getTopology_call(id, resultHandler, this, ___protocolFactory, ___transport);
+      updateBlobReplication_call method_call = new updateBlobReplication_call(key, replication, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
       ___manager.call(method_call);
     }
 
-    public static class getTopology_call extends org.apache.thrift.async.TAsyncMethodCall {
-      private String id;
-      public getTopology_call(String 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 {
+    public static class updateBlobReplication_call extends org.apache.thrift.async.TAsyncMethodCall {
+      private String key;
+      private int replication;
+      public updateBlobReplication_call(String key, int replication, 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.key = key;
+        this.replication = replication;
       }
 
       public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
-        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("getTopology", org.apache.thrift.protocol.TMessageType.CALL, 0));
-        getTopology_args args = new getTopology_args();
-        args.set_id(id);
+        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("updateBlobReplication", org.apache.thrift.protocol.TMessageType.CALL, 0));
+        updateBlobReplication_args args = new updateBlobReplication_args();
+        args.set_key(key);
+        args.set_replication(replication);
         args.write(prot);
         prot.writeMessageEnd();
       }
 
-      public StormTopology getResult() throws NotAliveException, AuthorizationException, org.apache.thrift.TException {
+      public int getResult() throws AuthorizationException, KeyNotFoundException, 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_getTopology();
+        return (new Client(prot)).recv_updateBlobReplication();
       }
     }
 
-    public void getUserTopology(String id, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
+    public void createStateInZookeeper(String key, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
-      getUserTopology_call method_call = new getUserTopology_call(id, resultHandler, this, ___protocolFactory, ___transport);
+      createStateInZookeeper_call method_call = new createStateInZookeeper_call(key, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
       ___manager.call(method_call);
     }
 
-    public static class getUserTopology_call extends org.apache.thrift.async.TAsyncMethodCall {
-      private String id;
-      public getUserTopology_call(String 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 {
+    public static class createStateInZookeeper_call extends org.apache.thrift.async.TAsyncMethodCall {
+      private String key;
+      public createStateInZookeeper_call(String key, 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.key = key;
       }
 
       public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
-        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("getUserTopology", org.apache.thrift.protocol.TMessageType.CALL, 0));
-        getUserTopology_args args = new getUserTopology_args();
-        args.set_id(id);
+        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("createStateInZookeeper", org.apache.thrift.protocol.TMessageType.CALL, 0));
+        createStateInZookeeper_args args = new createStateInZookeeper_args();
+        args.set_key(key);
         args.write(prot);
         prot.writeMessageEnd();
       }
 
-      public StormTopology getResult() throws NotAliveException, AuthorizationException, org.apache.thrift.TException {
+      public void getResult() throws 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_getUserTopology();
+        (new Client(prot)).recv_createStateInZookeeper();
       }
     }
 
-    public void getTopologyHistory(String user, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
+    public void beginFileUpload(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
-      getTopologyHistory_call method_call = new getTopologyHistory_call(user, resultHandler, this, ___protocolFactory, ___transport);
+      beginFileUpload_call method_call = new beginFileUpload_call(resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
       ___manager.call(method_call);
     }
 
-    public static class getTopologyHistory_call extends org.apache.thrift.async.TAsyncMethodCall {
-      private String user;
-      public getTopologyHistory_call(String user, 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 {
+    public static class beginFileUpload_call extends org.apache.thrift.async.TAsyncMethodCall {
+      public beginFileUpload_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);
-        this.user = user;
       }
 
       public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
-        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("getTopologyHistory", org.apache.thrift.protocol.TMessageType.CALL, 0));
-        getTopologyHistory_args args = new getTopologyHistory_args();
-        args.set_user(user);
+        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("beginFileUpload", org.apache.thrift.protocol.TMessageType.CALL, 0));
+        beginFileUpload_args args = new beginFileUpload_args();
         args.write(prot);
         prot.writeMessageEnd();
       }
 
-      public TopologyHistoryInfo getResult() throws AuthorizationException, org.apache.thrift.TException {
+      public String getResult() throws 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);
-        return (new Client(prot)).recv_getTopologyHistory();
+        return (new Client(prot)).recv_beginFileUpload();
       }
     }
 
-  }
-
-  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("submitTopology", new submitTopology());
-      processMap.put("submitTopologyWithOpts", new submitTopologyWithOpts());
-      processMap.put("killTopology", new killTopology());
-      processMap.put("killTopologyWithOpts", new killTopologyWithOpts());
-      processMap.put("activate", new activate());
-      processMap.put("deactivate", new deactivate());
-      processMap.put("rebalance", new rebalance());
-      processMap.put("setLogConfig", new setLogConfig());
-      processMap.put("getLogConfig", new getLogConfig());
-      processMap.put("debug", new debug());
-      processMap.put("setWorkerProfiler", new setWorkerProfiler());
-      processMap.put("getComponentPendingProfileActions", new getComponentPendingProfileActions());
-      processMap.put("uploadNewCredentials", new uploadNewCredentials());
-      processMap.put("beginFileUpload", new beginFileUpload());
-      processMap.put("uploadChunk", new uploadChunk());
-      processMap.put("finishFileUpload", new finishFileUpload());
-      processMap.put("beginFileDownload", new beginFileDownload());
-      processMap.put("downloadChunk", new downloadChunk());
-      processMap.put("getNimbusConf", new getNimbusConf());
-      processMap.put("getClusterInfo", new getClusterInfo());
-      processMap.put("getTopologyInfo", new getTopologyInfo());
-      processMap.put("getTopologyInfoWithOpts", new getTopologyInfoWithOpts());
-      processMap.put("getTopologyPageInfo", new getTopologyPageInfo());
-      processMap.put("getComponentPageInfo", new getComponentPageInfo());
-      processMap.put("getTopologyConf", new getTopologyConf());
-      processMap.put("getTopology", new getTopology());
-      processMap.put("getUserTopology", new getUserTopology());
-      processMap.put("getTopologyHistory", new getTopologyHistory());
-      return processMap;
+    public void uploadChunk(String location, ByteBuffer chunk, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
+      checkReady();
+      uploadChunk_call method_call = new uploadChunk_call(location, chunk, resultHandler, this, ___protocolFactory, ___transport);
+      this.___currentMethod = method_call;
+      ___manager.call(method_call);
     }
 
-    public static class submitTopology<I extends Iface> extends org.apache.thrift.ProcessFunction<I, submitTopology_args> {
-      public submitTopology() {
-        super("submitTopology");
-      }
-
-      public submitTopology_args getEmptyArgsInstance() {
-        return new submitTopology_args();
+    public static class uploadChunk_call extends org.apache.thrift.async.TAsyncMethodCall {
+      private String location;
+      private ByteBuffer chunk;
+      public uploadChunk_call(String location, ByteBuffer chunk, 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.location = location;
+        this.chunk = chunk;
       }
 
-      protected boolean isOneway() {
-        return false;
+      public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
+        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("uploadChunk", org.apache.thrift.protocol.TMessageType.CALL, 0));
+        uploadChunk_args args = new uploadChunk_args();
+        args.set_location(location);
+        args.set_chunk(chunk);
+        args.write(prot);
+        prot.writeMessageEnd();
       }
 
-      public submitTopology_result getResult(I iface, submitTopology_args args) throws org.apache.thrift.TException {
-        submitTopology_result result = new submitTopology_result();
-        try {
-          iface.submitTopology(args.name, args.uploadedJarLocation, args.jsonConf, args.topology);
-        } catch (AlreadyAliveException e) {
-          result.e = e;
-        } catch (InvalidTopologyException ite) {
-          result.ite = ite;
-        } catch (AuthorizationException aze) {
-          result.aze = aze;
+      public void getResult() throws AuthorizationException, org.apache.thrift.TException {
+        if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) {
+          throw new IllegalStateException("Method call not finished!");
         }
-        return result;
+        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_uploadChunk();
       }
     }
 
-    public static class submitTopologyWithOpts<I extends Iface> extends org.apache.thrift.ProcessFunction<I, submitTopologyWithOpts_args> {
-      public submitTopologyWithOpts() {
-        super("submitTopologyWithOpts");
-      }
-
-      public submitTopologyWithOpts_args getEmptyArgsInstance() {
-        return new submitTopologyWithOpts_args();
+    public void finishFileUpload(String location, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
+      checkReady();
+      finishFileUpload_call method_call = new finishFileUpload_call(location, resultHandler, this, ___protocolFactory, ___transport);
+      this.___currentMethod = method_call;
+      ___manager.call(method_call);
+    }
+
+    public static class finishFileUpload_call extends org.apache.thrift.async.TAsyncMethodCall {
+      private String location;
+      public finishFileUpload_call(String location, 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.location = location;
       }
 
-      protected boolean isOneway() {
-        return false;
+      public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
+        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("finishFileUpload", org.apache.thrift.protocol.TMessageType.CALL, 0));
+        finishFileUpload_args args = new finishFileUpload_args();
+        args.set_location(location);
+        args.write(prot);
+        prot.writeMessageEnd();
       }
 
-      public submitTopologyWithOpts_result getResult(I iface, submitTopologyWithOpts_args args) throws org.apache.thrift.TException {
-        submitTopologyWithOpts_result result = new submitTopologyWithOpts_result();
-        try {
-          iface.submitTopologyWithOpts(args.name, args.uploadedJarLocation, args.jsonConf, args.topology, args.options);
-        } catch (AlreadyAliveException e) {
-          result.e = e;
-        } catch (InvalidTopologyException ite) {
-          result.ite = ite;
-        } catch (AuthorizationException aze) {
-          result.aze = aze;
+      public void getResult() throws AuthorizationException, org.apache.thrift.TException {
+        if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) {
+          throw new IllegalStateException("Method call not finished!");
         }
-        return result;
+        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_finishFileUpload();
       }
     }
 
-    public static class killTopology<I extends Iface> extends org.apache.thrift.ProcessFunction<I, killTopology_args> {
-      public killTopology() {
-        super("killTopology");
-      }
+    public void beginFileDownload(String file, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
+      checkReady();
+      beginFileDownload_call method_call = new beginFileDownload_call(file, resultHandler, this, ___protocolFactory, ___transport);
+      this.___currentMethod = method_call;
+      ___manager.call(method_call);
+    }
 
-      public killTopology_args getEmptyArgsInstance() {
-        return new killTopology_args();
+    public static class beginFileDownload_call extends org.apache.thrift.async.TAsyncMethodCall {
+      private String file;
+      public beginFileDownload_call(String file, 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.file = file;
       }
 
-      protected boolean isOneway() {
-        return false;
+      public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
+        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("beginFileDownload", org.apache.thrift.protocol.TMessageType.CALL, 0));
+        beginFileDownload_args args = new beginFileDownload_args();
+        args.set_file(file);
+        args.write(prot);
+        prot.writeMessageEnd();
       }
 
-      public killTopology_result getResult(I iface, killTopology_args args) throws org.apache.thrift.TException {
-        killTopology_result result = new killTopology_result();
-        try {
-          iface.killTopology(args.name);
-        } catch (NotAliveException e) {
-          result.e = e;
-        } catch (AuthorizationException aze) {
-          result.aze = aze;
+      public String getResult() throws AuthorizationException, org.apache.thrift.TException {
+        if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) {
+          throw new IllegalStateException("Method call not finished!");
         }
-        return result;
+        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_beginFileDownload();
       }
     }
 
-    public static class killTopologyWithOpts<I extends Iface> extends org.apache.thrift.ProcessFunction<I, killTopologyWithOpts_args> {
-      public killTopologyWithOpts() {
-        super("killTopologyWithOpts");
-      }
+    public void downloadChunk(String id, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
+      checkReady();
+      downloadChunk_call method_call = new downloadChunk_call(id, resultHandler, this, ___protocolFactory, ___transport);
+      this.___currentMethod = method_call;
+      ___manager.call(method_call);
+    }
 
-      public killTopologyWithOpts_args getEmptyArgsInstance() {
-        return new killTopologyWithOpts_args();
+    public static class downloadChunk_call extends org.apache.thrift.async.TAsyncMethodCall {
+      private String id;
+      public downloadChunk_call(String 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;
       }
 
-      protected boolean isOneway() {
-        return false;
+      public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
+        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("downloadChunk", org.apache.thrift.protocol.TMessageType.CALL, 0));
+        downloadChunk_args args = new downloadChunk_args();
+        args.set_id(id);
+        args.write(prot);
+        prot.writeMessageEnd();
       }
 
-      public killTopologyWithOpts_result getResult(I iface, killTopologyWithOpts_args args) throws org.apache.thrift.TException {
-        killTopologyWithOpts_result result = new killTopologyWithOpts_result();
-        try {
-          iface.killTopologyWithOpts(args.name, args.options);
-        } catch (NotAliveException e) {
-          result.e = e;
-        } catch (AuthorizationException aze) {
-          result.aze = aze;
+      public ByteBuffer getResult() throws AuthorizationException, org.apache.thrift.TException {
+        if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) {
+          throw new IllegalStateException("Method call not finished!");
         }
-        return result;
+        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_downloadChunk();
       }
     }
 
-    public static class activate<I extends Iface> extends org.apache.thrift.ProcessFunction<I, activate_args> {
-      public activate() {
-        super("activate");
-      }
+    public void getNimbusConf(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
+      checkReady();
+      getNimbusConf_call method_call = new getNimbusConf_call(resultHandler, this, ___protocolFactory, ___transport);
+      this.___currentMethod = method_call;
+      ___manager.call(method_call);
+    }
 
-      public activate_args getEmptyArgsInstance() {
-        return new activate_args();
+    public static class getNimbusConf_call extends org.apache.thrift.async.TAsyncMethodCall {
+      public getNimbusConf_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);
       }
 
-      protected boolean isOneway() {
-        return false;
+      public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
+        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("getNimbusConf", org.apache.thrift.protocol.TMessageType.CALL, 0));
+        getNimbusConf_args args = new getNimbusConf_args();
+        args.write(prot);
+        prot.writeMessageEnd();
       }
 
-      public activate_result getResult(I iface, activate_args args) throws org.apache.thrift.TException {
-        activate_result result = new activate_result();
-        try {
-          iface.activate(args.name);
-        } catch (NotAliveException e) {
-          result.e = e;
-        } catch (AuthorizationException aze) {
-          result.aze = aze;
+      public String getResult() throws AuthorizationException, org.apache.thrift.TException {
+        if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) {
+          throw new IllegalStateException("Method call not finished!");
         }
-        return result;
+        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_getNimbusConf();
       }
     }
 
-    public static class deactivate<I extends Iface> extends org.apache.thrift.ProcessFunction<I, deactivate_args> {
-      public deactivate() {
-        super("deactivate");
-      }
+    public void getClusterInfo(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
+      checkReady();
+      getClusterInfo_call method_call = new getClusterInfo_call(resultHandler, this, ___protocolFactory, ___transport);
+      this.___currentMethod = method_call;
+      ___manager.call(method_call);
+    }
 
-      public deactivate_args getEmptyArgsInstance() {
-        return new deactivate_args();
+    public static class getClusterInfo_call extends org.apache.thrift.async.TAsyncMethodCall {
+      public getClusterInfo_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);
       }
 
-      protected boolean isOneway() {
-        return false;
+      public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
+        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("getClusterInfo", org.apache.thrift.protocol.TMessageType.CALL, 0));
+        getClusterInfo_args args = new getClusterInfo_args();
+        args.write(prot);
+        prot.writeMessageEnd();
       }
 
-      public deactivate_result getResult(I iface, deactivate_args args) throws org.apache.thrift.TException {
-        deactivate_result result = new deactivate_result();
-        try {
-          iface.deactivate(args.name);
-        } catch (NotAliveException e) {
-          result.e = e;
-        } catch (AuthorizationException aze) {
-          result.aze = aze;
+      public ClusterSummary getResult() throws AuthorizationException, org.apache.thrift.TException {
+        if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) {
+          throw new IllegalStateException("Method call not finished!");
         }
-        return result;
+        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_getClusterInfo();
       }
     }
 
-    public static class rebalance<I extends Iface> extends org.apache.thrift.ProcessFunction<I, rebalance_args> {
-      public rebalance() {
-        super("rebalance");
-      }
+    public void getTopologyInfo(String id, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
+      checkReady();
+      getTopologyInfo_call method_call = new getTopologyInfo_call(id, resultHandler, this, ___protocolFactory, ___transport);
+      this.___currentMethod = method_call;
+      ___manager.call(method_call);
+    }
 
-      public rebalance_args getEmptyArgsInstance() {
-        return new rebalance_args();
+    public static class getTopologyInfo_call extends org.apache.thrift.async.TAsyncMethodCall {
+      private String id;
+      public getTopologyInfo_call(String 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;
       }
 
-      protected boolean isOneway() {
-        return false;
+      public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
+        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("getTopologyInfo", org.apache.thrift.protocol.TMessageType.CALL, 0));
+        getTopologyInfo_args args = new getTopologyInfo_args();
+        args.set_id(id);
+        args.write(prot);
+        prot.writeMessageEnd();
       }
 
-      public rebalance_result getResult(I iface, rebalance_args args) throws org.apache.thrift.TException {
-        rebalance_result result = new rebalance_result();
-        try {
-          iface.rebalance(args.name, args.options);
-        } catch (NotAliveException e) {
-          result.e = e;
-        } catch (InvalidTopologyException ite) {
-          result.ite = ite;
-        } catch (AuthorizationException aze) {
-          result.aze = aze;
+      public TopologyInfo getResult() throws NotAliveException, AuthorizationException, org.apache.thrift.TException {
+        if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) {
+          throw new IllegalStateException("Method call not finished!");
         }
-        return result;
+        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_getTopologyInfo();
       }
     }
 
-    public static class setLogConfig<I extends Iface> extends org.apache.thrift.ProcessFunction<I, setLogConfig_args> {
-      public setLogConfig() {
-        super("setLogConfig");
-      }
+    public void getTopologyInfoWithOpts(String id, GetInfoOptions options, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
+      checkReady();
+      getTopologyInfoWithOpts_call method_call = new getTopologyInfoWithOpts_call(id, options, resultHandler, this, ___protocolFactory, 

<TRUNCATED>