IN
- Type of the elements emitted by this sink, it must extend Tuple
public class CassandraTupleSink<IN extends Tuple> extends AbstractCassandraTupleSink<IN>
Tuple
s into a Cassandra cluster.SinkFunction.Context
cluster, log, session
Constructor and Description |
---|
CassandraTupleSink(String insertQuery,
ClusterBuilder builder) |
Modifier and Type | Method and Description |
---|---|
protected Object[] |
extract(IN record) |
open, send
close, createSession, initializeState, invoke, snapshotState
getIterationRuntimeContext, getRuntimeContext, setRuntimeContext
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
invoke
public CassandraTupleSink(String insertQuery, ClusterBuilder builder)
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.