Package | Description |
---|---|
org.apache.storm.cassandra.bolt | |
org.apache.storm.cassandra.executor | |
org.apache.storm.cassandra.executor.impl |
Modifier and Type | Method and Description |
---|---|
protected abstract AsyncResultHandler<T> |
BaseCassandraBolt.getAsyncHandler() |
protected AsyncResultHandler<Tuple> |
CassandraWriterBolt.getAsyncHandler() |
protected AsyncResultHandler<List<Tuple>> |
BatchCassandraWriterBolt.getAsyncHandler() |
Modifier and Type | Field and Description |
---|---|
protected AsyncResultHandler<T> |
AsyncExecutor.handler |
static AsyncResultHandler |
AsyncResultHandler.NO_OP_HANDLER |
Modifier and Type | Method and Description |
---|---|
com.google.common.util.concurrent.SettableFuture<T> |
AsyncExecutor.execAsync(com.datastax.driver.core.Statement statement,
T inputs,
AsyncResultHandler<T> handler)
Asynchronously executes the specified batch statement.
|
static <T> AsyncExecutor |
AsyncExecutorProvider.getLocal(com.datastax.driver.core.Session session,
AsyncResultHandler<T> handler)
Returns a new
AsyncExecutor per storm executor. |
Constructor and Description |
---|
AsyncExecutor(com.datastax.driver.core.Session session,
AsyncResultHandler<T> handler)
Creates a new
AsyncExecutor instance. |
Modifier and Type | Class and Description |
---|---|
class |
BatchAsyncResultHandler |
class |
SingleAsyncResultHandler |
Copyright © 2022 The Apache Software Foundation. All rights reserved.