public abstract static class ClickHouseIO.Write<T> extends PTransform<PCollection<T>,PDone>
PTransform
to write to ClickHouse.name
Constructor and Description |
---|
Write() |
Modifier and Type | Method and Description |
---|---|
PDone |
expand(PCollection<T> input)
Override this method to specify how this
PTransform should be expanded on the given
InputT . |
abstract Duration |
initialBackoff() |
abstract java.lang.Boolean |
insertDeduplicate() |
abstract java.lang.Boolean |
insertDistributedSync() |
abstract java.lang.Long |
insertQuorum() |
abstract java.lang.String |
jdbcUrl() |
abstract Duration |
maxCumulativeBackoff() |
abstract long |
maxInsertBlockSize() |
abstract int |
maxRetries() |
abstract java.util.Properties |
properties() |
abstract java.lang.String |
table() |
ClickHouseIO.Write<T> |
withInitialBackoff(Duration value)
Set initial backoff duration.
|
ClickHouseIO.Write<T> |
withInsertDeduplicate(java.lang.Boolean value)
For INSERT queries in the replicated table, specifies that deduplication of inserting blocks
should be performed.
|
ClickHouseIO.Write<T> |
withInsertDistributedSync(java.lang.Boolean value)
If setting is enabled, insert query into distributed waits until data will be sent to all
nodes in cluster.
|
ClickHouseIO.Write<T> |
withInsertQuorum(java.lang.Long value)
For INSERT queries in the replicated table, wait writing for the specified number of replicas
and linearize the addition of the data.
|
ClickHouseIO.Write<T> |
withMaxCumulativeBackoff(Duration value)
Limits total time spent in backoff.
|
ClickHouseIO.Write<T> |
withMaxInsertBlockSize(long value)
The maximum block size for insertion, if we control the creation of blocks for insertion.
|
ClickHouseIO.Write<T> |
withMaxRetries(int value)
Maximum number of retries per insert.
|
compose, compose, getAdditionalInputs, getDefaultOutputCoder, getDefaultOutputCoder, getDefaultOutputCoder, getKindString, getName, populateDisplayData, toString, validate
public abstract java.lang.String jdbcUrl()
public abstract java.lang.String table()
public abstract java.util.Properties properties()
public abstract long maxInsertBlockSize()
public abstract int maxRetries()
public abstract Duration maxCumulativeBackoff()
public abstract Duration initialBackoff()
@Nullable public abstract java.lang.Boolean insertDistributedSync()
@Nullable public abstract java.lang.Long insertQuorum()
@Nullable public abstract java.lang.Boolean insertDeduplicate()
public PDone expand(PCollection<T> input)
PTransform
PTransform
should be expanded on the given
InputT
.
NOTE: This method should not be called directly. Instead apply the PTransform
should
be applied to the InputT
using the apply
method.
Composite transforms, which are defined in terms of other transforms, should return the output of one of the composed transforms. Non-composite transforms, which do not apply any transforms internally, should return a new unbound output and register evaluators (via backend-specific registration methods).
expand
in class PTransform<PCollection<T>,PDone>
public ClickHouseIO.Write<T> withMaxInsertBlockSize(long value)
value
- number of rowsPTransform
writing data to ClickHousepublic ClickHouseIO.Write<T> withInsertDistributedSync(@Nullable java.lang.Boolean value)
value
- true to enable, null for server defaultPTransform
writing data to ClickHousepublic ClickHouseIO.Write<T> withInsertQuorum(@Nullable java.lang.Long value)
This setting is disabled in default server settings.
value
- number of replicas, 0 for disabling, null for server defaultPTransform
writing data to ClickHousepublic ClickHouseIO.Write<T> withInsertDeduplicate(java.lang.Boolean value)
Enabled by default. Shouldn't be disabled unless your input has duplicate blocks, and you don't want to deduplicate them.
value
- true to enable, null for server defaultPTransform
writing data to ClickHousepublic ClickHouseIO.Write<T> withMaxRetries(int value)
See FluentBackoff.withMaxRetries(int)
.
value
- maximum number of retriesPTransform
writing data to ClickHousepublic ClickHouseIO.Write<T> withMaxCumulativeBackoff(Duration value)
See FluentBackoff.withMaxCumulativeBackoff(org.joda.time.Duration)
.
value
- maximum durationPTransform
writing data to ClickHousepublic ClickHouseIO.Write<T> withInitialBackoff(Duration value)
See FluentBackoff.withInitialBackoff(org.joda.time.Duration)
.
value
- initial durationPTransform
writing data to ClickHouse