public class CassandraRowSink extends AbstractCassandraTupleSink<Row>
SinkFunction.Context<T>
cluster, log, session
Constructor and Description |
---|
CassandraRowSink(int rowArity,
String insertQuery,
ClusterBuilder builder) |
Modifier and Type | Method and Description |
---|---|
protected Object[] |
extract(Row record) |
open, send
close, createSession, initializeState, invoke, snapshotState
getIterationRuntimeContext, getRuntimeContext, setRuntimeContext
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
invoke
public CassandraRowSink(int rowArity, String insertQuery, ClusterBuilder builder)
protected Object[] extract(Row record)
extract
in class AbstractCassandraTupleSink<Row>
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.