Package | Description |
---|---|
org.apache.storm.cassandra.executor |
Modifier and Type | Field and Description |
---|---|
static AsyncResultSetHandler |
AsyncResultSetHandler.NO_OP_HANDLER |
Modifier and Type | Method and Description |
---|---|
com.google.common.util.concurrent.SettableFuture<List<T>> |
AsyncExecutor.execAsync(List<com.datastax.driver.core.Statement> statements,
List<T> inputs,
Semaphore throttle,
AsyncResultSetHandler<T> handler)
Asynchronously executes the specified select statements.
|
Copyright © 2022 The Apache Software Foundation. All rights reserved.