public abstract static class RedisIO.ReadKeyPatterns
extends org.apache.beam.sdk.transforms.PTransform<org.apache.beam.sdk.values.PCollection<java.lang.String>,org.apache.beam.sdk.values.PCollection<org.apache.beam.sdk.values.KV<java.lang.String,java.lang.String>>>
RedisIO.readKeyPatterns()
.Constructor and Description |
---|
ReadKeyPatterns() |
Modifier and Type | Method and Description |
---|---|
org.apache.beam.sdk.values.PCollection<org.apache.beam.sdk.values.KV<java.lang.String,java.lang.String>> |
expand(org.apache.beam.sdk.values.PCollection<java.lang.String> input) |
RedisIO.ReadKeyPatterns |
withAuth(java.lang.String auth) |
RedisIO.ReadKeyPatterns |
withBatchSize(int batchSize) |
RedisIO.ReadKeyPatterns |
withConnectionConfiguration(RedisConnectionConfiguration connection) |
RedisIO.ReadKeyPatterns |
withEndpoint(java.lang.String host,
int port) |
RedisIO.ReadKeyPatterns |
withOutputParallelization(boolean outputParallelization)
Whether to reshuffle the resulting PCollection so results are distributed to all workers.
|
RedisIO.ReadKeyPatterns |
withTimeout(int timeout) |
public RedisIO.ReadKeyPatterns withEndpoint(java.lang.String host, int port)
public RedisIO.ReadKeyPatterns withAuth(java.lang.String auth)
public RedisIO.ReadKeyPatterns withTimeout(int timeout)
public RedisIO.ReadKeyPatterns withConnectionConfiguration(RedisConnectionConfiguration connection)
public RedisIO.ReadKeyPatterns withBatchSize(int batchSize)
public RedisIO.ReadKeyPatterns withOutputParallelization(boolean outputParallelization)
public org.apache.beam.sdk.values.PCollection<org.apache.beam.sdk.values.KV<java.lang.String,java.lang.String>> expand(org.apache.beam.sdk.values.PCollection<java.lang.String> input)
expand
in class org.apache.beam.sdk.transforms.PTransform<org.apache.beam.sdk.values.PCollection<java.lang.String>,org.apache.beam.sdk.values.PCollection<org.apache.beam.sdk.values.KV<java.lang.String,java.lang.String>>>