Serialized Form
-
Package org.apache.beam.io.debezium
-
Class org.apache.beam.io.debezium.DebeziumIO.ConnectorConfiguration
class ConnectorConfiguration extends Object implements Serializable- serialVersionUID:
- 1L
-
Class org.apache.beam.io.debezium.DebeziumIO.Read
- serialVersionUID:
- 1L
-
Class org.apache.beam.io.debezium.KafkaSourceConsumerFn
-
Serialized Fields
-
connectorClass
Class<? extends org.apache.kafka.connect.source.SourceConnector> connectorClass
-
fn
SourceRecordMapper<T> fn
-
maxRecords
Integer maxRecords
-
millisecondsToRun
Long millisecondsToRun
-
-
-
Class org.apache.beam.io.debezium.SourceRecordJson.SourceRecordJsonMapper
class SourceRecordJsonMapper extends Object implements Serializable
-
-
Package org.apache.beam.io.requestresponse
-
Class org.apache.beam.io.requestresponse.Monitoring
class Monitoring extends Object implements Serializable -
Class org.apache.beam.io.requestresponse.RequestResponseIO
class RequestResponseIO extends PTransform<PCollection<RequestT>,Result<ResponseT>> implements Serializable -
Serialized Fields
-
callConfiguration
org.apache.beam.io.requestresponse.Call.Configuration<RequestT,
ResponseT> callConfiguration -
failureTag
TupleTag<ApiIOError> failureTag
-
responseTag
TupleTag<ResponseT> responseTag
-
rrioConfiguration
org.apache.beam.io.requestresponse.RequestResponseIO.Configuration<RequestT,
ResponseT> rrioConfiguration
-
-
-
Exception Class org.apache.beam.io.requestresponse.UserCodeExecutionException
class UserCodeExecutionException extends Exception implements Serializable -
Exception Class org.apache.beam.io.requestresponse.UserCodeQuotaException
class UserCodeQuotaException extends UserCodeExecutionException implements Serializable -
Exception Class org.apache.beam.io.requestresponse.UserCodeRemoteSystemException
class UserCodeRemoteSystemException extends UserCodeExecutionException implements Serializable -
Exception Class org.apache.beam.io.requestresponse.UserCodeTimeoutException
class UserCodeTimeoutException extends UserCodeExecutionException implements Serializable
-
-
Package org.apache.beam.runners.dataflow
-
Class org.apache.beam.runners.dataflow.BatchStatefulParDoOverrides.BatchStatefulDoFn
-
Class org.apache.beam.runners.dataflow.CreateDataflowView
class CreateDataflowView extends PTransform<PCollection<ElemT>,PCollection<ElemT>> implements Serializable -
Serialized Fields
-
streaming
boolean streaming
-
view
PCollectionView<ViewT> view
-
-
-
Exception Class org.apache.beam.runners.dataflow.DataflowJobAlreadyExistsException
class DataflowJobAlreadyExistsException extends DataflowJobException implements Serializable -
Exception Class org.apache.beam.runners.dataflow.DataflowJobAlreadyUpdatedException
class DataflowJobAlreadyUpdatedException extends DataflowJobException implements Serializable -
Exception Class org.apache.beam.runners.dataflow.DataflowJobException
class DataflowJobException extends RuntimeException implements Serializable-
Serialized Fields
-
job
DataflowPipelineJob job
-
-
-
Class org.apache.beam.runners.dataflow.DataflowRunner.StreamingPCollectionViewWriterFn
-
Serialized Fields
-
dataCoder
Coder<T> dataCoder
-
view
PCollectionView<?> view
-
-
-
Class org.apache.beam.runners.dataflow.DataflowRunnerInfo
class DataflowRunnerInfo extends org.apache.beam.sdk.util.ReleaseInfo implements Serializable -
Exception Class org.apache.beam.runners.dataflow.DataflowServiceException
class DataflowServiceException extends DataflowJobException implements Serializable -
Class org.apache.beam.runners.dataflow.PrimitiveParDoSingleFactory.ParDoSingle
class ParDoSingle extends org.apache.beam.sdk.util.construction.ForwardingPTransform<PCollection<? extends InputT>,PCollection<OutputT>> implements Serializable -
Class org.apache.beam.runners.dataflow.RedistributeByKeyOverrideFactory.DataflowRedistributeByKey
class DataflowRedistributeByKey extends PTransform<PCollection<KV<K,V>>, PCollection<KV<K, V>>> implements Serializable -
Serialized Fields
-
originalTransform
Redistribute.RedistributeByKey<K,
V> originalTransform -
usesAtLeastOnceStreamingMode
boolean usesAtLeastOnceStreamingMode
-
-
-
-
Package org.apache.beam.runners.dataflow.internal
-
Class org.apache.beam.runners.dataflow.internal.DataflowGroupByKey
class DataflowGroupByKey extends PTransform<PCollection<KV<K,V>>, PCollection<KV<K, Iterable<V>>>> implements Serializable -
Serialized Fields
-
allowDuplicates
boolean allowDuplicates
-
-
-
Class org.apache.beam.runners.dataflow.internal.IsmFormat.IsmRecordCoder
-
Class org.apache.beam.runners.dataflow.internal.IsmFormat.IsmShardCoder
-
Class org.apache.beam.runners.dataflow.internal.IsmFormat.KeyPrefixCoder
-
Class org.apache.beam.runners.dataflow.internal.IsmFormat.MetadataKeyCoder
-
-
Package org.apache.beam.runners.dataflow.options
-
Class org.apache.beam.runners.dataflow.options.DataflowProfilingOptions.DataflowProfilingAgentConfiguration
-
Class org.apache.beam.runners.dataflow.options.DataflowWorkerLoggingOptions.WorkerLogLevelOverrides
class WorkerLogLevelOverrides extends HashMap<String,DataflowWorkerLoggingOptions.Level> implements Serializable
-
-
Package org.apache.beam.runners.dataflow.util
-
Class org.apache.beam.runners.dataflow.util.MonitoringUtil.TimeStampComparator
class TimeStampComparator extends Object implements Serializable -
Class org.apache.beam.runners.dataflow.util.RandomAccessData.RandomAccessDataCoder
-
Class org.apache.beam.runners.dataflow.util.RandomAccessData.UnsignedLexicographicalComparator
class UnsignedLexicographicalComparator extends Object implements Serializable
-
-
Package org.apache.beam.runners.flink
-
Class org.apache.beam.runners.flink.CreateStreamingFlinkView.CreateFlinkPCollectionView
class CreateFlinkPCollectionView extends PTransform<PCollection<List<ElemT>>,PCollection<List<ElemT>>> implements Serializable -
Serialized Fields
-
view
PCollectionView<ViewT> view
-
-
-
Class org.apache.beam.runners.flink.FlinkStreamingAggregationsTranslators.ConcatenateAsIterable
class ConcatenateAsIterable extends Combine.CombineFn<T,Iterable<T>, Iterable<T>> implements Serializable -
Class org.apache.beam.runners.flink.FlinkStreamingTransformTranslators.StripIdsMap
class StripIdsMap extends org.apache.flink.api.common.functions.RichFlatMapFunction<WindowedValue<ValueWithRecordId<T>>,WindowedValue<T>> implements Serializable -
Serialized Fields
-
options
org.apache.beam.runners.core.construction.SerializablePipelineOptions options
-
-
-
Class org.apache.beam.runners.flink.FlinkStreamingTransformTranslators.ToRawUnion
class ToRawUnion extends org.apache.flink.api.common.functions.RichMapFunction<T,RawUnionValue> implements Serializable -
Serialized Fields
-
intTag
int intTag
-
options
org.apache.beam.runners.core.construction.SerializablePipelineOptions options
-
-
-
-
Package org.apache.beam.runners.flink.adapter
-
Class org.apache.beam.runners.flink.adapter.FlinkKey
class FlinkKey extends Object implements Serializable-
Serialized Fields
-
serializer
CoderTypeSerializer<byte[]> serializer
-
underlying
ByteBuffer underlying
-
-
-
-
Package org.apache.beam.runners.flink.metrics
-
Class org.apache.beam.runners.flink.metrics.MetricsAccumulator
class MetricsAccumulator extends Object implements Serializable-
Serialized Fields
-
metricsContainers
org.apache.beam.runners.core.metrics.MetricsContainerStepMap metricsContainers
-
-
-
-
Package org.apache.beam.runners.flink.translation.functions
-
Class org.apache.beam.runners.flink.translation.functions.FlinkAssignWindows
class FlinkAssignWindows extends Object implements Serializable-
Serialized Fields
-
windowFn
WindowFn<T,
W extends BoundedWindow> windowFn
-
-
-
Class org.apache.beam.runners.flink.translation.functions.FlinkDoFnFunction
class FlinkDoFnFunction extends org.apache.flink.api.common.functions.AbstractRichFunction implements Serializable-
Serialized Fields
-
bundleStarted
boolean bundleStarted
-
doFn
DoFn<InputT,
OutputT> doFn -
doFnSchemaInformation
DoFnSchemaInformation doFnSchemaInformation
-
exceptionThrownInFlatMap
boolean exceptionThrownInFlatMap
-
inputCoder
Coder<InputT> inputCoder
-
mainOutputTag
TupleTag<OutputT> mainOutputTag
-
outputCoderMap
Map<TupleTag<?>,
Coder<?>> outputCoderMap -
outputMap
Map<TupleTag<?>,
Integer> outputMap -
serializedOptions
org.apache.beam.runners.core.construction.SerializablePipelineOptions serializedOptions
-
sideInputMapping
Map<String,
PCollectionView<?>> sideInputMapping -
sideInputs
Map<PCollectionView<?>,
WindowingStrategy<?, ?>> sideInputs -
stepName
String stepName
-
windowingStrategy
WindowingStrategy<?,
?> windowingStrategy
-
-
-
Class org.apache.beam.runners.flink.translation.functions.FlinkExecutableStageContextFactory
class FlinkExecutableStageContextFactory extends Object implements Serializable -
Class org.apache.beam.runners.flink.translation.functions.FlinkExecutableStageFunction
class FlinkExecutableStageFunction extends org.apache.flink.api.common.functions.AbstractRichFunction implements Serializable-
Serialized Fields
-
contextFactory
FlinkExecutableStageContextFactory contextFactory
-
inputCoder
Coder<WindowedValue<InputT>> inputCoder
-
jobInfo
JobInfo jobInfo
-
outputMap
Map<String,
Integer> outputMap -
pipelineOptions
org.apache.beam.runners.core.construction.SerializablePipelineOptions pipelineOptions
-
stagePayload
org.apache.beam.model.pipeline.v1.RunnerApi.ExecutableStagePayload stagePayload
-
stepName
String stepName
-
windowCoder
Coder windowCoder
-
-
-
Class org.apache.beam.runners.flink.translation.functions.FlinkExecutableStagePruningFunction
class FlinkExecutableStagePruningFunction extends org.apache.flink.api.common.functions.RichFlatMapFunction<RawUnionValue,WindowedValue<?>> implements Serializable -
Serialized Fields
-
options
org.apache.beam.runners.core.construction.SerializablePipelineOptions options
-
unionTag
int unionTag
-
-
-
Class org.apache.beam.runners.flink.translation.functions.FlinkExplodeWindowsFunction
class FlinkExplodeWindowsFunction extends Object implements Serializable -
Class org.apache.beam.runners.flink.translation.functions.FlinkIdentityFunction
class FlinkIdentityFunction extends Object implements Serializable -
Class org.apache.beam.runners.flink.translation.functions.FlinkMergingNonShuffleReduceFunction
class FlinkMergingNonShuffleReduceFunction extends org.apache.flink.api.common.functions.RichGroupReduceFunction<WindowedValue<KV<K,InputT>>, WindowedValue<KV<K, OutputT>>> implements Serializable -
Serialized Fields
-
combineFn
CombineFnBase.GlobalCombineFn<InputT,
AccumT, OutputT> combineFn -
serializedOptions
org.apache.beam.runners.core.construction.SerializablePipelineOptions serializedOptions
-
sideInputs
Map<PCollectionView<?>,
WindowingStrategy<?, ?>> sideInputs -
windowingStrategy
WindowingStrategy<Object,
W extends BoundedWindow> windowingStrategy
-
-
-
Class org.apache.beam.runners.flink.translation.functions.FlinkMultiOutputPruningFunction
class FlinkMultiOutputPruningFunction extends org.apache.flink.api.common.functions.RichFlatMapFunction<WindowedValue<RawUnionValue>,WindowedValue<T>> implements Serializable -
Serialized Fields
-
options
org.apache.beam.runners.core.construction.SerializablePipelineOptions options
-
ourOutputTag
int ourOutputTag
-
-
-
Class org.apache.beam.runners.flink.translation.functions.FlinkNonMergingReduceFunction
class FlinkNonMergingReduceFunction extends Object implements Serializable-
Serialized Fields
-
reIterableResult
boolean reIterableResult
-
windowingStrategy
WindowingStrategy<?,
?> windowingStrategy
-
-
-
Class org.apache.beam.runners.flink.translation.functions.FlinkPartialReduceFunction
class FlinkPartialReduceFunction extends org.apache.flink.api.common.functions.RichGroupCombineFunction<WindowedValue<KV<K,InputT>>, WindowedValue<KV<K, AccumT>>> implements Serializable -
Serialized Fields
-
combineFn
CombineFnBase.GlobalCombineFn<InputT,
AccumT, ?> combineFn -
groupedByWindow
boolean groupedByWindow
WindowedValues has been exploded and pre-grouped by window. -
serializedOptions
org.apache.beam.runners.core.construction.SerializablePipelineOptions serializedOptions
-
sideInputs
Map<PCollectionView<?>,
WindowingStrategy<?, ?>> sideInputs -
windowingStrategy
WindowingStrategy<Object,
W extends BoundedWindow> windowingStrategy
-
-
-
Class org.apache.beam.runners.flink.translation.functions.FlinkReduceFunction
class FlinkReduceFunction extends org.apache.flink.api.common.functions.RichGroupReduceFunction<WindowedValue<KV<K,AccumT>>, WindowedValue<KV<K, OutputT>>> implements Serializable -
Serialized Fields
-
combineFn
CombineFnBase.GlobalCombineFn<?,
AccumT, OutputT> combineFn -
groupedByWindow
boolean groupedByWindow
WindowedValues has been exploded and pre-grouped by window. -
serializedOptions
org.apache.beam.runners.core.construction.SerializablePipelineOptions serializedOptions
-
sideInputs
Map<PCollectionView<?>,
WindowingStrategy<?, ?>> sideInputs -
windowingStrategy
WindowingStrategy<Object,
W extends BoundedWindow> windowingStrategy
-
-
-
Class org.apache.beam.runners.flink.translation.functions.FlinkStatefulDoFnFunction
class FlinkStatefulDoFnFunction extends org.apache.flink.api.common.functions.RichGroupReduceFunction<WindowedValue<KV<K,V>>, WindowedValue<RawUnionValue>> implements Serializable -
Serialized Fields
-
dofn
DoFn<KV<K,
V>, OutputT> dofn -
doFnSchemaInformation
DoFnSchemaInformation doFnSchemaInformation
-
inputCoder
Coder<KV<K,
V>> inputCoder -
mainOutputTag
TupleTag<OutputT> mainOutputTag
-
outputCoderMap
Map<TupleTag<?>,
Coder<?>> outputCoderMap -
outputMap
Map<TupleTag<?>,
Integer> outputMap -
serializedOptions
org.apache.beam.runners.core.construction.SerializablePipelineOptions serializedOptions
-
sideInputMapping
Map<String,
PCollectionView<?>> sideInputMapping -
sideInputs
Map<PCollectionView<?>,
WindowingStrategy<?, ?>> sideInputs -
stepName
String stepName
-
usesOnWindowExpiration
boolean usesOnWindowExpiration
-
windowingStrategy
WindowingStrategy<?,
?> windowingStrategy
-
-
-
Class org.apache.beam.runners.flink.translation.functions.ImpulseSourceFunction
class ImpulseSourceFunction extends Object implements Serializable-
Serialized Fields
-
idleTimeoutMs
long idleTimeoutMs
The idle time before the source shuts down. -
running
boolean running
Indicates the streaming job is running and the source can produce elements.
-
-
-
-
Package org.apache.beam.runners.flink.translation.types
-
Class org.apache.beam.runners.flink.translation.types.CoderTypeInformation
class CoderTypeInformation extends org.apache.flink.api.common.typeinfo.TypeInformation<T> implements Serializable -
Class org.apache.beam.runners.flink.translation.types.CoderTypeSerializer
class CoderTypeSerializer extends org.apache.flink.api.common.typeutils.TypeSerializer<T> implements Serializable- serialVersionUID:
- 7247319138941746449L
-
Class org.apache.beam.runners.flink.translation.types.EncodedValueComparator
class EncodedValueComparator extends org.apache.flink.api.common.typeutils.TypeComparator<byte[]> implements Serializable-
Serialized Fields
-
ascending
boolean ascending
-
-
-
Class org.apache.beam.runners.flink.translation.types.EncodedValueSerializer
class EncodedValueSerializer extends org.apache.flink.api.common.typeutils.base.TypeSerializerSingleton<byte[]> implements Serializable- serialVersionUID:
- 1L
-
Class org.apache.beam.runners.flink.translation.types.EncodedValueTypeInformation
class EncodedValueTypeInformation extends org.apache.flink.api.common.typeinfo.TypeInformation<byte[]> implements Serializable- serialVersionUID:
- 1L
-
Class org.apache.beam.runners.flink.translation.types.KvKeySelector
class KvKeySelector extends Object implements Serializable -
Class org.apache.beam.runners.flink.translation.types.WindowedKvKeySelector
class WindowedKvKeySelector extends Object implements Serializable-
Serialized Fields
-
keyCoder
Coder<K> keyCoder
-
windowCoder
Coder<? extends BoundedWindow> windowCoder
-
-
-
-
Package org.apache.beam.runners.flink.translation.wrappers
-
Class org.apache.beam.runners.flink.translation.wrappers.ImpulseInputFormat
class ImpulseInputFormat extends org.apache.flink.api.common.io.RichInputFormat<WindowedValue<byte[]>,org.apache.flink.core.io.GenericInputSplit> implements Serializable -
Serialized Fields
-
availableOutput
boolean availableOutput
-
-
-
Class org.apache.beam.runners.flink.translation.wrappers.SourceInputFormat
class SourceInputFormat extends org.apache.flink.api.common.io.RichInputFormat<WindowedValue<T>,SourceInputSplit<T>> implements Serializable -
Serialized Fields
-
initialSource
BoundedSource<T> initialSource
-
inputAvailable
boolean inputAvailable
-
serializedOptions
org.apache.beam.runners.core.construction.SerializablePipelineOptions serializedOptions
-
stepName
String stepName
-
-
-
Class org.apache.beam.runners.flink.translation.wrappers.SourceInputSplit
class SourceInputSplit extends Object implements Serializable
-
-
Package org.apache.beam.runners.flink.translation.wrappers.streaming
-
Class org.apache.beam.runners.flink.translation.wrappers.streaming.DoFnOperator
class DoFnOperator extends org.apache.flink.streaming.api.operators.AbstractStreamOperator<WindowedValue<OutputT>> implements Serializable-
Serialized Fields
-
additionalOutputTags
List<TupleTag<?>> additionalOutputTags
-
doFn
DoFn<InputT,
OutputT> doFn -
doFnSchemaInformation
DoFnSchemaInformation doFnSchemaInformation
-
enableStableInputDrain
boolean enableStableInputDrain
If both requiresStableInput and this parameter are true, we must flush the buffer during drain operation. -
finishBundleBeforeCheckpointing
boolean finishBundleBeforeCheckpointing
-
isStreaming
boolean isStreaming
-
keyCoder
Coder<?> keyCoder
-
keySelector
org.apache.flink.api.java.functions.KeySelector<WindowedValue<InputT>,
?> keySelector -
mainOutputTag
TupleTag<OutputT> mainOutputTag
-
maxBundleSize
long maxBundleSize
Max number of elements to include in a bundle. -
maxBundleTimeMills
long maxBundleTimeMills
Max duration of a bundle. -
numConcurrentCheckpoints
int numConcurrentCheckpoints
-
outputCoders
Map<TupleTag<?>,
Coder<?>> outputCoders -
outputManagerFactory
org.apache.beam.runners.flink.translation.wrappers.streaming.DoFnOperator.OutputManagerFactory<OutputT> outputManagerFactory
-
requiresStableInput
boolean requiresStableInput
If true, we must process elements only after a checkpoint is finished. -
serializedOptions
org.apache.beam.runners.core.construction.SerializablePipelineOptions serializedOptions
-
sideInputMapping
Map<String,
PCollectionView<?>> sideInputMapping -
sideInputs
Collection<PCollectionView<?>> sideInputs
-
sideInputTagMapping
Map<Integer,
PCollectionView<?>> sideInputTagMapping -
stepName
String stepName
-
timerCoder
org.apache.beam.runners.core.TimerInternals.TimerDataCoderV2 timerCoder
-
usesOnWindowExpiration
boolean usesOnWindowExpiration
-
windowedInputCoder
Coder<WindowedValue<InputT>> windowedInputCoder
-
windowingStrategy
WindowingStrategy<?,
?> windowingStrategy
-
-
-
Class org.apache.beam.runners.flink.translation.wrappers.streaming.DoFnOperator.MultiOutputOutputManagerFactory
class MultiOutputOutputManagerFactory extends Object implements Serializable-
Serialized Fields
-
isStreaming
boolean isStreaming
-
mainTag
TupleTag<OutputT> mainTag
-
pipelineOptions
org.apache.beam.runners.core.construction.SerializablePipelineOptions pipelineOptions
-
tagsToCoders
Map<TupleTag<?>,
Coder<WindowedValue<?>>> tagsToCoders -
tagsToIds
Map<TupleTag<?>,
Integer> tagsToIds -
tagsToOutputTags
Map<TupleTag<?>,
org.apache.flink.util.OutputTag<WindowedValue<?>>> tagsToOutputTags
-
-
-
Class org.apache.beam.runners.flink.translation.wrappers.streaming.ExecutableStageDoFnOperator
class ExecutableStageDoFnOperator extends DoFnOperator<InputT,InputT, OutputT> implements Serializable -
Serialized Fields
-
contextFactory
FlinkExecutableStageContextFactory contextFactory
-
inputCoder
Coder<WindowedValue<InputT>> inputCoder
-
inputWatermarkBeforeBundleStart
long inputWatermarkBeforeBundleStart
The input watermark before the current bundle started. -
isStateful
boolean isStateful
-
jobInfo
JobInfo jobInfo
-
outputMap
Map<String,
TupleTag<?>> outputMap -
payload
org.apache.beam.model.pipeline.v1.RunnerApi.ExecutableStagePayload payload
-
pipelineOptions
org.apache.beam.runners.core.construction.SerializablePipelineOptions pipelineOptions
-
sideInputIds
Map<org.apache.beam.model.pipeline.v1.RunnerApi.ExecutableStagePayload.SideInputId,
PCollectionView<?>> sideInputIds -
stateBackendLock
ReentrantLock stateBackendLock
A lock which has to be acquired when concurrently accessing state and timers. -
windowCoder
Coder windowCoder
-
-
-
Class org.apache.beam.runners.flink.translation.wrappers.streaming.KvToFlinkKeyKeySelector
class KvToFlinkKeyKeySelector extends Object implements Serializable -
Class org.apache.beam.runners.flink.translation.wrappers.streaming.PartialReduceBundleOperator
class PartialReduceBundleOperator extends DoFnOperator<KV<K,InputT>, KV<K, InputT>, KV<K, AccumT>> implements Serializable -
Serialized Fields
-
combineFn
CombineFnBase.GlobalCombineFn<InputT,
AccumT, OutputT> combineFn -
state
org.apache.beam.vendor.guava.v32_1_2_jre.com.google.common.collect.Multimap<K,
WindowedValue<KV<K, InputT>>> state
-
-
-
Class org.apache.beam.runners.flink.translation.wrappers.streaming.SdfFlinkKeyKeySelector
class SdfFlinkKeyKeySelector extends Object implements Serializable -
Class org.apache.beam.runners.flink.translation.wrappers.streaming.SingletonKeyedWorkItemCoder
class SingletonKeyedWorkItemCoder extends StructuredCoder<org.apache.beam.runners.core.KeyedWorkItem<K,ElemT>> implements Serializable -
Serialized Fields
-
elemCoder
Coder<ElemT> elemCoder
-
keyCoder
Coder<K> keyCoder
-
valueCoder
WindowedValues.FullWindowedValueCoder<ElemT> valueCoder
-
windowCoder
Coder<? extends BoundedWindow> windowCoder
-
-
-
Class org.apache.beam.runners.flink.translation.wrappers.streaming.SplittableDoFnOperator
class SplittableDoFnOperator extends DoFnOperator<org.apache.beam.runners.core.KeyedWorkItem<byte[],KV<InputT, RestrictionT>>, org.apache.beam.runners.core.KeyedWorkItem<byte[], KV<InputT, RestrictionT>>, OutputT> implements Serializable -
Class org.apache.beam.runners.flink.translation.wrappers.streaming.WindowDoFnOperator
class WindowDoFnOperator extends DoFnOperator<KV<K,InputT>, org.apache.beam.runners.core.KeyedWorkItem<K, InputT>, KV<K, OutputT>> implements Serializable -
Serialized Fields
-
systemReduceFn
org.apache.beam.runners.core.SystemReduceFn<K,
InputT, ?, OutputT, BoundedWindow> systemReduceFn
-
-
-
Class org.apache.beam.runners.flink.translation.wrappers.streaming.WorkItemKeySelector
class WorkItemKeySelector extends Object implements Serializable
-
-
Package org.apache.beam.runners.flink.translation.wrappers.streaming.io
-
Class org.apache.beam.runners.flink.translation.wrappers.streaming.io.DedupingOperator
class DedupingOperator extends org.apache.flink.streaming.api.operators.AbstractStreamOperator<WindowedValue<T>> implements Serializable-
Serialized Fields
-
dedupingStateDescriptor
org.apache.flink.api.common.state.ValueStateDescriptor<Long> dedupingStateDescriptor
-
options
org.apache.beam.runners.core.construction.SerializablePipelineOptions options
-
-
-
Class org.apache.beam.runners.flink.translation.wrappers.streaming.io.StreamingImpulseSource
class StreamingImpulseSource extends org.apache.flink.streaming.api.functions.source.RichParallelSourceFunction<WindowedValue<byte[]>> implements Serializable-
Serialized Fields
-
count
long count
Deprecated. -
intervalMillis
int intervalMillis
Deprecated. -
messageCount
int messageCount
Deprecated. -
running
boolean running
Deprecated.
-
-
-
Class org.apache.beam.runners.flink.translation.wrappers.streaming.io.TestStreamSource
class TestStreamSource extends org.apache.flink.streaming.api.functions.source.RichSourceFunction<WindowedValue<T>> implements Serializable-
Serialized Fields
-
isRunning
boolean isRunning
-
payload
byte[] payload
-
testStreamDecoder
SerializableFunction<byte[],
TestStream<T>> testStreamDecoder
-
-
-
Class org.apache.beam.runners.flink.translation.wrappers.streaming.io.UnboundedSourceWrapper
class UnboundedSourceWrapper extends org.apache.flink.streaming.api.functions.source.RichParallelSourceFunction<WindowedValue<ValueWithRecordId<OutputT>>> implements Serializable-
Serialized Fields
-
checkpointCoder
KvCoder<? extends UnboundedSource<OutputT,
CheckpointMarkT extends UnboundedSource.CheckpointMark>, CheckpointMarkT extends UnboundedSource.CheckpointMark> checkpointCoder For snapshot and restore. -
idleTimeoutMs
long idleTimeoutMs
The idle time before we the source shuts down. -
isConvertedBoundedSource
boolean isConvertedBoundedSource
We are processing bounded data and should read from the sources sequentially instead of reading round-robin from all the sources. In case of file sources this avoids having too many open files/connections at once. -
isRunning
boolean isRunning
Flag to indicate whether the source is running. Initialize here and not in run() to prevent races where we cancel a job before run() is ever called or run() is called after cancel(). -
serializedOptions
org.apache.beam.runners.core.construction.SerializablePipelineOptions serializedOptions
Keep the options so that we can initialize the localReaders. -
splitSources
List<? extends UnboundedSource<OutputT,
CheckpointMarkT extends UnboundedSource.CheckpointMark>> splitSources The split sources. We split them in the constructor to ensure that all parallel sources are consistent about the split sources. -
stepName
String stepName
-
-
-
-
Package org.apache.beam.runners.flink.translation.wrappers.streaming.io.source
-
Class org.apache.beam.runners.flink.translation.wrappers.streaming.io.source.FlinkSource
class FlinkSource extends Object implements Serializable -
Class org.apache.beam.runners.flink.translation.wrappers.streaming.io.source.FlinkSourceSplit
class FlinkSourceSplit extends Object implements Serializable- serialVersionUID:
- 7458114818012108972L
-
-
Package org.apache.beam.runners.flink.translation.wrappers.streaming.io.source.bounded
-
Class org.apache.beam.runners.flink.translation.wrappers.streaming.io.source.bounded.FlinkBoundedSource
-
Serialized Fields
-
timestampExtractor
FlinkSource.TimestampExtractor<WindowedValue<T>> timestampExtractor
-
-
-
-
Package org.apache.beam.runners.flink.translation.wrappers.streaming.io.source.impulse
-
Class org.apache.beam.runners.flink.translation.wrappers.streaming.io.source.impulse.BeamImpulseSource
class BeamImpulseSource extends BoundedSource<byte[]> implements Serializable
-
-
Package org.apache.beam.runners.flink.translation.wrappers.streaming.io.source.unbounded
-
Class org.apache.beam.runners.flink.translation.wrappers.streaming.io.source.unbounded.FlinkUnboundedSource
class FlinkUnboundedSource extends FlinkSource<T,WindowedValue<ValueWithRecordId<T>>> implements Serializable -
Serialized Fields
-
timestampExtractor
FlinkSource.TimestampExtractor<WindowedValue<ValueWithRecordId<T>>> timestampExtractor
-
-
-
-
Package org.apache.beam.runners.flink.translation.wrappers.streaming.state
-
Class org.apache.beam.runners.flink.translation.wrappers.streaming.state.FlinkStateInternals.FlinkStateNamespaceKeySerializer
class FlinkStateNamespaceKeySerializer extends org.apache.flink.api.common.typeutils.TypeSerializer<org.apache.beam.runners.core.StateNamespace> implements Serializable-
Serialized Fields
-
coder
Coder<? extends BoundedWindow> coder
-
-
-
-
Package org.apache.beam.runners.fnexecution.control
-
Class org.apache.beam.runners.fnexecution.control.ReferenceCountingExecutableStageContextFactory
class ReferenceCountingExecutableStageContextFactory extends Object implements Serializable-
Serialized Fields
-
creator
ReferenceCountingExecutableStageContextFactory.Creator creator
-
isReleaseSynchronous
SerializableFunction<Object,
Boolean> isReleaseSynchronous
-
-
-
-
Package org.apache.beam.runners.fnexecution.provisioning
-
Class org.apache.beam.runners.fnexecution.provisioning.JobInfo
class JobInfo extends Object implements Serializable
-
-
Package org.apache.beam.runners.fnexecution.wire
-
Class org.apache.beam.runners.fnexecution.wire.ByteStringCoder
class ByteStringCoder extends AtomicCoder<org.apache.beam.vendor.grpc.v1p69p0.com.google.protobuf.ByteString> implements Serializable
-
-
Package org.apache.beam.runners.jet.metrics
-
Class org.apache.beam.runners.jet.metrics.BoundedTrieImpl
class BoundedTrieImpl extends org.apache.beam.runners.jet.metrics.AbstractMetric<org.apache.beam.runners.core.metrics.BoundedTrieData> implements Serializable-
Serialized Fields
-
boundedTrieDataData
org.apache.beam.runners.core.metrics.BoundedTrieData boundedTrieDataData
-
-
-
Class org.apache.beam.runners.jet.metrics.CounterImpl
class CounterImpl extends org.apache.beam.runners.jet.metrics.AbstractMetric<Long> implements Serializable-
Serialized Fields
-
count
long count
-
-
-
Class org.apache.beam.runners.jet.metrics.DistributionImpl
class DistributionImpl extends org.apache.beam.runners.jet.metrics.AbstractMetric<org.apache.beam.runners.core.metrics.DistributionData> implements Serializable-
Serialized Fields
-
distributionData
org.apache.beam.runners.core.metrics.DistributionData distributionData
-
-
-
Class org.apache.beam.runners.jet.metrics.GaugeImpl
class GaugeImpl extends org.apache.beam.runners.jet.metrics.AbstractMetric<org.apache.beam.runners.core.metrics.GaugeData> implements Serializable-
Serialized Fields
-
gaugeData
org.apache.beam.runners.core.metrics.GaugeData gaugeData
-
-
-
Class org.apache.beam.runners.jet.metrics.JetMetricsContainer
class JetMetricsContainer extends Object implements Serializable-
Serialized Fields
-
accumulator
com.hazelcast.map.IMap<String,
org.apache.beam.runners.core.metrics.MetricUpdates> accumulator -
boundedTries
Map<MetricName,
BoundedTrieImpl> boundedTries -
counters
Map<MetricName,
CounterImpl> counters -
distributions
Map<MetricName,
DistributionImpl> distributions -
gauges
Map<MetricName,
GaugeImpl> gauges -
metricsKey
String metricsKey
-
stepName
String stepName
-
stringSets
Map<MetricName,
StringSetImpl> stringSets
-
-
-
Class org.apache.beam.runners.jet.metrics.StringSetImpl
class StringSetImpl extends org.apache.beam.runners.jet.metrics.AbstractMetric<org.apache.beam.runners.core.metrics.StringSetData> implements Serializable-
Serialized Fields
-
stringSetData
org.apache.beam.runners.core.metrics.StringSetData stringSetData
-
-
-
-
Package org.apache.beam.runners.jet.processors
-
Class org.apache.beam.runners.jet.processors.FlattenP.Supplier
class Supplier extends Object implements Serializable -
Class org.apache.beam.runners.jet.processors.ParDoP.Supplier
class Supplier extends org.apache.beam.runners.jet.processors.AbstractParDoP.AbstractSupplier<InputT,OutputT> implements Serializable -
Class org.apache.beam.runners.jet.processors.StatefulParDoP.Supplier
class Supplier extends org.apache.beam.runners.jet.processors.AbstractParDoP.AbstractSupplier<KV<?,?>, OutputT> implements Serializable
-
-
Package org.apache.beam.runners.portability
-
Exception Class org.apache.beam.runners.portability.CloseableResource.CloseException
class CloseException extends Exception implements Serializable
-
-
Package org.apache.beam.runners.spark.coders
-
Class org.apache.beam.runners.spark.coders.CoderHelpers.FromByteFunction
class FromByteFunction extends Object implements Serializable
-
-
Package org.apache.beam.runners.spark.io
-
Class org.apache.beam.runners.spark.io.ConsoleIO.Write.Unbound
-
Serialized Fields
-
num
int num
-
-
-
Class org.apache.beam.runners.spark.io.CreateStream
-
Serialized Fields
-
-
Class org.apache.beam.runners.spark.io.EmptyCheckpointMark
class EmptyCheckpointMark extends Object implements Serializable -
Class org.apache.beam.runners.spark.io.MicrobatchSource
-
Serialized Fields
-
maxNumRecords
long maxNumRecords
-
maxReadTime
Duration maxReadTime
-
numInitialSplits
int numInitialSplits
-
readerCacheInterval
double readerCacheInterval
-
source
UnboundedSource<T,
CheckpointMarkT extends UnboundedSource.CheckpointMark> source -
sourceId
int sourceId
-
splitId
int splitId
-
-
-
Class org.apache.beam.runners.spark.io.SourceRDD.Bounded
-
Serialized Fields
-
bundleSize
long bundleSize
-
metricsAccum
MetricsContainerStepMapAccumulator metricsAccum
-
numPartitions
int numPartitions
-
options
org.apache.beam.runners.core.construction.SerializablePipelineOptions options
-
source
BoundedSource<T> source
-
stepName
String stepName
-
-
-
Class org.apache.beam.runners.spark.io.SourceRDD.Unbounded
class Unbounded extends org.apache.spark.rdd.RDD<scala.Tuple2<Source<T>,CheckpointMarkT extends UnboundedSource.CheckpointMark>> implements Serializable -
Serialized Fields
-
microbatchSource
MicrobatchSource<T,
CheckpointMarkT extends UnboundedSource.CheckpointMark> microbatchSource -
options
org.apache.beam.runners.core.construction.SerializablePipelineOptions options
-
partitioner
org.apache.spark.Partitioner partitioner
-
-
-
Class org.apache.beam.runners.spark.io.SparkUnboundedSource.Metadata
class Metadata extends Object implements Serializable
-
-
Package org.apache.beam.runners.spark.metrics
-
Class org.apache.beam.runners.spark.metrics.MetricsContainerStepMapAccumulator
class MetricsContainerStepMapAccumulator extends org.apache.spark.util.AccumulatorV2<org.apache.beam.runners.core.metrics.MetricsContainerStepMap,org.apache.beam.runners.core.metrics.MetricsContainerStepMap> implements Serializable -
Serialized Fields
-
value
org.apache.beam.runners.core.metrics.MetricsContainerStepMap value
-
-
-
-
Package org.apache.beam.runners.spark.stateful
-
Class org.apache.beam.runners.spark.stateful.SparkGroupAlsoByWindowViaWindowSet
class SparkGroupAlsoByWindowViaWindowSet extends Object implements Serializable -
Class org.apache.beam.runners.spark.stateful.StateAndTimers
class StateAndTimers extends Object implements Serializable
-
-
Package org.apache.beam.runners.spark.structuredstreaming.examples
-
Class org.apache.beam.runners.spark.structuredstreaming.examples.WordCount.CountWords
class CountWords extends PTransform<PCollection<String>,PCollection<KV<String, Long>>> implements Serializable -
Class org.apache.beam.runners.spark.structuredstreaming.examples.WordCount.FormatAsTextFn
-
-
Package org.apache.beam.runners.spark.structuredstreaming.metrics
-
Class org.apache.beam.runners.spark.structuredstreaming.metrics.MetricsAccumulator
class MetricsAccumulator extends org.apache.spark.util.AccumulatorV2<org.apache.beam.runners.core.metrics.MetricsContainerStepMap,org.apache.beam.runners.core.metrics.MetricsContainerStepMap> implements Serializable -
Serialized Fields
-
value
org.apache.beam.runners.core.metrics.MetricsContainerStepMap value
-
-
-
-
Package org.apache.beam.runners.spark.structuredstreaming.translation.batch.functions
-
Class org.apache.beam.runners.spark.structuredstreaming.translation.batch.functions.GroupAlsoByWindowViaOutputBufferFn
class GroupAlsoByWindowViaOutputBufferFn extends Object implements Serializable-
Serialized Fields
-
options
Supplier<PipelineOptions> options
-
reduceFn
org.apache.beam.runners.core.SystemReduceFn<K,
InputT, Iterable<InputT>, Iterable<InputT>, W extends BoundedWindow> reduceFn -
stateInternalsFactory
org.apache.beam.runners.core.StateInternalsFactory<K> stateInternalsFactory
-
windowingStrategy
WindowingStrategy<?,
W extends BoundedWindow> windowingStrategy
-
-
-
Class org.apache.beam.runners.spark.structuredstreaming.translation.batch.functions.SideInputValues.BaseSideInputValues
class BaseSideInputValues extends Object implements Serializable -
Class org.apache.beam.runners.spark.structuredstreaming.translation.batch.functions.SideInputValues.ByWindow
class ByWindow extends SideInputValues.BaseSideInputValues<WindowedValue<T>,Map<BoundedWindow, List<T>>, T> implements Serializable -
Class org.apache.beam.runners.spark.structuredstreaming.translation.batch.functions.SideInputValues.Global
-
Class org.apache.beam.runners.spark.structuredstreaming.translation.batch.functions.SparkSideInputReader
class SparkSideInputReader extends Object implements Serializable-
Serialized Fields
-
sideInputs
Map<String,
org.apache.spark.broadcast.Broadcast<SideInputValues<?>>> sideInputs
-
-
-
-
Package org.apache.beam.runners.spark.structuredstreaming.translation.utils
-
Package org.apache.beam.runners.spark.translation
-
Class org.apache.beam.runners.spark.translation.BoundedDataset
class BoundedDataset extends Object implements Serializable-
Serialized Fields
-
clientBytes
List<byte[]> clientBytes
-
coder
Coder<T> coder
-
rdd
org.apache.spark.api.java.JavaRDD<WindowedValue<T>> rdd
-
windowedValues
Iterable<WindowedValue<T>> windowedValues
-
-
-
Class org.apache.beam.runners.spark.translation.MultiDoFnFunction
class MultiDoFnFunction extends Object implements Serializable-
Serialized Fields
-
additionalOutputTags
List<TupleTag<?>> additionalOutputTags
-
doFn
DoFn<InputT,
OutputT> doFn -
doFnSchemaInformation
DoFnSchemaInformation doFnSchemaInformation
-
inputCoder
Coder<InputT> inputCoder
-
mainOutputTag
TupleTag<OutputT> mainOutputTag
-
metricsAccum
MetricsContainerStepMapAccumulator metricsAccum
-
options
org.apache.beam.runners.core.construction.SerializablePipelineOptions options
-
outputCoders
Map<TupleTag<?>,
Coder<?>> outputCoders -
sideInputMapping
Map<String,
PCollectionView<?>> sideInputMapping -
sideInputs
Map<TupleTag<?>,
KV<WindowingStrategy<?, ?>, SideInputBroadcast<?>>> sideInputs -
stateful
boolean stateful
-
stepName
String stepName
-
useBoundedConcurrentOutput
boolean useBoundedConcurrentOutput
-
useStreamingSideInput
boolean useStreamingSideInput
-
windowingStrategy
WindowingStrategy<?,
?> windowingStrategy
-
-
-
Class org.apache.beam.runners.spark.translation.ReifyTimestampsAndWindowsFunction
class ReifyTimestampsAndWindowsFunction extends Object implements Serializable -
Class org.apache.beam.runners.spark.translation.SideInputMetadata
class SideInputMetadata extends Object implements Serializable-
Serialized Fields
-
coder
Coder<Iterable<WindowedValue<?>>> coder
-
data
byte[] data
-
type
SparkPCollectionView.Type type
-
-
-
Class org.apache.beam.runners.spark.translation.SingleEmitInputDStream
class SingleEmitInputDStream extends org.apache.spark.streaming.dstream.ConstantInputDStream<T> implements Serializable-
Serialized Fields
-
emitted
boolean emitted
-
-
-
Class org.apache.beam.runners.spark.translation.SparkAssignWindowFn
class SparkAssignWindowFn extends Object implements Serializable-
Serialized Fields
-
fn
WindowFn<? super T,
W extends BoundedWindow> fn
-
-
-
Class org.apache.beam.runners.spark.translation.SparkCombineFn
class SparkCombineFn extends Object implements Serializable-
Serialized Fields
-
combineFn
CombineWithContext.CombineFnWithContext<ValueT,
AccumT, OutputT> combineFn -
defaultNonMergingCombineStrategy
SparkCombineFn.WindowedAccumulator.Type defaultNonMergingCombineStrategy
-
globalCombine
boolean globalCombine
-
options
org.apache.beam.runners.core.construction.SerializablePipelineOptions options
-
sideInputs
Map<TupleTag<?>,
KV<WindowingStrategy<?, ?>, SideInputBroadcast<?>>> sideInputs -
toValue
org.apache.spark.api.java.function.Function<InputT,
ValueT> toValue -
windowComparator
Comparator<BoundedWindow> windowComparator
-
windowingStrategy
WindowingStrategy<?,
BoundedWindow> windowingStrategy
-
-
-
Class org.apache.beam.runners.spark.translation.SparkExecutableStageContextFactory
class SparkExecutableStageContextFactory extends Object implements Serializable -
Class org.apache.beam.runners.spark.translation.SparkPCollectionView
class SparkPCollectionView extends Object implements Serializable-
Serialized Fields
-
pviews
Map<PCollectionView<?>,
SideInputMetadata> pviews
-
-
-
Class org.apache.beam.runners.spark.translation.TranslationUtils.CombineGroupedValues
class CombineGroupedValues extends Object implements Serializable -
Class org.apache.beam.runners.spark.translation.TranslationUtils.TupleTagFilter
class TupleTagFilter extends Object implements Serializable -
Class org.apache.beam.runners.spark.translation.ValueAndCoderLazySerializable
class ValueAndCoderLazySerializable extends Object implements Serializable-
Serialization Methods
-
readObject
- Throws:
IOException
-
writeObject
- Throws:
IOException
-
-
Serialized Fields
-
-
-
Package org.apache.beam.runners.spark.translation.streaming
-
Class org.apache.beam.runners.spark.translation.streaming.CreateStreamingSparkView
class CreateStreamingSparkView extends PTransform<PCollection<ElemT>,PCollection<ElemT>> implements Serializable -
Serialized Fields
-
view
PCollectionView<ViewT> view
-
-
-
Class org.apache.beam.runners.spark.translation.streaming.CreateStreamingSparkView.CreateSparkPCollectionView
class CreateSparkPCollectionView extends PTransform<PCollection<List<ElemT>>,PCollection<List<ElemT>>> implements Serializable -
Serialized Fields
-
view
PCollectionView<ViewT> view
-
-
-
Class org.apache.beam.runners.spark.translation.streaming.ParDoStateUpdateFn
class ParDoStateUpdateFn extends scala.runtime.AbstractFunction3<ByteArray,scala.Option<byte[]>, org.apache.spark.streaming.State<StateAndTimers>, List<scala.Tuple2<TupleTag<?>, byte[]>>> implements Serializable -
Serialized Fields
-
additionalOutputTags
List<TupleTag<?>> additionalOutputTags
-
doFn
DoFn<InputT extends KV<KeyT,
ValueT>, OutputT> doFn -
doFnSchemaInformation
DoFnSchemaInformation doFnSchemaInformation
-
inputCoder
Coder<InputT extends KV<KeyT,
ValueT>> inputCoder -
keyCoder
Coder<KeyT> keyCoder
-
mainOutputTag
TupleTag<?> mainOutputTag
-
metricsAccum
MetricsContainerStepMapAccumulator metricsAccum
-
options
org.apache.beam.runners.core.construction.SerializablePipelineOptions options
-
outputCoders
Map<TupleTag<?>,
Coder<?>> outputCoders -
sideInputMapping
Map<String,
PCollectionView<?>> sideInputMapping -
sideInputs
Map<TupleTag<?>,
KV<WindowingStrategy<?, ?>, SideInputBroadcast<?>>> sideInputs -
sourceIds
List<Integer> sourceIds
-
stepName
String stepName
-
timerDataCoder
org.apache.beam.runners.core.TimerInternals.TimerDataCoderV2 timerDataCoder
-
useStreamingSideInput
boolean useStreamingSideInput
-
watermarks
Map<Integer,
GlobalWatermarkHolder.SparkWatermarks> watermarks -
windowingStrategy
WindowingStrategy<?,
?> windowingStrategy -
wvCoder
WindowedValues.FullWindowedValueCoder<ValueT> wvCoder
-
-
-
Class org.apache.beam.runners.spark.translation.streaming.SparkRunnerStreamingContextFactory
class SparkRunnerStreamingContextFactory extends Object implements Serializable -
Class org.apache.beam.runners.spark.translation.streaming.StatefulStreamingParDoEvaluator
class StatefulStreamingParDoEvaluator extends Object implements Serializable -
Class org.apache.beam.runners.spark.translation.streaming.TestDStream
class TestDStream extends org.apache.spark.streaming.dstream.InputDStream<WindowedValue<T>> implements Serializable-
Serialized Fields
-
coder
Coder<WindowedValue<T>> coder
-
currentEventIndex
int currentEventIndex
-
insertEmptyBatch
boolean insertEmptyBatch
-
lastValidTimeMs
long lastValidTimeMs
-
lastWatermark
Instant lastWatermark
-
-
-
Class org.apache.beam.runners.spark.translation.streaming.UnboundedDataset
class UnboundedDataset extends Object implements Serializable-
Serialized Fields
-
dStream
org.apache.spark.streaming.api.java.JavaDStream<WindowedValue<T>> dStream
-
streamSources
List<Integer> streamSources
-
-
-
-
Package org.apache.beam.runners.spark.util
-
Class org.apache.beam.runners.spark.util.ByteArray
class ByteArray extends Object implements Serializable-
Serialized Fields
-
value
byte[] value
-
-
-
Class org.apache.beam.runners.spark.util.GlobalWatermarkHolder.SparkWatermarks
class SparkWatermarks extends Object implements Serializable -
Class org.apache.beam.runners.spark.util.SideInputBroadcast
class SideInputBroadcast extends Object implements Serializable-
Serialized Fields
-
bcast
org.apache.spark.broadcast.Broadcast<byte[]> bcast
-
coder
Coder<T> coder
-
sparkPCollectionViewType
SparkPCollectionView.Type sparkPCollectionViewType
-
-
-
Class org.apache.beam.runners.spark.util.TimerUtils.TimerMarker
class TimerMarker extends Object implements Serializable- serialVersionUID:
- 1L
-
-
Package org.apache.beam.runners.twister2
-
Class org.apache.beam.runners.twister2.BeamBatchWorker
class BeamBatchWorker extends Object implements Serializable
-
-
Package org.apache.beam.runners.twister2.translation.wrappers
-
Class org.apache.beam.runners.twister2.translation.wrappers.Twister2BoundedSource
class Twister2BoundedSource extends edu.iu.dsc.tws.api.tset.fn.BaseSourceFunc<WindowedValue<T>> implements Serializable-
Serialization Methods
-
readResolve
- Throws:
ObjectStreamException
-
-
Serialized Fields
-
-
Class org.apache.beam.runners.twister2.translation.wrappers.Twister2EmptySource
class Twister2EmptySource extends edu.iu.dsc.tws.api.tset.fn.BaseSourceFunc<WindowedValue<T>> implements Serializable
-
-
Package org.apache.beam.runners.twister2.translators.functions
-
Class org.apache.beam.runners.twister2.translators.functions.AssignWindowsFunction
class AssignWindowsFunction extends Object implements Serializable-
Serialization Methods
-
readResolve
- Throws:
ObjectStreamException
-
-
Serialized Fields
-
windowFnBytes
byte[] windowFnBytes
-
-
-
Class org.apache.beam.runners.twister2.translators.functions.ByteToElemFunction
class ByteToElemFunction extends Object implements Serializable-
Serialization Methods
-
readResolve
- Throws:
ObjectStreamException
-
-
Serialized Fields
-
wvCoderBytes
byte[] wvCoderBytes
-
-
-
Class org.apache.beam.runners.twister2.translators.functions.ByteToWindowFunction
class ByteToWindowFunction extends Object implements Serializable-
Serialization Methods
-
readResolve
- Throws:
ObjectStreamException
-
-
Serialized Fields
-
keyCoderBytes
byte[] keyCoderBytes
-
wvCoderBytes
byte[] wvCoderBytes
-
-
-
Class org.apache.beam.runners.twister2.translators.functions.ByteToWindowFunctionPrimitive
class ByteToWindowFunctionPrimitive extends Object implements Serializable-
Serialization Methods
-
readResolve
- Throws:
ObjectStreamException
-
-
Serialized Fields
-
keyCoderBytes
byte[] keyCoderBytes
-
wvCoderBytes
byte[] wvCoderBytes
-
-
-
Class org.apache.beam.runners.twister2.translators.functions.DoFnFunction
class DoFnFunction extends Object implements Serializable- serialVersionUID:
- -5701440128544343353L
-
Serialization Methods
-
readResolve
- Throws:
ObjectStreamException
-
-
Serialized Fields
-
coderBytes
byte[] coderBytes
-
doFnwithExBytes
byte[] doFnwithExBytes
-
outputCodersBytes
Map<String,
byte[]> outputCodersBytes -
serializedOptions
String serializedOptions
-
serializedOutputMap
Map<String,
Integer> serializedOutputMap -
serializedSideOutputs
List<String> serializedSideOutputs
-
sideInputBytes
Map<String,
byte[]> sideInputBytes -
stepcontext
org.apache.beam.runners.core.StepContext stepcontext
-
windowBytes
byte[] windowBytes
-
-
Class org.apache.beam.runners.twister2.translators.functions.ElemToBytesFunction
class ElemToBytesFunction extends Object implements Serializable-
Serialization Methods
-
readResolve
- Throws:
ObjectStreamException
-
-
Serialized Fields
-
wvCoderBytes
byte[] wvCoderBytes
-
-
-
Class org.apache.beam.runners.twister2.translators.functions.GroupByWindowFunction
class GroupByWindowFunction extends Object implements Serializable-
Serialization Methods
-
readResolve
- Throws:
ObjectStreamException
-
-
Serialized Fields
-
-
Class org.apache.beam.runners.twister2.translators.functions.ImpulseSource
class ImpulseSource extends Object implements Serializable-
Serialized Fields
-
impulseEmitted
boolean impulseEmitted
-
-
-
Class org.apache.beam.runners.twister2.translators.functions.MapToTupleFunction
class MapToTupleFunction extends Object implements Serializable-
Serialization Methods
-
readResolve
- Throws:
ObjectStreamException
-
-
Serialized Fields
-
keyCoderBytes
byte[] keyCoderBytes
-
wvCoderBytes
byte[] wvCoderBytes
-
-
-
Class org.apache.beam.runners.twister2.translators.functions.OutputTagFilter
class OutputTagFilter extends Object implements Serializable-
Serialized Fields
-
tag
int tag
-
-
-
Class org.apache.beam.runners.twister2.translators.functions.Twister2SinkFunction
class Twister2SinkFunction extends Object implements Serializable
-
-
Package org.apache.beam.runners.twister2.translators.functions.internal
-
Class org.apache.beam.runners.twister2.translators.functions.internal.SystemReduceFnBuffering
class SystemReduceFnBuffering extends org.apache.beam.runners.core.SystemReduceFn<K,T, Iterable<T>, Iterable<T>, W extends BoundedWindow> implements Serializable -
Serialization Methods
-
readResolve
- Throws:
ObjectStreamException
-
-
Serialized Fields
-
coderBytes
byte[] coderBytes
-
-
-
-
Package org.apache.beam.runners.twister2.utils
-
Class org.apache.beam.runners.twister2.utils.NoOpStepContext
class NoOpStepContext extends Object implements Serializable
-
-
Package org.apache.beam.sdk
-
Exception Class org.apache.beam.sdk.Pipeline.PipelineExecutionException
class PipelineExecutionException extends RuntimeException implements Serializable -
Class org.apache.beam.sdk.RequiresStableInputIT.MakeSideEffectAndThenFailFn
-
Serialized Fields
-
firstTimeCallback
SerializableFunction<Void,
Void> firstTimeCallback -
outputPrefix
String outputPrefix
-
-
-
Class org.apache.beam.sdk.RequiresStableInputIT.PairWithRandomKeyFn
-
-
Package org.apache.beam.sdk.coders
-
Class org.apache.beam.sdk.coders.AtomicCoder
-
Class org.apache.beam.sdk.coders.BigDecimalCoder
-
Class org.apache.beam.sdk.coders.BigEndianIntegerCoder
-
Class org.apache.beam.sdk.coders.BigEndianLongCoder
-
Class org.apache.beam.sdk.coders.BigEndianShortCoder
-
Class org.apache.beam.sdk.coders.BigIntegerCoder
-
Class org.apache.beam.sdk.coders.BitSetCoder
-
Class org.apache.beam.sdk.coders.BooleanCoder
-
Class org.apache.beam.sdk.coders.ByteArrayCoder
class ByteArrayCoder extends AtomicCoder<byte[]> implements Serializable -
Class org.apache.beam.sdk.coders.ByteCoder
-
Exception Class org.apache.beam.sdk.coders.CannotProvideCoderException
class CannotProvideCoderException extends Exception implements Serializable-
Serialized Fields
-
reason
CannotProvideCoderException.ReasonCode reason
-
-
-
Class org.apache.beam.sdk.coders.Coder
class Coder extends Object implements Serializable -
Exception Class org.apache.beam.sdk.coders.Coder.NonDeterministicException
class NonDeterministicException extends Exception implements Serializable -
Exception Class org.apache.beam.sdk.coders.CoderException
class CoderException extends IOException implements Serializable -
Class org.apache.beam.sdk.coders.CollectionCoder
-
Class org.apache.beam.sdk.coders.CustomCoder
-
Class org.apache.beam.sdk.coders.DelegateCoder
-
Serialized Fields
-
coder
Coder<IntermediateT> coder
-
fromFn
DelegateCoder.CodingFunction<IntermediateT,
T> fromFn -
toFn
DelegateCoder.CodingFunction<T,
IntermediateT> toFn -
typeDescriptor
@Nullable TypeDescriptor<T> typeDescriptor
-
-
-
Class org.apache.beam.sdk.coders.DelegateCoderTest
class DelegateCoderTest extends Object implements Serializable -
Class org.apache.beam.sdk.coders.DequeCoder
class DequeCoder extends IterableLikeCoder<T extends @NonNull Object,Deque<T extends @NonNull Object>> implements Serializable -
Class org.apache.beam.sdk.coders.DoubleCoder
-
Class org.apache.beam.sdk.coders.DurationCoder
-
Class org.apache.beam.sdk.coders.FloatCoder
-
Class org.apache.beam.sdk.coders.InstantCoder
-
Class org.apache.beam.sdk.coders.IterableCoder
-
Class org.apache.beam.sdk.coders.IterableLikeCoder
class IterableLikeCoder extends StructuredCoder<IterableT extends Iterable<T>> implements Serializable -
Class org.apache.beam.sdk.coders.KvCoder
class KvCoder extends StructuredCoder<KV<K extends @Nullable Object,V extends @Nullable Object>> implements Serializable -
Class org.apache.beam.sdk.coders.LengthPrefixCoder
-
Class org.apache.beam.sdk.coders.ListCoder
-
Class org.apache.beam.sdk.coders.MapCoder
-
Class org.apache.beam.sdk.coders.NullableCoder
-
Class org.apache.beam.sdk.coders.OptionalCoder
-
Serialized Fields
-
nullableCoder
NullableCoder<T> nullableCoder
-
-
-
Class org.apache.beam.sdk.coders.PCollectionCustomCoderTest.CustomTestCoder
-
Serialization Methods
-
readObject
- Throws:
IOException
ClassNotFoundException
-
writeObject
- Throws:
IOException
-
-
Serialized Fields
-
-
Class org.apache.beam.sdk.coders.RowCoder
-
Class org.apache.beam.sdk.coders.SerializableCoder
-
Serialized Fields
-
type
Class<T extends Serializable> type
-
-
-
Class org.apache.beam.sdk.coders.SerializableCoderTest
class SerializableCoderTest extends Object implements Serializable-
Serialized Fields
-
expectedLogs
org.apache.beam.sdk.testing.ExpectedLogs expectedLogs
-
p
TestPipeline p
-
-
-
Class org.apache.beam.sdk.coders.SetCoder
-
Class org.apache.beam.sdk.coders.ShardedKeyCoder
-
Serialized Fields
-
keyCoder
Coder<KeyT> keyCoder
-
shardNumberCoder
VarIntCoder shardNumberCoder
-
-
-
Class org.apache.beam.sdk.coders.SnappyCoder
-
Class org.apache.beam.sdk.coders.SortedMapCoder
class SortedMapCoder extends StructuredCoder<SortedMap<K extends Comparable<? super K>,V>> implements Serializable -
Class org.apache.beam.sdk.coders.StringDelegateCoder
-
Serialized Fields
-
clazz
Class<T> clazz
-
delegateCoder
DelegateCoder<T,
String> delegateCoder
-
-
-
Class org.apache.beam.sdk.coders.StringUtf8Coder
-
Class org.apache.beam.sdk.coders.StructuredCoder
-
Class org.apache.beam.sdk.coders.TextualIntegerCoder
-
Class org.apache.beam.sdk.coders.TimestampPrefixingWindowCoder
class TimestampPrefixingWindowCoder extends StructuredCoder<T extends BoundedWindow> implements Serializable-
Serialized Fields
-
windowCoder
Coder<T extends BoundedWindow> windowCoder
-
-
-
Class org.apache.beam.sdk.coders.VarIntCoder
-
Class org.apache.beam.sdk.coders.VarLongCoder
-
Class org.apache.beam.sdk.coders.VoidCoder
-
Class org.apache.beam.sdk.coders.ZstdCoder
-
-
Package org.apache.beam.sdk.extensions.avro.coders
-
Class org.apache.beam.sdk.extensions.avro.coders.AvroCoder
-
Serialization Methods
-
readObject
- Throws:
IOException
ClassNotFoundException
-
-
Serialized Fields
-
datumFactory
AvroDatumFactory<T> datumFactory
-
decoder
org.apache.beam.sdk.util.EmptyOnDeserializationThreadLocal<BinaryDecoder> decoder
-
encoder
org.apache.beam.sdk.util.EmptyOnDeserializationThreadLocal<BinaryEncoder> encoder
-
nonDeterministicReasons
List<String> nonDeterministicReasons
-
reader
org.apache.beam.sdk.util.EmptyOnDeserializationThreadLocal<DatumReader<T>> reader
-
schemaSupplier
org.apache.beam.sdk.extensions.avro.coders.AvroCoder.SerializableSchemaSupplier schemaSupplier
-
typeDescriptor
TypeDescriptor<T> typeDescriptor
-
writer
org.apache.beam.sdk.util.EmptyOnDeserializationThreadLocal<DatumWriter<T>> writer
-
-
-
Class org.apache.beam.sdk.extensions.avro.coders.AvroGenericCoder
-
-
Package org.apache.beam.sdk.extensions.avro.io
-
Class org.apache.beam.sdk.extensions.avro.io.AvroDatumFactory
class AvroDatumFactory extends Object implements Serializable -
Class org.apache.beam.sdk.extensions.avro.io.AvroDatumFactory.GenericDatumFactory
-
Class org.apache.beam.sdk.extensions.avro.io.AvroDatumFactory.ReflectDatumFactory
-
Class org.apache.beam.sdk.extensions.avro.io.AvroDatumFactory.SpecificDatumFactory
-
Class org.apache.beam.sdk.extensions.avro.io.AvroIO.Parse
-
Class org.apache.beam.sdk.extensions.avro.io.AvroIO.ParseAll
-
Class org.apache.beam.sdk.extensions.avro.io.AvroIO.ParseFiles
class ParseFiles extends PTransform<PCollection<FileIO.ReadableFile>,PCollection<T>> implements Serializable -
Class org.apache.beam.sdk.extensions.avro.io.AvroIO.Read
-
Class org.apache.beam.sdk.extensions.avro.io.AvroIO.ReadAll
-
Class org.apache.beam.sdk.extensions.avro.io.AvroIO.ReadFiles
class ReadFiles extends PTransform<PCollection<FileIO.ReadableFile>,PCollection<T>> implements Serializable -
Class org.apache.beam.sdk.extensions.avro.io.AvroIO.Sink
class Sink extends Object implements Serializable -
Class org.apache.beam.sdk.extensions.avro.io.AvroIO.TypedWrite
class TypedWrite extends PTransform<PCollection<UserT>,WriteFilesResult<DestinationT>> implements Serializable -
Class org.apache.beam.sdk.extensions.avro.io.AvroIO.Write
-
Serialized Fields
-
inner
AvroIO.TypedWrite<T,
?, T> inner
-
-
-
Class org.apache.beam.sdk.extensions.avro.io.AvroSink
-
Class org.apache.beam.sdk.extensions.avro.io.AvroSource
-
Serialization Methods
-
readResolve
- Throws:
ObjectStreamException
-
-
Serialized Fields
-
mode
org.apache.beam.sdk.extensions.avro.io.AvroSource.Mode<T> mode
-
-
-
Class org.apache.beam.sdk.extensions.avro.io.DynamicAvroDestinations
class DynamicAvroDestinations extends FileBasedSink.DynamicDestinations<UserT,DestinationT, OutputT> implements Serializable
-
-
Package org.apache.beam.sdk.extensions.avro.schemas
-
Class org.apache.beam.sdk.extensions.avro.schemas.AvroRecordSchema
class AvroRecordSchema extends GetterBasedSchemaProviderV2 implements Serializable
-
-
Package org.apache.beam.sdk.extensions.gcp.options
-
Package org.apache.beam.sdk.extensions.gcp.storage
-
Class org.apache.beam.sdk.extensions.gcp.storage.GcsResourceId
class GcsResourceId extends Object implements Serializable-
Serialized Fields
-
gcsPath
GcsPath gcsPath
-
-
-
-
Package org.apache.beam.sdk.extensions.gcp.util
-
Class org.apache.beam.sdk.extensions.gcp.util.CustomHttpErrors.MatcherAndError
class MatcherAndError extends Object implements Serializable
-
-
Package org.apache.beam.sdk.extensions.gcp.util.gcsfs
-
Class org.apache.beam.sdk.extensions.gcp.util.gcsfs.GcsPath
class GcsPath extends Object implements Serializable
-
-
Package org.apache.beam.sdk.extensions.jackson
-
Class org.apache.beam.sdk.extensions.jackson.AsJsons
-
Serialized Fields
-
customMapper
ObjectMapper customMapper
-
inputClass
Class<? extends InputT> inputClass
-
-
-
Class org.apache.beam.sdk.extensions.jackson.AsJsons.AsJsonsWithFailures
class AsJsonsWithFailures extends PTransform<PCollection<InputT>,WithFailures.Result<PCollection<String>, FailureT>> implements Serializable -
Serialized Fields
-
exceptionHandler
@Nullable InferableFunction<WithFailures.ExceptionElement<InputT>,
FailureT> exceptionHandler
-
-
-
Class org.apache.beam.sdk.extensions.jackson.ParseJsons
class ParseJsons extends PTransform<PCollection<String>,PCollection<OutputT>> implements Serializable -
Serialized Fields
-
customMapper
ObjectMapper customMapper
-
outputClass
Class<? extends OutputT> outputClass
-
-
-
Class org.apache.beam.sdk.extensions.jackson.ParseJsons.ParseJsonsWithFailures
class ParseJsonsWithFailures extends PTransform<PCollection<String>,WithFailures.Result<PCollection<OutputT>, FailureT>> implements Serializable -
Serialized Fields
-
exceptionHandler
@Nullable InferableFunction<WithFailures.ExceptionElement<String>,
FailureT> exceptionHandler
-
-
-
-
Package org.apache.beam.sdk.extensions.joinlibrary
-
Class org.apache.beam.sdk.extensions.joinlibrary.Join.FullOuterJoin
class FullOuterJoin extends PTransform<PCollection<KV<K,V1>>, PCollection<KV<K, KV<V1, V2>>>> implements Serializable -
Class org.apache.beam.sdk.extensions.joinlibrary.Join.InnerJoin
class InnerJoin extends PTransform<PCollection<KV<K,V1>>, PCollection<KV<K, KV<V1, V2>>>> implements Serializable -
Class org.apache.beam.sdk.extensions.joinlibrary.Join.LeftOuterJoin
class LeftOuterJoin extends PTransform<PCollection<KV<K,V1>>, PCollection<KV<K, KV<V1, V2>>>> implements Serializable -
Serialized Fields
-
nullValue
V2 nullValue
-
-
-
Class org.apache.beam.sdk.extensions.joinlibrary.Join.RightOuterJoin
class RightOuterJoin extends PTransform<PCollection<KV<K,V1>>, PCollection<KV<K, KV<V1, V2>>>> implements Serializable -
Serialized Fields
-
nullValue
V1 nullValue
-
-
-
-
Package org.apache.beam.sdk.extensions.ml
-
Class org.apache.beam.sdk.extensions.ml.AnnotateImages.PerformImageAnnotation
-
Class org.apache.beam.sdk.extensions.ml.AnnotateText
class AnnotateText extends PTransform<PCollection<com.google.cloud.language.v1.Document>,PCollection<com.google.cloud.language.v1.AnnotateTextResponse>> implements Serializable -
Class org.apache.beam.sdk.extensions.ml.CloudVision.AnnotateImagesFromBytes
class AnnotateImagesFromBytes extends org.apache.beam.sdk.extensions.ml.AnnotateImages<ByteString> implements Serializable -
Class org.apache.beam.sdk.extensions.ml.CloudVision.AnnotateImagesFromBytesWithContext
class AnnotateImagesFromBytesWithContext extends org.apache.beam.sdk.extensions.ml.AnnotateImages<KV<ByteString,com.google.cloud.vision.v1.ImageContext>> implements Serializable -
Class org.apache.beam.sdk.extensions.ml.CloudVision.AnnotateImagesFromGcsUri
class AnnotateImagesFromGcsUri extends org.apache.beam.sdk.extensions.ml.AnnotateImages<String> implements Serializable -
Class org.apache.beam.sdk.extensions.ml.CloudVision.AnnotateImagesFromGcsUriWithContext
class AnnotateImagesFromGcsUriWithContext extends org.apache.beam.sdk.extensions.ml.AnnotateImages<KV<String,com.google.cloud.vision.v1.ImageContext>> implements Serializable -
Class org.apache.beam.sdk.extensions.ml.DLPDeidentifyText
class DLPDeidentifyText extends PTransform<PCollection<KV<String,String>>, PCollection<KV<String, com.google.privacy.dlp.v2.DeidentifyContentResponse>>> implements Serializable -
Class org.apache.beam.sdk.extensions.ml.DLPInspectText
class DLPInspectText extends PTransform<PCollection<KV<String,String>>, PCollection<KV<String, com.google.privacy.dlp.v2.InspectContentResponse>>> implements Serializable -
Class org.apache.beam.sdk.extensions.ml.DLPReidentifyText
class DLPReidentifyText extends PTransform<PCollection<KV<String,String>>, PCollection<KV<String, com.google.privacy.dlp.v2.ReidentifyContentResponse>>> implements Serializable -
Class org.apache.beam.sdk.extensions.ml.RecommendationAICreateCatalogItem
class RecommendationAICreateCatalogItem extends PTransform<PCollection<com.google.api.client.json.GenericJson>,PCollectionTuple> implements Serializable -
Class org.apache.beam.sdk.extensions.ml.RecommendationAIImportCatalogItems
class RecommendationAIImportCatalogItems extends PTransform<PCollection<KV<String,com.google.api.client.json.GenericJson>>, PCollectionTuple> implements Serializable -
Class org.apache.beam.sdk.extensions.ml.RecommendationAIImportUserEvents
class RecommendationAIImportUserEvents extends PTransform<PCollection<KV<String,com.google.api.client.json.GenericJson>>, PCollectionTuple> implements Serializable -
Class org.apache.beam.sdk.extensions.ml.RecommendationAIPredict
class RecommendationAIPredict extends PTransform<PCollection<com.google.api.client.json.GenericJson>,PCollectionTuple> implements Serializable -
Class org.apache.beam.sdk.extensions.ml.RecommendationAIWriteUserEvent
class RecommendationAIWriteUserEvent extends PTransform<PCollection<com.google.api.client.json.GenericJson>,PCollectionTuple> implements Serializable -
Class org.apache.beam.sdk.extensions.ml.VideoIntelligence.AnnotateVideoFromBytes
class AnnotateVideoFromBytes extends PTransform<PCollection<ByteString>,PCollection<List<com.google.cloud.videointelligence.v1.VideoAnnotationResults>>> implements Serializable -
Serialized Fields
-
contextSideInput
PCollectionView<Map<ByteString,
com.google.cloud.videointelligence.v1.VideoContext>> contextSideInput -
featureList
List<com.google.cloud.videointelligence.v1.Feature> featureList
-
-
-
Class org.apache.beam.sdk.extensions.ml.VideoIntelligence.AnnotateVideoFromBytesWithContext
class AnnotateVideoFromBytesWithContext extends PTransform<PCollection<KV<ByteString,com.google.cloud.videointelligence.v1.VideoContext>>, PCollection<List<com.google.cloud.videointelligence.v1.VideoAnnotationResults>>> implements Serializable -
Serialized Fields
-
featureList
List<com.google.cloud.videointelligence.v1.Feature> featureList
-
-
-
Class org.apache.beam.sdk.extensions.ml.VideoIntelligence.AnnotateVideoFromUri
class AnnotateVideoFromUri extends PTransform<PCollection<String>,PCollection<List<com.google.cloud.videointelligence.v1.VideoAnnotationResults>>> implements Serializable -
Serialized Fields
-
contextSideInput
PCollectionView<Map<String,
com.google.cloud.videointelligence.v1.VideoContext>> contextSideInput -
featureList
List<com.google.cloud.videointelligence.v1.Feature> featureList
-
-
-
Class org.apache.beam.sdk.extensions.ml.VideoIntelligence.AnnotateVideoFromURIWithContext
class AnnotateVideoFromURIWithContext extends PTransform<PCollection<KV<String,com.google.cloud.videointelligence.v1.VideoContext>>, PCollection<List<com.google.cloud.videointelligence.v1.VideoAnnotationResults>>> implements Serializable -
Serialized Fields
-
featureList
List<com.google.cloud.videointelligence.v1.Feature> featureList
-
-
-
-
Package org.apache.beam.sdk.extensions.ordered
-
Class org.apache.beam.sdk.extensions.ordered.ContiguousSequenceRange
class ContiguousSequenceRange extends Object implements Serializable -
Class org.apache.beam.sdk.extensions.ordered.OrderedEventProcessor
class OrderedEventProcessor extends PTransform<PCollection<KV<EventKeyT,KV<Long, EventT>>>, OrderedEventProcessorResult<EventKeyT, ResultT, EventT>> implements Serializable -
Class org.apache.beam.sdk.extensions.ordered.OrderedProcessingHandler
class OrderedProcessingHandler extends Object implements Serializable-
Serialized Fields
-
eventTClass
Class<EventT> eventTClass
-
keyTClass
Class<KeyT> keyTClass
-
maxOutputElementsPerBundle
int maxOutputElementsPerBundle
-
produceStatusUpdateOnEveryEvent
boolean produceStatusUpdateOnEveryEvent
-
resultTClass
Class<ResultT> resultTClass
-
stateTClass
Class<StateT extends MutableState<EventT,
?>> stateTClass -
statusUpdateFrequency
Duration statusUpdateFrequency
-
-
-
Class org.apache.beam.sdk.extensions.ordered.OrderedProcessingHandler.OrderedProcessingGlobalSequenceHandler
class OrderedProcessingGlobalSequenceHandler extends OrderedProcessingHandler<EventT,KeyT, StateT extends MutableState<EventT, ?>, ResultT> implements Serializable
-
-
Package org.apache.beam.sdk.extensions.ordered.combiner
-
Class org.apache.beam.sdk.extensions.ordered.combiner.DefaultSequenceCombiner
class DefaultSequenceCombiner extends Combine.CombineFn<TimestampedValue<KV<EventKeyT,KV<Long, EventT>>>, SequenceRangeAccumulator, ContiguousSequenceRange> implements Serializable -
Serialized Fields
-
eventExaminer
EventExaminer<EventT,
StateT extends MutableState<EventT, ?>> eventExaminer
-
-
-
Class org.apache.beam.sdk.extensions.ordered.combiner.SequenceRangeAccumulator.SequenceRangeAccumulatorCoder
class SequenceRangeAccumulatorCoder extends CustomCoder<SequenceRangeAccumulator> implements Serializable-
Serialized Fields
-
dataCoder
VarLongCoder dataCoder
-
initialSequenceCoder
NullableCoder<Long> initialSequenceCoder
-
numberOfRangesCoder
VarIntCoder numberOfRangesCoder
-
-
-
-
Package org.apache.beam.sdk.extensions.protobuf
-
Class org.apache.beam.sdk.extensions.protobuf.ByteStringCoder
-
Class org.apache.beam.sdk.extensions.protobuf.DynamicProtoCoder
- serialVersionUID:
- 1L
-
Serialization Methods
-
readObject
- Throws:
ClassNotFoundException
IOException
-
writeObject
- Throws:
IOException
-
-
Class org.apache.beam.sdk.extensions.protobuf.ProtoCoder
- serialVersionUID:
- -5043999806040629525L
-
Serialized Fields
-
extensionHostClasses
Set<Class<?>> extensionHostClasses
All extension host classes included in thisProtoCoder
. The extensions from these classes will be included in theExtensionRegistry
used during encoding and decoding. -
protoMessageClass
Class<T extends Message> protoMessageClass
TheMessage
type to be coded.
-
-
Class org.apache.beam.sdk.extensions.protobuf.ProtoDomain
class ProtoDomain extends Object implements Serializable- serialVersionUID:
- 1L
-
Serialization Methods
-
readObject
- Throws:
IOException
-
writeObject
- Throws:
IOException
-
-
Class org.apache.beam.sdk.extensions.protobuf.ProtoDynamicMessageSchema
class ProtoDynamicMessageSchema extends Object implements Serializable- serialVersionUID:
- 1L
-
Serialization Methods
-
readResolve
Initialize the transient fields after deserialization or construction.
-
-
Serialized Fields
-
context
org.apache.beam.sdk.extensions.protobuf.ProtoDynamicMessageSchema.Context context
Context of the schema, the context can be generated from a source schema or descriptors. The ability of converting back from Row to proto depends on the type of context.
-
-
Class org.apache.beam.sdk.extensions.protobuf.ProtoMessageSchema
class ProtoMessageSchema extends GetterBasedSchemaProviderV2 implements Serializable -
Class org.apache.beam.sdk.extensions.protobuf.ProtoSchemaLogicalTypes.Fixed32
-
Class org.apache.beam.sdk.extensions.protobuf.ProtoSchemaLogicalTypes.Fixed64
-
Class org.apache.beam.sdk.extensions.protobuf.ProtoSchemaLogicalTypes.SFixed32
-
Class org.apache.beam.sdk.extensions.protobuf.ProtoSchemaLogicalTypes.SFixed64
-
Class org.apache.beam.sdk.extensions.protobuf.ProtoSchemaLogicalTypes.SInt32
-
Class org.apache.beam.sdk.extensions.protobuf.ProtoSchemaLogicalTypes.SInt64
-
Class org.apache.beam.sdk.extensions.protobuf.ProtoSchemaLogicalTypes.UInt32
-
Class org.apache.beam.sdk.extensions.protobuf.ProtoSchemaLogicalTypes.UInt64
-
-
Package org.apache.beam.sdk.extensions.python
-
Class org.apache.beam.sdk.extensions.python.PythonExternalTransform
class PythonExternalTransform extends PTransform<InputT extends PInput,OutputT extends POutput> implements Serializable -
Serialized Fields
-
argsArray
@Nullable Object @NonNull [] argsArray
-
expansionService
String expansionService
-
extraPackages
List<String> extraPackages
-
fullyQualifiedName
String fullyQualifiedName
-
kwargsMap
SortedMap<String,
Object> kwargsMap -
outputCoders
Map<String,
Coder<?>> outputCoders -
providedKwargsRow
@Nullable Row providedKwargsRow
-
typeHints
Map<Class<?>,
Schema.FieldType> typeHints
-
-
-
-
Package org.apache.beam.sdk.extensions.python.transforms
-
Class org.apache.beam.sdk.extensions.python.transforms.DataframeTransform
class DataframeTransform extends PTransform<PCollection<Row>,PCollection<Row>> implements Serializable -
Class org.apache.beam.sdk.extensions.python.transforms.PythonMap
class PythonMap extends PTransform<PCollection<? extends InputT>,PCollection<OutputT>> implements Serializable -
Class org.apache.beam.sdk.extensions.python.transforms.RunInference
-
-
Package org.apache.beam.sdk.extensions.sbe
-
Class org.apache.beam.sdk.extensions.sbe.SbeLogicalTypes.LocalMktDate
class LocalMktDate extends org.apache.beam.sdk.extensions.sbe.SbeLogicalTypes.SbeDateType implements Serializable -
Class org.apache.beam.sdk.extensions.sbe.SbeLogicalTypes.TZTimeOnly
class TZTimeOnly extends Object implements Serializable -
Class org.apache.beam.sdk.extensions.sbe.SbeLogicalTypes.TZTimestamp
class TZTimestamp extends Object implements Serializable -
Class org.apache.beam.sdk.extensions.sbe.SbeLogicalTypes.Uint16
-
Class org.apache.beam.sdk.extensions.sbe.SbeLogicalTypes.Uint32
-
Class org.apache.beam.sdk.extensions.sbe.SbeLogicalTypes.Uint64
-
Class org.apache.beam.sdk.extensions.sbe.SbeLogicalTypes.Uint8
-
Class org.apache.beam.sdk.extensions.sbe.SbeLogicalTypes.UTCDateOnly
class UTCDateOnly extends org.apache.beam.sdk.extensions.sbe.SbeLogicalTypes.SbeDateType implements Serializable -
Class org.apache.beam.sdk.extensions.sbe.SbeLogicalTypes.UTCTimeOnly
class UTCTimeOnly extends Object implements Serializable -
Class org.apache.beam.sdk.extensions.sbe.SbeLogicalTypes.UTCTimestamp
class UTCTimestamp extends Object implements Serializable -
Class org.apache.beam.sdk.extensions.sbe.SbeSchema
class SbeSchema extends Object implements Serializable- serialVersionUID:
- 1L
-
Serialized Fields
-
ir
@Nullable SerializableIr ir
-
irOptions
@Nullable SbeSchema.IrOptions irOptions
-
sbeFields
org.apache.beam.vendor.guava.v32_1_2_jre.com.google.common.collect.ImmutableList<org.apache.beam.sdk.extensions.sbe.SbeField> sbeFields
-
-
Class org.apache.beam.sdk.extensions.sbe.SbeSchema.IrOptions
class IrOptions extends Object implements Serializable- serialVersionUID:
- 1L
-
Class org.apache.beam.sdk.extensions.sbe.SerializableIr
class SerializableIr extends Object implements Serializable- serialVersionUID:
- 1L
-
Serialization Methods
-
readObject
- Throws:
IOException
ClassNotFoundException
-
writeObject
- Throws:
IOException
-
-
Serialized Fields
-
ir
Ir ir
-
-
Class org.apache.beam.sdk.extensions.sbe.UnsignedOptions
class UnsignedOptions extends Object implements Serializable- serialVersionUID:
- 1L
-
-
Package org.apache.beam.sdk.extensions.sketching
-
Class org.apache.beam.sdk.extensions.sketching.ApproximateDistinct.ApproximateDistinctFn
class ApproximateDistinctFn extends Combine.CombineFn<InputT,com.clearspring.analytics.stream.cardinality.HyperLogLogPlus, com.clearspring.analytics.stream.cardinality.HyperLogLogPlus> implements Serializable -
Class org.apache.beam.sdk.extensions.sketching.ApproximateDistinct.GloballyDistinct
class GloballyDistinct extends PTransform<PCollection<InputT>,PCollection<Long>> implements Serializable -
Class org.apache.beam.sdk.extensions.sketching.ApproximateDistinct.HyperLogLogPlusCoder
class HyperLogLogPlusCoder extends CustomCoder<com.clearspring.analytics.stream.cardinality.HyperLogLogPlus> implements Serializable -
Class org.apache.beam.sdk.extensions.sketching.ApproximateDistinct.PerKeyDistinct
class PerKeyDistinct extends PTransform<PCollection<KV<K,V>>, PCollection<KV<K, Long>>> implements Serializable -
Class org.apache.beam.sdk.extensions.sketching.SketchFrequencies.CountMinSketchFn
class CountMinSketchFn extends Combine.CombineFn<InputT,SketchFrequencies.Sketch<InputT>, SketchFrequencies.Sketch<InputT>> implements Serializable -
Class org.apache.beam.sdk.extensions.sketching.SketchFrequencies.GlobalSketch
class GlobalSketch extends PTransform<PCollection<InputT>,PCollection<SketchFrequencies.Sketch<InputT>>> implements Serializable -
Class org.apache.beam.sdk.extensions.sketching.SketchFrequencies.PerKeySketch
class PerKeySketch extends PTransform<PCollection<KV<K,V>>, PCollection<KV<K, SketchFrequencies.Sketch<V>>>> implements Serializable -
Class org.apache.beam.sdk.extensions.sketching.SketchFrequencies.Sketch
class Sketch extends Object implements Serializable -
Class org.apache.beam.sdk.extensions.sketching.TDigestQuantiles.GlobalDigest
class GlobalDigest extends PTransform<PCollection<Double>,PCollection<com.tdunning.math.stats.MergingDigest>> implements Serializable -
Class org.apache.beam.sdk.extensions.sketching.TDigestQuantiles.PerKeyDigest
class PerKeyDigest extends PTransform<PCollection<KV<K,Double>>, PCollection<KV<K, com.tdunning.math.stats.MergingDigest>>> implements Serializable -
Class org.apache.beam.sdk.extensions.sketching.TDigestQuantiles.TDigestQuantilesFn
class TDigestQuantilesFn extends Combine.CombineFn<Double,com.tdunning.math.stats.MergingDigest, com.tdunning.math.stats.MergingDigest> implements Serializable -
Serialized Fields
-
compression
double compression
-
-
-
-
Package org.apache.beam.sdk.extensions.sorter
-
Class org.apache.beam.sdk.extensions.sorter.BufferedExternalSorter.Options
class Options extends Object implements Serializable-
Serialized Fields
-
memoryMB
int memoryMB
-
sorterType
ExternalSorter.Options.SorterType sorterType
-
tempLocation
String tempLocation
-
-
-
Class org.apache.beam.sdk.extensions.sorter.ExternalSorter.Options
class Options extends Object implements Serializable-
Serialized Fields
-
memoryMB
int memoryMB
-
sorterType
ExternalSorter.Options.SorterType sorterType
-
tempLocation
String tempLocation
-
-
-
Class org.apache.beam.sdk.extensions.sorter.InMemorySorter.Options
class Options extends Object implements Serializable-
Serialized Fields
-
memoryMB
long memoryMB
-
-
-
Class org.apache.beam.sdk.extensions.sorter.SortValues
class SortValues extends PTransform<PCollection<KV<PrimaryKeyT,Iterable<KV<SecondaryKeyT, ValueT>>>>, PCollection<KV<PrimaryKeyT, Iterable<KV<SecondaryKeyT, ValueT>>>>> implements Serializable -
Serialized Fields
-
sorterOptions
BufferedExternalSorter.Options sorterOptions
-
-
-
-
Package org.apache.beam.sdk.extensions.sql
-
Class org.apache.beam.sdk.extensions.sql.SqlTransform
-
Class org.apache.beam.sdk.extensions.sql.TypedCombineFnDelegate
class TypedCombineFnDelegate extends Combine.CombineFn<InputT,AccumT, OutputT> implements Serializable -
Serialized Fields
-
delegate
Combine.CombineFn<InputT,
AccumT, OutputT> delegate
-
-
-
-
Package org.apache.beam.sdk.extensions.sql.example.model
-
Class org.apache.beam.sdk.extensions.sql.example.model.Customer
class Customer extends Object implements Serializable -
Class org.apache.beam.sdk.extensions.sql.example.model.Order
class Order extends Object implements Serializable-
Serialized Fields
-
customerId
int customerId
-
id
int id
-
-
-
-
Package org.apache.beam.sdk.extensions.sql.impl
-
Class org.apache.beam.sdk.extensions.sql.impl.BeamTableStatistics
class BeamTableStatistics extends Object implements Serializable -
Class org.apache.beam.sdk.extensions.sql.impl.LazyAggregateCombineFn
class LazyAggregateCombineFn extends Combine.CombineFn<InputT,AccumT, OutputT> implements Serializable -
Exception Class org.apache.beam.sdk.extensions.sql.impl.ParseException
class ParseException extends RuntimeException implements Serializable -
Exception Class org.apache.beam.sdk.extensions.sql.impl.SqlConversionException
class SqlConversionException extends RuntimeException implements Serializable -
Class org.apache.beam.sdk.extensions.sql.impl.TVFSlidingWindowFn
-
Class org.apache.beam.sdk.extensions.sql.impl.UdafImpl
class UdafImpl extends Object implements Serializable-
Serialized Fields
-
combineFn
Combine.CombineFn<InputT,
AccumT, OutputT> combineFn
-
-
-
-
Package org.apache.beam.sdk.extensions.sql.impl.cep
-
Class org.apache.beam.sdk.extensions.sql.impl.cep.CEPCall
class CEPCall extends CEPOperation implements Serializable-
Serialized Fields
-
operands
List<CEPOperation> operands
-
operator
CEPOperator operator
-
-
-
Class org.apache.beam.sdk.extensions.sql.impl.cep.CEPFieldRef
class CEPFieldRef extends CEPOperation implements Serializable-
Serialized Fields
-
alpha
String alpha
-
fieldIndex
int fieldIndex
-
-
-
Class org.apache.beam.sdk.extensions.sql.impl.cep.CEPLiteral
class CEPLiteral extends CEPOperation implements Serializable-
Serialized Fields
-
typeName
Schema.TypeName typeName
-
-
-
Class org.apache.beam.sdk.extensions.sql.impl.cep.CEPMeasure
class CEPMeasure extends Object implements Serializable-
Serialized Fields
-
fieldRef
CEPFieldRef fieldRef
-
fieldType
Schema.FieldType fieldType
-
opr
CEPOperation opr
-
outTableName
String outTableName
-
-
-
Class org.apache.beam.sdk.extensions.sql.impl.cep.CEPOperation
class CEPOperation extends Object implements Serializable -
Class org.apache.beam.sdk.extensions.sql.impl.cep.CEPOperator
class CEPOperator extends Object implements Serializable-
Serialized Fields
-
cepKind
CEPKind cepKind
-
-
-
Class org.apache.beam.sdk.extensions.sql.impl.cep.CEPPattern
class CEPPattern extends Object implements Serializable-
Serialized Fields
-
patternCondition
CEPCall patternCondition
-
patternVar
String patternVar
-
quant
Quantifier quant
-
-
-
Class org.apache.beam.sdk.extensions.sql.impl.cep.OrderKey
class OrderKey extends Object implements Serializable-
Serialized Fields
-
dir
boolean dir
-
fIndex
int fIndex
-
nullFirst
boolean nullFirst
-
-
-
Class org.apache.beam.sdk.extensions.sql.impl.cep.PatternCondition
class PatternCondition extends Object implements Serializable -
Class org.apache.beam.sdk.extensions.sql.impl.cep.Quantifier
class Quantifier extends Object implements Serializable-
Serialized Fields
-
repr
String repr
-
-
-
-
Package org.apache.beam.sdk.extensions.sql.impl.nfa
-
Class org.apache.beam.sdk.extensions.sql.impl.nfa.NFA
class NFA extends Object implements Serializable
-
-
Package org.apache.beam.sdk.extensions.sql.impl.rel
-
Class org.apache.beam.sdk.extensions.sql.impl.rel.BeamSetOperatorRelBase
class BeamSetOperatorRelBase extends PTransform<PCollectionList<Row>,PCollection<Row>> implements Serializable -
Serialized Fields
-
all
boolean all
-
beamRelNode
BeamRelNode beamRelNode
-
opType
BeamSetOperatorRelBase.OpType opType
-
-
-
Class org.apache.beam.sdk.extensions.sql.impl.rel.BeamSortRel.BeamSqlRowComparator
class BeamSqlRowComparator extends Object implements Serializable
-
-
Package org.apache.beam.sdk.extensions.sql.impl.schema
-
Class org.apache.beam.sdk.extensions.sql.impl.schema.BeamPCollectionTable
class BeamPCollectionTable extends SchemaBaseBeamTable implements Serializable
-
-
Package org.apache.beam.sdk.extensions.sql.impl.transform
-
Class org.apache.beam.sdk.extensions.sql.impl.transform.BeamBuiltinAggregations.BitXOr
class BitXOr extends Combine.CombineFn<T extends Number,org.apache.beam.sdk.extensions.sql.impl.transform.BeamBuiltinAggregations.BitXOr.Accum, Long> implements Serializable -
Class org.apache.beam.sdk.extensions.sql.impl.transform.BeamBuiltinAnalyticFunctions.PositionAwareCombineFn
class PositionAwareCombineFn extends Combine.CombineFn<InputT,AccumT, OutputT> implements Serializable -
Class org.apache.beam.sdk.extensions.sql.impl.transform.BeamJoinTransforms.JoinAsLookup
-
Class org.apache.beam.sdk.extensions.sql.impl.transform.BeamSetOperatorsTransforms.BeamSqlRow2KvFn
-
Class org.apache.beam.sdk.extensions.sql.impl.transform.BeamSetOperatorsTransforms.SetOperatorFilteringDoFn
-
Serialized Fields
-
all
boolean all
-
leftTag
String leftTag
-
opType
BeamSetOperatorRelBase.OpType opType
-
rightTag
String rightTag
-
-
-
Class org.apache.beam.sdk.extensions.sql.impl.transform.BeamSqlOutputToConsoleFn
-
-
Package org.apache.beam.sdk.extensions.sql.impl.transform.agg
-
Class org.apache.beam.sdk.extensions.sql.impl.transform.agg.CountIf.CountIfFn
-
Serialized Fields
-
countFn
Combine.CombineFn<Boolean,
long[], Long> countFn
-
-
-
Class org.apache.beam.sdk.extensions.sql.impl.transform.agg.CovarianceFn
class CovarianceFn extends Combine.CombineFn<Row,org.apache.beam.sdk.extensions.sql.impl.transform.agg.CovarianceAccumulator, T extends Number> implements Serializable -
Serialized Fields
-
decimalConverter
SerializableFunction<BigDecimal,
T extends Number> decimalConverter -
isSample
boolean isSample
-
-
-
Class org.apache.beam.sdk.extensions.sql.impl.transform.agg.VarianceFn
class VarianceFn extends Combine.CombineFn<T extends Number,org.apache.beam.sdk.extensions.sql.impl.transform.agg.VarianceAccumulator, T extends Number> implements Serializable -
Serialized Fields
-
decimalConverter
SerializableFunction<BigDecimal,
T extends Number> decimalConverter -
isSample
boolean isSample
-
-
-
-
Package org.apache.beam.sdk.extensions.sql.impl.udaf
-
Class org.apache.beam.sdk.extensions.sql.impl.udaf.ArrayAgg.ArrayAggArray
-
Class org.apache.beam.sdk.extensions.sql.impl.udaf.StringAgg.StringAggByte
class StringAggByte extends Combine.CombineFn<byte[],String, byte[]> implements Serializable -
Serialized Fields
-
delimiter
String delimiter
-
-
-
Class org.apache.beam.sdk.extensions.sql.impl.udaf.StringAgg.StringAggString
-
Serialized Fields
-
delimiter
String delimiter
-
-
-
-
Package org.apache.beam.sdk.extensions.sql.impl.utils
-
Class org.apache.beam.sdk.extensions.sql.impl.utils.CalciteUtils.TimeWithLocalTzType
-
Class org.apache.beam.sdk.extensions.sql.impl.utils.SerializableRexFieldAccess
class SerializableRexFieldAccess extends SerializableRexNode implements Serializable -
Class org.apache.beam.sdk.extensions.sql.impl.utils.SerializableRexInputRef
class SerializableRexInputRef extends SerializableRexNode implements Serializable-
Serialized Fields
-
index
int index
-
-
-
Class org.apache.beam.sdk.extensions.sql.impl.utils.SerializableRexNode
class SerializableRexNode extends Object implements Serializable
-
-
Package org.apache.beam.sdk.extensions.sql.meta
-
Class org.apache.beam.sdk.extensions.sql.meta.SchemaBaseBeamTable
class SchemaBaseBeamTable extends BaseBeamTable implements Serializable-
Serialized Fields
-
schema
Schema schema
-
-
-
Class org.apache.beam.sdk.extensions.sql.meta.Table
class Table extends Object implements Serializable
-
-
Package org.apache.beam.sdk.extensions.sql.meta.provider
-
Exception Class org.apache.beam.sdk.extensions.sql.meta.provider.InvalidTableException
class InvalidTableException extends IllegalArgumentException implements Serializable -
Class org.apache.beam.sdk.extensions.sql.meta.provider.SchemaIOTableProviderWrapper
class SchemaIOTableProviderWrapper extends InMemoryMetaTableProvider implements Serializable
-
-
Package org.apache.beam.sdk.extensions.sql.meta.provider.avro
-
Class org.apache.beam.sdk.extensions.sql.meta.provider.avro.AvroTableProvider
class AvroTableProvider extends SchemaIOTableProviderWrapper implements Serializable
-
-
Package org.apache.beam.sdk.extensions.sql.meta.provider.bigquery
-
Exception Class org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BigQueryTable.InvalidPropertyException
class InvalidPropertyException extends UnsupportedOperationException implements Serializable
-
-
Package org.apache.beam.sdk.extensions.sql.meta.provider.bigtable
-
Class org.apache.beam.sdk.extensions.sql.meta.provider.bigtable.BigtableTable
class BigtableTable extends SchemaBaseBeamTable implements Serializable
-
-
Package org.apache.beam.sdk.extensions.sql.meta.provider.datagen
-
Class org.apache.beam.sdk.extensions.sql.meta.provider.datagen.DataGeneratorPTransform
-
Serialized Fields
-
properties
ObjectNode properties
-
schema
Schema schema
-
-
-
Class org.apache.beam.sdk.extensions.sql.meta.provider.datagen.DataGeneratorRowFn
-
Serialized Fields
-
primaryTimestampField
String primaryTimestampField
-
properties
ObjectNode properties
-
schema
Schema schema
-
-
-
Class org.apache.beam.sdk.extensions.sql.meta.provider.datagen.DataGeneratorTable
class DataGeneratorTable extends SchemaBaseBeamTable implements Serializable-
Serialized Fields
-
properties
ObjectNode properties
-
-
-
-
Package org.apache.beam.sdk.extensions.sql.meta.provider.datastore
-
Class org.apache.beam.sdk.extensions.sql.meta.provider.datastore.DataStoreV1TableProvider
class DataStoreV1TableProvider extends SchemaIOTableProviderWrapper implements Serializable
-
-
Package org.apache.beam.sdk.extensions.sql.meta.provider.kafka
-
Class org.apache.beam.sdk.extensions.sql.meta.provider.kafka.BeamKafkaCSVTable
class BeamKafkaCSVTable extends BeamKafkaTable implements Serializable-
Serialized Fields
-
csvFormat
CSVFormat csvFormat
-
-
-
Class org.apache.beam.sdk.extensions.sql.meta.provider.kafka.BeamKafkaTable
class BeamKafkaTable extends SchemaBaseBeamTable implements Serializable-
Serialized Fields
-
bootstrapServers
String bootstrapServers
-
configUpdates
Map<String,
Object> configUpdates -
numberOfRecordsForRate
int numberOfRecordsForRate
-
rowCountStatistics
BeamTableStatistics rowCountStatistics
-
timestampPolicyFactory
TimestampPolicyFactory timestampPolicyFactory
-
topicPartitions
List<TopicPartition> topicPartitions
-
topics
List<String> topics
-
-
-
Class org.apache.beam.sdk.extensions.sql.meta.provider.kafka.PayloadSerializerKafkaTable
class PayloadSerializerKafkaTable extends BeamKafkaTable implements Serializable-
Serialized Fields
-
serializer
PayloadSerializer serializer
-
-
-
-
Package org.apache.beam.sdk.extensions.sql.meta.provider.mongodb
-
Class org.apache.beam.sdk.extensions.sql.meta.provider.mongodb.MongoDbTable
class MongoDbTable extends SchemaBaseBeamTable implements Serializable -
Class org.apache.beam.sdk.extensions.sql.meta.provider.mongodb.MongoDbTable.DocumentToRow
class DocumentToRow extends PTransform<PCollection<Document>,PCollection<Row>> implements Serializable -
Serialized Fields
-
schema
Schema schema
-
-
-
Class org.apache.beam.sdk.extensions.sql.meta.provider.mongodb.MongoDbTable.RowToDocument
class RowToDocument extends PTransform<PCollection<Row>,PCollection<Document>> implements Serializable
-
-
Package org.apache.beam.sdk.extensions.sql.meta.provider.pubsub
-
Class org.apache.beam.sdk.extensions.sql.meta.provider.pubsub.PubsubTableProvider
class PubsubTableProvider extends SchemaIOTableProviderWrapper implements Serializable
-
-
Package org.apache.beam.sdk.extensions.sql.meta.provider.test
-
Class org.apache.beam.sdk.extensions.sql.meta.provider.test.TestBoundedTable
class TestBoundedTable extends TestTable implements Serializable -
Class org.apache.beam.sdk.extensions.sql.meta.provider.test.TestTable
class TestTable extends SchemaBaseBeamTable implements Serializable -
Class org.apache.beam.sdk.extensions.sql.meta.provider.test.TestTableProvider.TableWithRows
class TableWithRows extends Object implements Serializable -
Class org.apache.beam.sdk.extensions.sql.meta.provider.test.TestUnboundedTable
class TestUnboundedTable extends TestTable implements Serializable-
Serialized Fields
-
statistics
BeamTableStatistics statistics
-
timestampedRows
List<org.apache.beam.vendor.calcite.v1_28_0.org.apache.calcite.util.Pair<Duration,
List<Row>>> timestampedRows rows flow out from this table with the specified watermark instant. -
timestampField
int timestampField
specify the index of column in the row which stands for the event time field.
-
-
-
-
Package org.apache.beam.sdk.extensions.sql.meta.provider.text
-
Class org.apache.beam.sdk.extensions.sql.meta.provider.text.TextJsonTable
class TextJsonTable extends TextTable implements Serializable -
Class org.apache.beam.sdk.extensions.sql.meta.provider.text.TextTable
class TextTable extends SchemaBaseBeamTable implements Serializable-
Serialized Fields
-
filePattern
String filePattern
-
readConverter
PTransform<PCollection<String>,
PCollection<Row>> readConverter -
rowCountStatistics
BeamTableStatistics rowCountStatistics
-
writeConverter
PTransform<PCollection<Row>,
PCollection<String>> writeConverter
-
-
-
Class org.apache.beam.sdk.extensions.sql.meta.provider.text.TextTableProvider.CsvToRow
-
Class org.apache.beam.sdk.extensions.sql.meta.provider.text.TextTableProvider.LinesReadConverter
class LinesReadConverter extends PTransform<PCollection<String>,PCollection<Row>> implements Serializable -
Class org.apache.beam.sdk.extensions.sql.meta.provider.text.TextTableProvider.LinesWriteConverter
class LinesWriteConverter extends PTransform<PCollection<Row>,PCollection<String>> implements Serializable
-
-
Package org.apache.beam.sdk.extensions.sql.provider
-
Class org.apache.beam.sdk.extensions.sql.provider.UdfTestProvider.DateIncrementAllFn
class DateIncrementAllFn extends ScalarFn implements Serializable -
Class org.apache.beam.sdk.extensions.sql.provider.UdfTestProvider.HelloWorldFn
class HelloWorldFn extends ScalarFn implements Serializable -
Class org.apache.beam.sdk.extensions.sql.provider.UdfTestProvider.IncrementFn
class IncrementFn extends ScalarFn implements Serializable -
Class org.apache.beam.sdk.extensions.sql.provider.UdfTestProvider.IsNullFn
class IsNullFn extends ScalarFn implements Serializable -
Class org.apache.beam.sdk.extensions.sql.provider.UdfTestProvider.MatchFn
class MatchFn extends ScalarFn implements Serializable -
Class org.apache.beam.sdk.extensions.sql.provider.UdfTestProvider.UnusedFn
class UnusedFn extends ScalarFn implements Serializable
-
-
Package org.apache.beam.sdk.extensions.sql.udf
-
Class org.apache.beam.sdk.extensions.sql.udf.ScalarFn
class ScalarFn extends Object implements Serializable
-
-
Package org.apache.beam.sdk.extensions.sql.zetasql
-
Exception Class org.apache.beam.sdk.extensions.sql.zetasql.ZetaSqlException
class ZetaSqlException extends RuntimeException implements Serializable
-
-
Package org.apache.beam.sdk.extensions.timeseries
-
Class org.apache.beam.sdk.extensions.timeseries.FillGaps
-
Class org.apache.beam.sdk.extensions.timeseries.FillGaps.FillGapsDoFn
-
Serialized Fields
-
bucketWindows
FixedWindows bucketWindows
-
gapDurationSpec
StateSpec<ValueState<SortedMap<Instant,
Long>>> gapDurationSpec -
gapFillingTimersSpec
TimerSpec gapFillingTimersSpec
-
gcTimersSpec
TimerSpec gcTimersSpec
-
gcWindows
FixedWindows gcWindows
-
interpolateFunction
SerializableFunction<FillGaps.InterpolateData<ValueT>,
ValueT> interpolateFunction -
maxGapFillBuckets
long maxGapFillBuckets
-
mergeValues
SerializableBiFunction<TimestampedValue<ValueT>,
TimestampedValue<ValueT>, TimestampedValue<ValueT>> mergeValues -
seenBucketsSpec
StateSpec<ValueState<SortedMap<Instant,
TimestampedValue<ValueT>>>> seenBucketsSpec -
stopTime
Instant stopTime
-
-
-
-
Package org.apache.beam.sdk.extensions.yaml
-
Class org.apache.beam.sdk.extensions.yaml.YamlTransform
class YamlTransform extends PTransform<InputT extends PInput,OutputT extends POutput> implements Serializable -
Serialized Fields
-
inputTags
@Nullable Set<String> inputTags
If non-null, the set of input tags that are expected to be passed to this transform.If null, a PCollection<Row> or PBegin is expected.
-
outputTags
@Nullable Set<String> outputTags
If non-null, the set of output tags that are expected to be produced by this transform.If null, exactly one output is expected and will be returned as a PCollection<Row>.
-
yamlDefinition
String yamlDefinition
The YAML definition of this transform.
-
-
-
-
Package org.apache.beam.sdk.extensions.zetasketch
-
Class org.apache.beam.sdk.extensions.zetasketch.ApproximateCountDistinct.Globally
-
Class org.apache.beam.sdk.extensions.zetasketch.ApproximateCountDistinct.PerKey
class PerKey extends PTransform<PCollection<KV<K,V>>, PCollection<KV<K, Long>>> implements Serializable
-
-
Package org.apache.beam.sdk.fn.data
-
Exception Class org.apache.beam.sdk.fn.data.BeamFnDataInboundObserver.CloseException
class CloseException extends Exception implements Serializable
-
-
Package org.apache.beam.sdk.fn.windowing
-
Package org.apache.beam.sdk.io
-
Class org.apache.beam.sdk.io.BlockBasedSource
-
Class org.apache.beam.sdk.io.BoundedReadFromUnboundedSource
class BoundedReadFromUnboundedSource extends PTransform<PBegin,PCollection<T>> implements Serializable -
Serialized Fields
-
maxNumRecords
long maxNumRecords
-
maxReadTime
@Nullable Duration maxReadTime
-
source
UnboundedSource<T,
?> source
-
-
-
Class org.apache.beam.sdk.io.BoundedReadFromUnboundedSourceTest
class BoundedReadFromUnboundedSourceTest extends Object implements Serializable -
Class org.apache.beam.sdk.io.BoundedReadFromUnboundedSourceTest.TestCountingSource
class TestCountingSource extends UnboundedSource<KV<Integer,Integer>, org.apache.beam.sdk.io.BoundedReadFromUnboundedSourceTest.TestCountingSource.CounterMark> implements Serializable -
Serialized Fields
-
allowSplitting
boolean allowSplitting
-
dedup
boolean dedup
-
numMessagesPerShard
int numMessagesPerShard
-
shardNumber
int shardNumber
-
throwOnFirstSnapshot
boolean throwOnFirstSnapshot
-
-
-
Class org.apache.beam.sdk.io.BoundedSource
-
Class org.apache.beam.sdk.io.ClassLoaderFileSystem.ClassLoaderResourceId
class ClassLoaderResourceId extends Object implements Serializable-
Serialized Fields
-
path
String path
-
-
-
Class org.apache.beam.sdk.io.CompressedSource
-
Serialized Fields
-
channelFactory
CompressedSource.DecompressingChannelFactory channelFactory
-
sourceDelegate
FileBasedSource<T> sourceDelegate
-
-
-
Class org.apache.beam.sdk.io.CountingSource.CounterMarkCoder
-
Class org.apache.beam.sdk.io.DefaultFilenamePolicy
class DefaultFilenamePolicy extends FileBasedSink.FilenamePolicy implements Serializable-
Serialized Fields
-
params
DefaultFilenamePolicy.Params params
-
-
-
Class org.apache.beam.sdk.io.DefaultFilenamePolicy.Params
class Params extends Object implements Serializable-
Serialized Fields
-
baseFilename
@Nullable ValueProvider<ResourceId> baseFilename
-
explicitTemplate
boolean explicitTemplate
-
shardTemplate
String shardTemplate
-
suffix
String suffix
-
-
-
Class org.apache.beam.sdk.io.DefaultFilenamePolicy.ParamsCoder
-
Class org.apache.beam.sdk.io.DrunkWritableByteChannelFactory
class DrunkWritableByteChannelFactory extends Object implements Serializable -
Class org.apache.beam.sdk.io.FileBasedSink
class FileBasedSink extends Object implements Serializable-
Serialized Fields
-
dynamicDestinations
FileBasedSink.DynamicDestinations<?,
DestinationT, OutputT> dynamicDestinations -
tempDirectoryProvider
ValueProvider<ResourceId> tempDirectoryProvider
The directory to which files will be written. -
writableByteChannelFactory
FileBasedSink.WritableByteChannelFactory writableByteChannelFactory
TheFileBasedSink.WritableByteChannelFactory
that is used to wrap the raw data output to the underlying channel. The default is to not compress the output usingCompression.UNCOMPRESSED
.
-
-
-
Class org.apache.beam.sdk.io.FileBasedSink.DynamicDestinations
class DynamicDestinations extends Object implements Serializable -
Class org.apache.beam.sdk.io.FileBasedSink.FilenamePolicy
class FilenamePolicy extends Object implements Serializable -
Class org.apache.beam.sdk.io.FileBasedSink.FileResultCoder
class FileResultCoder extends StructuredCoder<FileBasedSink.FileResult<DestinationT>> implements Serializable-
Serialized Fields
-
destinationCoder
Coder<DestinationT> destinationCoder
-
windowCoder
Coder<BoundedWindow> windowCoder
-
-
-
Class org.apache.beam.sdk.io.FileBasedSink.WriteOperation
class WriteOperation extends Object implements Serializable-
Serialized Fields
-
baseTempDirectory
ValueProvider<ResourceId> baseTempDirectory
Base directory for temporary output files. A subdirectory of this may be used based upon tempSubdirType. -
sink
FileBasedSink<?,
DestinationT, OutputT> sink The Sink that this WriteOperation will write to. -
subdirUUID
UUID subdirUUID
-
tempSubdirType
org.apache.beam.sdk.io.FileBasedSink.WriteOperation.TempSubDirType tempSubdirType
-
windowedWrites
boolean windowedWrites
Whether windowed writes are being used.
-
-
-
Class org.apache.beam.sdk.io.FileBasedSource
-
Serialized Fields
-
emptyMatchTreatment
EmptyMatchTreatment emptyMatchTreatment
-
fileOrPatternSpec
ValueProvider<String> fileOrPatternSpec
-
filesSizeBytes
AtomicReference<@Nullable Long> filesSizeBytes
-
mode
FileBasedSource.Mode mode
-
singleFileMetadata
@Nullable MatchResult.Metadata singleFileMetadata
-
-
-
Class org.apache.beam.sdk.io.FileIO.Match
-
Class org.apache.beam.sdk.io.FileIO.MatchAll
class MatchAll extends PTransform<PCollection<String>,PCollection<MatchResult.Metadata>> implements Serializable -
Class org.apache.beam.sdk.io.FileIO.MatchConfiguration
class MatchConfiguration extends Object implements Serializable -
Class org.apache.beam.sdk.io.FileIO.ReadMatches
class ReadMatches extends PTransform<PCollection<MatchResult.Metadata>,PCollection<FileIO.ReadableFile>> implements Serializable -
Class org.apache.beam.sdk.io.FileIO.Write
class Write extends PTransform<PCollection<UserT>,WriteFilesResult<DestinationT>> implements Serializable -
Class org.apache.beam.sdk.io.FileIOTest
class FileIOTest extends Object implements Serializable -
Class org.apache.beam.sdk.io.GenerateSequence
-
Class org.apache.beam.sdk.io.OffsetBasedSource
-
Serialized Fields
-
endOffset
long endOffset
-
minBundleSize
long minBundleSize
-
startOffset
long startOffset
-
-
-
Class org.apache.beam.sdk.io.Read.Bounded
-
Serialized Fields
-
source
BoundedSource<T> source
-
-
-
Class org.apache.beam.sdk.io.Read.Unbounded
-
Serialized Fields
-
source
UnboundedSource<T,
UnboundedSource.CheckpointMark> source
-
-
-
Class org.apache.beam.sdk.io.ReadableFileCoder
-
Serialized Fields
-
metadataCoder
Coder<MatchResult.Metadata> metadataCoder
-
-
-
Class org.apache.beam.sdk.io.ReadAllViaFileBasedSource
class ReadAllViaFileBasedSource extends ReadAllViaFileBasedSourceTransform<T,T> implements Serializable -
Class org.apache.beam.sdk.io.ReadAllViaFileBasedSource.ReadFileRangesFnExceptionHandler
class ReadFileRangesFnExceptionHandler extends Object implements Serializable -
Class org.apache.beam.sdk.io.ReadAllViaFileBasedSourceTransform
class ReadAllViaFileBasedSourceTransform extends PTransform<PCollection<FileIO.ReadableFile>,PCollection<T>> implements Serializable -
Serialized Fields
-
coder
Coder<T> coder
-
createSource
SerializableFunction<String,
? extends FileBasedSource<InT>> createSource -
desiredBundleSizeBytes
long desiredBundleSizeBytes
-
exceptionHandler
ReadAllViaFileBasedSource.ReadFileRangesFnExceptionHandler exceptionHandler
-
usesReshuffle
boolean usesReshuffle
-
-
-
Class org.apache.beam.sdk.io.ReadAllViaFileBasedSourceTransform.AbstractReadFileRangesFn
class AbstractReadFileRangesFn extends DoFn<KV<FileIO.ReadableFile,OffsetRange>, T> implements Serializable -
Serialized Fields
-
createSource
SerializableFunction<String,
? extends FileBasedSource<InT>> createSource -
exceptionHandler
ReadAllViaFileBasedSource.ReadFileRangesFnExceptionHandler exceptionHandler
-
-
-
Class org.apache.beam.sdk.io.ReadAllViaFileBasedSourceTransform.SplitIntoRangesFn
class SplitIntoRangesFn extends DoFn<FileIO.ReadableFile,KV<FileIO.ReadableFile, OffsetRange>> implements Serializable -
Serialized Fields
-
desiredBundleSizeBytes
long desiredBundleSizeBytes
-
-
-
Class org.apache.beam.sdk.io.ReadAllViaFileBasedSourceWithFilename
class ReadAllViaFileBasedSourceWithFilename extends ReadAllViaFileBasedSourceTransform<T,KV<String, T>> implements Serializable -
Class org.apache.beam.sdk.io.ReadTest
class ReadTest extends Object implements Serializable -
Class org.apache.beam.sdk.io.Source
class Source extends Object implements Serializable -
Class org.apache.beam.sdk.io.TextIO.Read
-
Class org.apache.beam.sdk.io.TextIO.ReadAll
-
Class org.apache.beam.sdk.io.TextIO.ReadFiles
class ReadFiles extends PTransform<PCollection<FileIO.ReadableFile>,PCollection<String>> implements Serializable -
Class org.apache.beam.sdk.io.TextIO.Sink
class Sink extends Object implements Serializable -
Class org.apache.beam.sdk.io.TextIO.TypedWrite
class TypedWrite extends PTransform<PCollection<UserT>,WriteFilesResult<DestinationT>> implements Serializable -
Class org.apache.beam.sdk.io.TextIO.Write
-
Serialized Fields
-
inner
TextIO.TypedWrite<String,
?> inner
-
-
-
Class org.apache.beam.sdk.io.TextIOWriteTest.UserWriteTypeCoder
class UserWriteTypeCoder extends CustomCoder<org.apache.beam.sdk.io.TextIOWriteTest.UserWriteType> implements Serializable -
Exception Class org.apache.beam.sdk.io.TextRowCountEstimator.NoEstimationException
class NoEstimationException extends Exception implements Serializable -
Class org.apache.beam.sdk.io.TextSource
-
Serialized Fields
-
delimiter
byte[] delimiter
-
skipHeaderLines
int skipHeaderLines
-
-
-
Class org.apache.beam.sdk.io.TFRecordIO.Read
-
Class org.apache.beam.sdk.io.TFRecordIO.ReadFiles
class ReadFiles extends PTransform<PCollection<FileIO.ReadableFile>,PCollection<byte[]>> implements Serializable -
Class org.apache.beam.sdk.io.TFRecordIO.Sink
class Sink extends Object implements Serializable -
Class org.apache.beam.sdk.io.TFRecordIO.Write
-
Class org.apache.beam.sdk.io.TFRecordReadSchemaTransformConfiguration
class TFRecordReadSchemaTransformConfiguration extends Object implements Serializable -
Class org.apache.beam.sdk.io.TFRecordReadSchemaTransformProvider.ErrorFn
class ErrorFn extends DoFn<byte[],Row> implements Serializable -
Serialized Fields
-
errorCounter
Counter errorCounter
-
errorSchema
Schema errorSchema
-
errorsInBundle
Long errorsInBundle
-
handleErrors
boolean handleErrors
-
valueMapper
SerializableFunction<byte[],
Row> valueMapper
-
-
-
Class org.apache.beam.sdk.io.TFRecordWriteSchemaTransformProvider.ErrorFn
-
Serialized Fields
-
errorCounter
Counter errorCounter
-
errorSchema
Schema errorSchema
-
errorsInBundle
Long errorsInBundle
-
handleErrors
boolean handleErrors
-
toBytesFn
SerializableFunction<Row,
byte[]> toBytesFn
-
-
-
Class org.apache.beam.sdk.io.UnboundedSource
-
Class org.apache.beam.sdk.io.WriteFiles
class WriteFiles extends PTransform<PCollection<UserT>,WriteFilesResult<DestinationT>> implements Serializable -
Serialized Fields
-
writeOperation
@Nullable FileBasedSink.WriteOperation<DestinationT,
OutputT> writeOperation
-
-
-
-
Package org.apache.beam.sdk.io.amqp
-
Class org.apache.beam.sdk.io.amqp.AmqpIO.Read
class Read extends PTransform<PBegin,PCollection<org.apache.qpid.proton.message.Message>> implements Serializable -
Class org.apache.beam.sdk.io.amqp.AmqpIO.Write
class Write extends PTransform<PCollection<org.apache.qpid.proton.message.Message>,PDone> implements Serializable -
Class org.apache.beam.sdk.io.amqp.AmqpMessageCoder
class AmqpMessageCoder extends CustomCoder<org.apache.qpid.proton.message.Message> implements Serializable
-
-
Package org.apache.beam.sdk.io.aws2.common
-
Class org.apache.beam.sdk.io.aws2.common.ClientBuilderFactory.DefaultClientBuilder
class DefaultClientBuilder extends Object implements Serializable -
Class org.apache.beam.sdk.io.aws2.common.ClientConfiguration
class ClientConfiguration extends Object implements Serializable -
Class org.apache.beam.sdk.io.aws2.common.HttpClientConfiguration
class HttpClientConfiguration extends Object implements Serializable -
Class org.apache.beam.sdk.io.aws2.common.RetryConfiguration
class RetryConfiguration extends Object implements Serializable
-
-
Package org.apache.beam.sdk.io.aws2.dynamodb
-
Package org.apache.beam.sdk.io.aws2.kinesis
-
Exception Class org.apache.beam.sdk.io.aws2.kinesis.KinesisClientThrottledException
class KinesisClientThrottledException extends org.apache.beam.sdk.io.aws2.kinesis.TransientKinesisException implements Serializable -
Class org.apache.beam.sdk.io.aws2.kinesis.KinesisIO.Read
- serialVersionUID:
- 1L
-
Class org.apache.beam.sdk.io.aws2.kinesis.KinesisIO.RecordAggregation
class RecordAggregation extends Object implements Serializable -
Class org.apache.beam.sdk.io.aws2.kinesis.KinesisIO.Write
-
Class org.apache.beam.sdk.io.aws2.kinesis.KinesisTransformRegistrar.KinesisReadToBytes
-
Serialized Fields
-
readTransform
KinesisIO.Read readTransform
-
-
-
Class org.apache.beam.sdk.io.aws2.kinesis.WatermarkParameters
class WatermarkParameters extends Object implements Serializable -
Class org.apache.beam.sdk.io.aws2.kinesis.WatermarkPolicyFactory.ArrivalTimeWatermarkPolicy
class ArrivalTimeWatermarkPolicy extends Object implements Serializable-
Serialized Fields
-
watermarkPolicy
WatermarkPolicyFactory.CustomWatermarkPolicy watermarkPolicy
-
-
-
Class org.apache.beam.sdk.io.aws2.kinesis.WatermarkPolicyFactory.CustomWatermarkPolicy
class CustomWatermarkPolicy extends Object implements Serializable-
Serialized Fields
-
watermarkParameters
WatermarkParameters watermarkParameters
-
-
-
Class org.apache.beam.sdk.io.aws2.kinesis.WatermarkPolicyFactory.ProcessingTimeWatermarkPolicy
class ProcessingTimeWatermarkPolicy extends Object implements Serializable
-
-
Package org.apache.beam.sdk.io.aws2.options
-
Class org.apache.beam.sdk.io.aws2.options.AwsModule
class AwsModule extends SimpleModule implements Serializable
-
-
Package org.apache.beam.sdk.io.aws2.schemas
-
Class org.apache.beam.sdk.io.aws2.schemas.AwsBuilderFactory
class AwsBuilderFactory extends Object implements Serializable -
Class org.apache.beam.sdk.io.aws2.schemas.AwsSchemaProvider
class AwsSchemaProvider extends GetterBasedSchemaProviderV2 implements Serializable
-
-
Package org.apache.beam.sdk.io.aws2.sns
-
Package org.apache.beam.sdk.io.aws2.sqs
-
Class org.apache.beam.sdk.io.aws2.sqs.SqsIO.Read
-
Class org.apache.beam.sdk.io.aws2.sqs.SqsIO.Write
-
Class org.apache.beam.sdk.io.aws2.sqs.SqsIO.WriteBatches
class WriteBatches extends PTransform<PCollection<T>,SqsIO.WriteBatches.Result> implements Serializable -
Class org.apache.beam.sdk.io.aws2.sqs.SqsMessage
class SqsMessage extends Object implements Serializable
-
-
Package org.apache.beam.sdk.io.aws2.sqs.providers
-
Class org.apache.beam.sdk.io.aws2.sqs.providers.SqsReadSchemaTransformProvider.SqsMessageToBeamRow
class SqsMessageToBeamRow extends Object implements Serializable
-
-
Package org.apache.beam.sdk.io.azure.cosmos
-
Class org.apache.beam.sdk.io.azure.cosmos.CosmosIO.BoundedCosmosBDSource
-
Serialized Fields
-
estimatedByteSize
@Nullable Long estimatedByteSize
-
range
NormalizedRange range
-
spec
CosmosIO.Read<T> spec
-
-
-
Class org.apache.beam.sdk.io.azure.cosmos.CosmosIO.Read
-
Class org.apache.beam.sdk.io.azure.cosmos.NormalizedRange
class NormalizedRange extends Object implements Serializable
-
-
Package org.apache.beam.sdk.io.azure.options
-
Class org.apache.beam.sdk.io.azure.options.AzureModule
class AzureModule extends SimpleModule implements Serializable
-
-
Package org.apache.beam.sdk.io.cassandra
-
Class org.apache.beam.sdk.io.cassandra.CassandraIO.Read
-
Class org.apache.beam.sdk.io.cassandra.CassandraIO.ReadAll
class ReadAll extends PTransform<PCollection<CassandraIO.Read<T>>,PCollection<T>> implements Serializable -
Class org.apache.beam.sdk.io.cassandra.CassandraIO.Write
-
Class org.apache.beam.sdk.io.cassandra.RingRange
class RingRange extends Object implements Serializable-
Serialized Fields
-
end
BigInteger end
-
start
BigInteger start
-
-
-
-
Package org.apache.beam.sdk.io.cdap
-
Package org.apache.beam.sdk.io.clickhouse
-
Class org.apache.beam.sdk.io.clickhouse.ClickHouseIO.Write
-
Class org.apache.beam.sdk.io.clickhouse.TableSchema
class TableSchema extends Object implements Serializable -
Class org.apache.beam.sdk.io.clickhouse.TableSchema.Column
class Column extends Object implements Serializable -
Class org.apache.beam.sdk.io.clickhouse.TableSchema.ColumnType
class ColumnType extends Object implements Serializable
-
-
Package org.apache.beam.sdk.io.contextualtextio
-
Class org.apache.beam.sdk.io.contextualtextio.ContextualTextIO.Read
-
Class org.apache.beam.sdk.io.contextualtextio.ContextualTextIO.ReadFiles
class ReadFiles extends PTransform<PCollection<FileIO.ReadableFile>,PCollection<Row>> implements Serializable
-
-
Package org.apache.beam.sdk.io.csv
-
Class org.apache.beam.sdk.io.csv.CsvIO.Write
-
Class org.apache.beam.sdk.io.csv.CsvIOParse
class CsvIOParse extends PTransform<PCollection<String>,CsvIOParseResult<T>> implements Serializable -
Serialized Fields
-
errorTag
TupleTag<CsvIOParseError> errorTag
-
outputTag
TupleTag<T> outputTag
-
-
-
-
Package org.apache.beam.sdk.io.csv.providers
-
Class org.apache.beam.sdk.io.csv.providers.CsvWriteTransformProvider.CsvWriteTransform
class CsvWriteTransform extends SchemaTransform implements Serializable-
Serialized Fields
-
configuration
CsvWriteTransformProvider.CsvWriteConfiguration configuration
-
-
-
-
Package org.apache.beam.sdk.io.elasticsearch
-
Class org.apache.beam.sdk.io.elasticsearch.ElasticsearchIO.BoundedElasticsearchSource
-
Class org.apache.beam.sdk.io.elasticsearch.ElasticsearchIO.BulkIO
class BulkIO extends PTransform<PCollection<ElasticsearchIO.Document>,PCollectionTuple> implements Serializable -
Class org.apache.beam.sdk.io.elasticsearch.ElasticsearchIO.ConnectionConfiguration
class ConnectionConfiguration extends Object implements Serializable -
Class org.apache.beam.sdk.io.elasticsearch.ElasticsearchIO.DocToBulk
class DocToBulk extends PTransform<PCollection<String>,PCollection<ElasticsearchIO.Document>> implements Serializable -
Class org.apache.beam.sdk.io.elasticsearch.ElasticsearchIO.Document
class Document extends Object implements Serializable -
Class org.apache.beam.sdk.io.elasticsearch.ElasticsearchIO.DocumentCoder
-
Class org.apache.beam.sdk.io.elasticsearch.ElasticsearchIO.Read
-
Class org.apache.beam.sdk.io.elasticsearch.ElasticsearchIO.RetryConfiguration
class RetryConfiguration extends Object implements Serializable -
Class org.apache.beam.sdk.io.elasticsearch.ElasticsearchIO.Write
-
Serialized Fields
-
bulkIO
ElasticsearchIO.BulkIO bulkIO
-
docToBulk
ElasticsearchIO.DocToBulk docToBulk
-
-
-
-
Package org.apache.beam.sdk.io.fs
-
Class org.apache.beam.sdk.io.fs.MatchResult.Metadata
class Metadata extends Object implements Serializable -
Class org.apache.beam.sdk.io.fs.MetadataCoder
-
Class org.apache.beam.sdk.io.fs.MetadataCoderV2
-
Class org.apache.beam.sdk.io.fs.ResourceIdCoder
-
-
Package org.apache.beam.sdk.io.gcp.bigquery
-
Class org.apache.beam.sdk.io.gcp.bigquery.BigQueryExportReadSchemaTransformProvider.BigQueryExportSchemaTransform
class BigQueryExportSchemaTransform extends SchemaTransform implements Serializable-
Serialized Fields
-
configuration
BigQueryExportReadSchemaTransformConfiguration configuration
-
testBigQueryServices
BigQueryServices testBigQueryServices
An instance ofBigQueryServices
used for testing.
-
-
-
Class org.apache.beam.sdk.io.gcp.bigquery.BigQueryInsertErrorCoder
-
Class org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO.Read
-
Serialized Fields
-
inner
BigQueryIO.TypedRead<TableRow> inner
-
-
-
Class org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO.TypedRead
-
Class org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO.Write
-
Exception Class org.apache.beam.sdk.io.gcp.bigquery.BigQueryRowWriter.BigQueryRowSerializationException
class BigQueryRowSerializationException extends Exception implements Serializable -
Exception Class org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaRetrievalException
class BigQuerySchemaRetrievalException extends RuntimeException implements Serializable -
Class org.apache.beam.sdk.io.gcp.bigquery.BigQueryServicesImpl
class BigQueryServicesImpl extends Object implements Serializable -
Class org.apache.beam.sdk.io.gcp.bigquery.BigQueryStorageApiInsertErrorCoder
class BigQueryStorageApiInsertErrorCoder extends AtomicCoder<BigQueryStorageApiInsertError> implements Serializable -
Class org.apache.beam.sdk.io.gcp.bigquery.BigQueryStorageTableSource
class BigQueryStorageTableSource extends org.apache.beam.sdk.io.gcp.bigquery.BigQueryStorageSourceBase<T> implements Serializable-
Serialization Methods
-
readObject
- Throws:
ClassNotFoundException
IOException
-
-
Serialized Fields
-
projectionPushdownApplied
boolean projectionPushdownApplied
-
tableReferenceProvider
ValueProvider<TableReference> tableReferenceProvider
-
-
-
Class org.apache.beam.sdk.io.gcp.bigquery.BigQueryUtils.ConversionOptions
class ConversionOptions extends Object implements Serializable -
Class org.apache.beam.sdk.io.gcp.bigquery.BigQueryUtils.SchemaConversionOptions
class SchemaConversionOptions extends Object implements Serializable -
Class org.apache.beam.sdk.io.gcp.bigquery.CombineAsIterable
class CombineAsIterable extends PTransform<PCollection<T>,PCollection<Iterable<T>>> implements Serializable -
Class org.apache.beam.sdk.io.gcp.bigquery.CreateTables
class CreateTables extends PTransform<PCollection<KV<DestinationT,ElementT>>, PCollection<KV<TableDestination, ElementT>>> implements Serializable -
Serialized Fields
-
bqServices
BigQueryServices bqServices
-
createDisposition
BigQueryIO.Write.CreateDisposition createDisposition
-
dynamicDestinations
DynamicDestinations<?,
DestinationT> dynamicDestinations -
kmsKey
@Nullable String kmsKey
-
-
-
Class org.apache.beam.sdk.io.gcp.bigquery.DynamicDestinations
class DynamicDestinations extends Object implements Serializable -
Class org.apache.beam.sdk.io.gcp.bigquery.InsertRetryPolicy
class InsertRetryPolicy extends Object implements Serializable -
Class org.apache.beam.sdk.io.gcp.bigquery.PrepareWrite
class PrepareWrite extends PTransform<PCollection<InputT>,PCollection<KV<DestinationT extends @NonNull Object, OutputT>>> implements Serializable -
Serialized Fields
-
dynamicDestinations
DynamicDestinations<InputT,
DestinationT extends @NonNull Object> dynamicDestinations -
formatFunction
SerializableFunction<InputT,
OutputT> formatFunction
-
-
-
Class org.apache.beam.sdk.io.gcp.bigquery.ReifyAsIterable
class ReifyAsIterable extends PTransform<PCollection<T>,PCollection<Iterable<T>>> implements Serializable -
Class org.apache.beam.sdk.io.gcp.bigquery.RowMutation.RowMutationCoder
-
Class org.apache.beam.sdk.io.gcp.bigquery.StorageApiConvertMessages
class StorageApiConvertMessages extends PTransform<PCollection<KV<DestinationT,ElementT>>, PCollectionTuple> implements Serializable -
Serialized Fields
-
badRecordRouter
BadRecordRouter badRecordRouter
-
bqServices
BigQueryServices bqServices
-
dynamicDestinations
org.apache.beam.sdk.io.gcp.bigquery.StorageApiDynamicDestinations<ElementT,
DestinationT> dynamicDestinations -
errorCoder
Coder<BigQueryStorageApiInsertError> errorCoder
-
failedWritesTag
TupleTag<BigQueryStorageApiInsertError> failedWritesTag
-
rowMutationFn
@Nullable SerializableFunction<ElementT,
RowMutationInformation> rowMutationFn -
successCoder
Coder<KV<DestinationT,
StorageApiWritePayload>> successCoder -
successfulWritesTag
TupleTag<KV<DestinationT,
StorageApiWritePayload>> successfulWritesTag
-
-
-
Class org.apache.beam.sdk.io.gcp.bigquery.StorageApiConvertMessages.ConvertMessagesDoFn
class ConvertMessagesDoFn extends DoFn<KV<DestinationT extends @NonNull Object,ElementT>, KV<DestinationT extends @NonNull Object, StorageApiWritePayload>> implements Serializable -
Serialized Fields
-
badRecordRouter
BadRecordRouter badRecordRouter
-
bqServices
BigQueryServices bqServices
-
dynamicDestinations
org.apache.beam.sdk.io.gcp.bigquery.StorageApiDynamicDestinations<ElementT,
DestinationT extends @NonNull Object> dynamicDestinations -
elementCoder
Coder<KV<DestinationT extends @NonNull Object,
ElementT>> elementCoder -
failedWritesTag
TupleTag<BigQueryStorageApiInsertError> failedWritesTag
-
messageConverters
org.apache.beam.sdk.io.gcp.bigquery.TwoLevelMessageConverterCache<DestinationT extends @NonNull Object,
ElementT> messageConverters -
rowMutationFn
@Nullable SerializableFunction<ElementT,
RowMutationInformation> rowMutationFn -
successfulWritesTag
TupleTag<KV<DestinationT extends @NonNull Object,
StorageApiWritePayload>> successfulWritesTag
-
-
-
Class org.apache.beam.sdk.io.gcp.bigquery.StorageApiDynamicDestinationsTableRow
class StorageApiDynamicDestinationsTableRow extends org.apache.beam.sdk.io.gcp.bigquery.StorageApiDynamicDestinations<T,DestinationT extends @NonNull Object> implements Serializable -
Serialized Fields
-
autoSchemaUpdates
boolean autoSchemaUpdates
-
createDisposition
BigQueryIO.Write.CreateDisposition createDisposition
-
formatFunction
SerializableFunction<T,
TableRow> formatFunction -
formatRecordOnFailureFunction
SerializableFunction<T,
TableRow> formatRecordOnFailureFunction -
ignoreUnknownValues
boolean ignoreUnknownValues
-
usesCdc
boolean usesCdc
-
-
-
Class org.apache.beam.sdk.io.gcp.bigquery.StorageApiFlushAndFinalizeDoFn
class StorageApiFlushAndFinalizeDoFn extends DoFn<KV<String,org.apache.beam.sdk.io.gcp.bigquery.StorageApiFlushAndFinalizeDoFn.Operation>, Void> implements Serializable -
Serialized Fields
-
bqServices
BigQueryServices bqServices
-
finalizeOperationsFailed
Counter finalizeOperationsFailed
-
finalizeOperationsSent
Counter finalizeOperationsSent
-
finalizeOperationsSucceeded
Counter finalizeOperationsSucceeded
-
flushLatencyDistribution
Distribution flushLatencyDistribution
-
flushOperationsAlreadyExists
Counter flushOperationsAlreadyExists
-
flushOperationsFailed
Counter flushOperationsFailed
-
flushOperationsInvalidArgument
Counter flushOperationsInvalidArgument
-
flushOperationsOffsetBeyondEnd
Counter flushOperationsOffsetBeyondEnd
-
flushOperationsSent
Counter flushOperationsSent
-
flushOperationsSucceeded
Counter flushOperationsSucceeded
-
-
-
Class org.apache.beam.sdk.io.gcp.bigquery.StorageApiLoads
class StorageApiLoads extends PTransform<PCollection<KV<DestinationT,ElementT>>, WriteResult> implements Serializable -
Serialized Fields
-
allowAutosharding
boolean allowAutosharding
-
allowInconsistentWrites
boolean allowInconsistentWrites
-
autoUpdateSchema
boolean autoUpdateSchema
-
badRecordErrorHandler
ErrorHandler<BadRecord,
?> badRecordErrorHandler -
badRecordRouter
BadRecordRouter badRecordRouter
-
bigLakeConfiguration
Map<String,
String> bigLakeConfiguration -
bqServices
BigQueryServices bqServices
-
createDisposition
BigQueryIO.Write.CreateDisposition createDisposition
-
defaultMissingValueInterpretation
com.google.cloud.bigquery.storage.v1.AppendRowsRequest.MissingValueInterpretation defaultMissingValueInterpretation
-
destinationCoder
Coder<DestinationT> destinationCoder
-
dynamicDestinations
org.apache.beam.sdk.io.gcp.bigquery.StorageApiDynamicDestinations<ElementT,
DestinationT> dynamicDestinations -
failedRowsTag
TupleTag<BigQueryStorageApiInsertError> failedRowsTag
-
ignoreUnknownValues
boolean ignoreUnknownValues
-
kmsKey
String kmsKey
-
numShards
int numShards
-
rowUpdateFn
SerializableFunction<ElementT,
RowMutationInformation> rowUpdateFn -
successfulConvertedRowsTag
TupleTag<KV<DestinationT,
StorageApiWritePayload>> successfulConvertedRowsTag -
successfulRowsPredicate
Predicate<String> successfulRowsPredicate
-
successfulWrittenRowsTag
TupleTag<TableRow> successfulWrittenRowsTag
-
triggeringFrequency
Duration triggeringFrequency
-
usesCdc
boolean usesCdc
-
-
-
Class org.apache.beam.sdk.io.gcp.bigquery.StorageApiWriteRecordsInconsistent
class StorageApiWriteRecordsInconsistent extends PTransform<PCollection<KV<DestinationT,StorageApiWritePayload>>, PCollectionTuple> implements Serializable -
Serialized Fields
-
autoUpdateSchema
boolean autoUpdateSchema
-
bigLakeConfiguration
Map<String,
String> bigLakeConfiguration -
bqServices
BigQueryServices bqServices
-
createDisposition
BigQueryIO.Write.CreateDisposition createDisposition
-
defaultMissingValueInterpretation
com.google.cloud.bigquery.storage.v1.AppendRowsRequest.MissingValueInterpretation defaultMissingValueInterpretation
-
dynamicDestinations
org.apache.beam.sdk.io.gcp.bigquery.StorageApiDynamicDestinations<ElementT,
DestinationT> dynamicDestinations -
failedRowsCoder
Coder<BigQueryStorageApiInsertError> failedRowsCoder
-
failedRowsTag
TupleTag<BigQueryStorageApiInsertError> failedRowsTag
-
finalizeTag
TupleTag<KV<String,
String>> finalizeTag -
ignoreUnknownValues
boolean ignoreUnknownValues
-
kmsKey
String kmsKey
-
successfulRowsCoder
Coder<TableRow> successfulRowsCoder
-
successfulRowsPredicate
Predicate<String> successfulRowsPredicate
-
successfulRowsTag
TupleTag<TableRow> successfulRowsTag
-
usesCdc
boolean usesCdc
-
-
-
Class org.apache.beam.sdk.io.gcp.bigquery.StorageApiWritesShardedRecords
class StorageApiWritesShardedRecords extends PTransform<PCollection<KV<org.apache.beam.sdk.util.ShardedKey<DestinationT extends @NonNull Object>,Iterable<StorageApiWritePayload>>>, PCollectionTuple> implements Serializable -
Serialized Fields
-
autoUpdateSchema
boolean autoUpdateSchema
-
bigLakeConfiguration
@Nullable Map<String,
String> bigLakeConfiguration -
bqServices
BigQueryServices bqServices
-
createDisposition
BigQueryIO.Write.CreateDisposition createDisposition
-
defaultMissingValueInterpretation
com.google.cloud.bigquery.storage.v1.AppendRowsRequest.MissingValueInterpretation defaultMissingValueInterpretation
-
destinationCoder
Coder<DestinationT extends @NonNull Object> destinationCoder
-
dynamicDestinations
org.apache.beam.sdk.io.gcp.bigquery.StorageApiDynamicDestinations<ElementT,
DestinationT extends @NonNull Object> dynamicDestinations -
failedRowsCoder
Coder<BigQueryStorageApiInsertError> failedRowsCoder
-
failedRowsTag
TupleTag<BigQueryStorageApiInsertError> failedRowsTag
-
flushTag
TupleTag<KV<String,
org.apache.beam.sdk.io.gcp.bigquery.StorageApiFlushAndFinalizeDoFn.Operation>> flushTag -
ignoreUnknownValues
boolean ignoreUnknownValues
-
kmsKey
String kmsKey
-
streamIdleTime
Duration streamIdleTime
-
successfulRowsPredicate
Predicate<String> successfulRowsPredicate
-
successfulRowsTag
@Nullable TupleTag<TableRow> successfulRowsTag
-
succussfulRowsCoder
Coder<TableRow> succussfulRowsCoder
-
-
-
Class org.apache.beam.sdk.io.gcp.bigquery.StorageApiWriteUnshardedRecords
class StorageApiWriteUnshardedRecords extends PTransform<PCollection<KV<DestinationT,StorageApiWritePayload>>, PCollectionTuple> implements Serializable -
Serialized Fields
-
autoUpdateSchema
boolean autoUpdateSchema
-
bigLakeConfiguration
@Nullable Map<String,
String> bigLakeConfiguration -
bqServices
BigQueryServices bqServices
-
createDisposition
BigQueryIO.Write.CreateDisposition createDisposition
-
defaultMissingValueInterpretation
com.google.cloud.bigquery.storage.v1.AppendRowsRequest.MissingValueInterpretation defaultMissingValueInterpretation
-
dynamicDestinations
org.apache.beam.sdk.io.gcp.bigquery.StorageApiDynamicDestinations<ElementT,
DestinationT> dynamicDestinations -
failedRowsCoder
Coder<BigQueryStorageApiInsertError> failedRowsCoder
-
failedRowsTag
TupleTag<BigQueryStorageApiInsertError> failedRowsTag
-
finalizeTag
TupleTag<KV<String,
String>> finalizeTag -
ignoreUnknownValues
boolean ignoreUnknownValues
-
kmsKey
@Nullable String kmsKey
-
successfulRowsCoder
Coder<TableRow> successfulRowsCoder
-
successfulRowsPredicate
Predicate<String> successfulRowsPredicate
-
successfulRowsTag
@Nullable TupleTag<TableRow> successfulRowsTag
-
usesCdc
boolean usesCdc
-
-
-
Class org.apache.beam.sdk.io.gcp.bigquery.StreamingInserts
class StreamingInserts extends PTransform<PCollection<KV<DestinationT,ElementT>>, WriteResult> implements Serializable -
Serialized Fields
-
autoSharding
boolean autoSharding
-
bigQueryServices
BigQueryServices bigQueryServices
-
createDisposition
BigQueryIO.Write.CreateDisposition createDisposition
-
deterministicRecordIdFn
@Nullable SerializableFunction<ElementT,
String> deterministicRecordIdFn -
dynamicDestinations
DynamicDestinations<?,
DestinationT> dynamicDestinations -
elementCoder
Coder<ElementT> elementCoder
-
extendedErrorInfo
boolean extendedErrorInfo
-
ignoreInsertIds
boolean ignoreInsertIds
-
ignoreUnknownValues
boolean ignoreUnknownValues
-
kmsKey
@Nullable String kmsKey
-
propagateSuccessful
boolean propagateSuccessful
-
retryPolicy
InsertRetryPolicy retryPolicy
-
skipInvalidRows
boolean skipInvalidRows
-
toFailsafeTableRow
SerializableFunction<ElementT,
TableRow> toFailsafeTableRow -
toTableRow
SerializableFunction<ElementT,
TableRow> toTableRow
-
-
-
Class org.apache.beam.sdk.io.gcp.bigquery.StreamingWriteTables
class StreamingWriteTables extends PTransform<PCollection<KV<TableDestination,ElementT>>, WriteResult> implements Serializable -
Serialized Fields
-
autoSharding
boolean autoSharding
-
bigQueryServices
BigQueryServices bigQueryServices
-
deterministicRecordIdFn
@Nullable SerializableFunction<ElementT,
String> deterministicRecordIdFn -
elementCoder
@Nullable Coder<ElementT> elementCoder
-
extendedErrorInfo
boolean extendedErrorInfo
-
ignoreInsertIds
boolean ignoreInsertIds
-
ignoreUnknownValues
boolean ignoreUnknownValues
-
propagateSuccessful
boolean propagateSuccessful
-
retryPolicy
InsertRetryPolicy retryPolicy
-
skipInvalidRows
boolean skipInvalidRows
-
toFailsafeTableRow
@Nullable SerializableFunction<ElementT,
TableRow> toFailsafeTableRow -
toTableRow
@Nullable SerializableFunction<ElementT,
TableRow> toTableRow
-
-
-
Class org.apache.beam.sdk.io.gcp.bigquery.TableDestination
class TableDestination extends Object implements Serializable- serialVersionUID:
- 1L
-
Class org.apache.beam.sdk.io.gcp.bigquery.TableDestinationCoder
-
Class org.apache.beam.sdk.io.gcp.bigquery.TableDestinationCoderV2
-
Class org.apache.beam.sdk.io.gcp.bigquery.TableDestinationCoderV3
-
Class org.apache.beam.sdk.io.gcp.bigquery.TableRowJsonCoder
-
Exception Class org.apache.beam.sdk.io.gcp.bigquery.TableRowToStorageApiProto.SchemaDoesntMatchException
class SchemaDoesntMatchException extends org.apache.beam.sdk.io.gcp.bigquery.TableRowToStorageApiProto.SchemaConversionException implements Serializable -
Exception Class org.apache.beam.sdk.io.gcp.bigquery.TableRowToStorageApiProto.SchemaTooNarrowException
class SchemaTooNarrowException extends org.apache.beam.sdk.io.gcp.bigquery.TableRowToStorageApiProto.SchemaConversionException implements Serializable -
Exception Class org.apache.beam.sdk.io.gcp.bigquery.TableRowToStorageApiProto.SingleValueConversionException
class SingleValueConversionException extends org.apache.beam.sdk.io.gcp.bigquery.TableRowToStorageApiProto.SchemaConversionException implements Serializable -
Class org.apache.beam.sdk.io.gcp.bigquery.UpdateSchemaDestination
class UpdateSchemaDestination extends DoFn<Iterable<KV<DestinationT,org.apache.beam.sdk.io.gcp.bigquery.WriteTables.Result>>, Iterable<KV<TableDestination, org.apache.beam.sdk.io.gcp.bigquery.WriteTables.Result>>> implements Serializable -
Serialized Fields
-
bqServices
BigQueryServices bqServices
-
createDisposition
BigQueryIO.Write.CreateDisposition createDisposition
-
dynamicDestinations
DynamicDestinations<?,
DestinationT> dynamicDestinations -
jobService
BigQueryServices.JobService jobService
-
kmsKey
String kmsKey
-
loadJobProjectId
ValueProvider<String> loadJobProjectId
-
maxRetryJobs
int maxRetryJobs
-
pendingJobs
Map<DestinationT,
org.apache.beam.sdk.io.gcp.bigquery.UpdateSchemaDestination.PendingJobData> pendingJobs -
schemaUpdateOptions
Set<BigQueryIO.Write.SchemaUpdateOption> schemaUpdateOptions
-
writeDisposition
BigQueryIO.Write.WriteDisposition writeDisposition
-
zeroLoadJobIdPrefixView
PCollectionView<String> zeroLoadJobIdPrefixView
-
-
-
Class org.apache.beam.sdk.io.gcp.bigquery.WriteBundlesToFiles.ResultCoder
class ResultCoder extends StructuredCoder<org.apache.beam.sdk.io.gcp.bigquery.WriteBundlesToFiles.Result<DestinationT>> implements Serializable-
Serialized Fields
-
destinationCoder
Coder<DestinationT> destinationCoder
-
-
-
Class org.apache.beam.sdk.io.gcp.bigquery.WriteRename.PendingJobData
class PendingJobData extends Object implements Serializable-
Serialized Fields
-
retryJob
org.apache.beam.sdk.io.gcp.bigquery.BigQueryHelpers.PendingJob retryJob
-
tableDestination
TableDestination tableDestination
-
tempTables
List<String> tempTables
-
window
BoundedWindow window
-
-
-
Class org.apache.beam.sdk.io.gcp.bigquery.WriteRename.TempTableCleanupFn
class TempTableCleanupFn extends DoFn<KV<TableDestination,List<String>>, TableDestination> implements Serializable -
Serialized Fields
-
bqServices
BigQueryServices bqServices
-
-
-
Class org.apache.beam.sdk.io.gcp.bigquery.WriteRename.WriteRenameFn
class WriteRenameFn extends DoFn<Iterable<KV<TableDestination,org.apache.beam.sdk.io.gcp.bigquery.WriteTables.Result>>, KV<TableDestination, List<String>>> implements Serializable -
Serialized Fields
-
bqServices
BigQueryServices bqServices
-
firstPaneCreateDisposition
BigQueryIO.Write.CreateDisposition firstPaneCreateDisposition
-
firstPaneWriteDisposition
BigQueryIO.Write.WriteDisposition firstPaneWriteDisposition
-
jobIdToken
PCollectionView<String> jobIdToken
-
kmsKey
@Nullable String kmsKey
-
loadJobProjectId
@Nullable ValueProvider<String> loadJobProjectId
-
maxRetryJobs
int maxRetryJobs
-
pendingJobs
List<org.apache.beam.sdk.io.gcp.bigquery.WriteRename.PendingJobData> pendingJobs
-
-
-
-
Package org.apache.beam.sdk.io.gcp.bigquery.providers
-
Class org.apache.beam.sdk.io.gcp.bigquery.providers.BigQueryDirectReadSchemaTransformProvider.BigQueryDirectReadSchemaTransform
class BigQueryDirectReadSchemaTransform extends SchemaTransform implements Serializable-
Serialized Fields
-
configuration
BigQueryDirectReadSchemaTransformProvider.BigQueryDirectReadSchemaTransformConfiguration configuration
-
testBigQueryServices
BigQueryServices testBigQueryServices
-
-
-
Class org.apache.beam.sdk.io.gcp.bigquery.providers.BigQueryFileLoadsSchemaTransformProvider.BigQueryFileLoadsSchemaTransform
class BigQueryFileLoadsSchemaTransform extends SchemaTransform implements Serializable-
Serialized Fields
-
configuration
BigQueryWriteConfiguration configuration
-
testBigQueryServices
BigQueryServices testBigQueryServices
An instance ofBigQueryServices
used for testing.
-
-
-
Class org.apache.beam.sdk.io.gcp.bigquery.providers.BigQueryStorageWriteApiSchemaTransformProvider.BigQueryStorageWriteApiSchemaTransform
class BigQueryStorageWriteApiSchemaTransform extends SchemaTransform implements Serializable-
Serialized Fields
-
configuration
BigQueryWriteConfiguration configuration
-
testBigQueryServices
BigQueryServices testBigQueryServices
-
-
-
Class org.apache.beam.sdk.io.gcp.bigquery.providers.BigQueryWriteSchemaTransformProvider.BigQueryWriteSchemaTransform
class BigQueryWriteSchemaTransform extends SchemaTransform implements Serializable-
Serialized Fields
-
configuration
BigQueryWriteConfiguration configuration
-
-
-
Class org.apache.beam.sdk.io.gcp.bigquery.providers.PortableBigQueryDestinations
-
-
Package org.apache.beam.sdk.io.gcp.bigtable
-
Class org.apache.beam.sdk.io.gcp.bigtable.BeamRowToBigtableMutation
class BeamRowToBigtableMutation extends PTransform<PCollection<Row>,PCollection<KV<ByteString, Iterable<com.google.bigtable.v2.Mutation>>>> implements Serializable -
Class org.apache.beam.sdk.io.gcp.bigtable.BeamRowToBigtableMutation.ToBigtableRowFn
class ToBigtableRowFn extends SimpleFunction<Row,KV<ByteString, Iterable<com.google.bigtable.v2.Mutation>>> implements Serializable -
Class org.apache.beam.sdk.io.gcp.bigtable.BigtableConfig
class BigtableConfig extends Object implements Serializable -
Class org.apache.beam.sdk.io.gcp.bigtable.BigtableIO.Read
class Read extends PTransform<PBegin,PCollection<com.google.bigtable.v2.Row>> implements Serializable -
Class org.apache.beam.sdk.io.gcp.bigtable.BigtableIO.ReadChangeStream
class ReadChangeStream extends PTransform<PBegin,PCollection<KV<ByteString, com.google.cloud.bigtable.data.v2.models.ChangeStreamMutation>>> implements Serializable -
Class org.apache.beam.sdk.io.gcp.bigtable.BigtableIO.Write
class Write extends PTransform<PCollection<KV<ByteString,Iterable<com.google.bigtable.v2.Mutation>>>, PDone> implements Serializable -
Class org.apache.beam.sdk.io.gcp.bigtable.BigtableIO.WriteWithResults
class WriteWithResults extends PTransform<PCollection<KV<ByteString,Iterable<com.google.bigtable.v2.Mutation>>>, PCollection<BigtableWriteResult>> implements Serializable -
Serialized Fields
-
badRecordErrorHandler
ErrorHandler<BadRecord,
?> badRecordErrorHandler -
badRecordRouter
BadRecordRouter badRecordRouter
-
bigtableConfig
BigtableConfig bigtableConfig
-
bigtableWriteOptions
org.apache.beam.sdk.io.gcp.bigtable.BigtableWriteOptions bigtableWriteOptions
-
factory
org.apache.beam.sdk.io.gcp.bigtable.BigtableServiceFactory factory
-
-
-
Class org.apache.beam.sdk.io.gcp.bigtable.BigtableReadSchemaTransformProvider.BigtableRowToBeamRow
class BigtableRowToBeamRow extends SimpleFunction<com.google.bigtable.v2.Row,Row> implements Serializable -
Class org.apache.beam.sdk.io.gcp.bigtable.BigtableRowToBeamRow
class BigtableRowToBeamRow extends PTransform<PCollection<com.google.bigtable.v2.Row>,PCollection<Row>> implements Serializable -
Serialized Fields
-
schema
Schema schema
-
-
-
Class org.apache.beam.sdk.io.gcp.bigtable.BigtableRowToBeamRowFlat
class BigtableRowToBeamRowFlat extends PTransform<PCollection<com.google.bigtable.v2.Row>,PCollection<Row>> implements Serializable -
Class org.apache.beam.sdk.io.gcp.bigtable.BigtableWriteResultCoder
-
Class org.apache.beam.sdk.io.gcp.bigtable.BigtableWriteSchemaTransformProvider.GetMutationsFromBeamRow
class GetMutationsFromBeamRow extends SimpleFunction<Row,KV<ByteString, Iterable<com.google.bigtable.v2.Mutation>>> implements Serializable
-
-
Package org.apache.beam.sdk.io.gcp.bigtable.changestreams
-
Class org.apache.beam.sdk.io.gcp.bigtable.changestreams.ChangeStreamMetrics
class ChangeStreamMetrics extends Object implements Serializable- serialVersionUID:
- 7298901109362981596L
-
-
Package org.apache.beam.sdk.io.gcp.bigtable.changestreams.action
-
Class org.apache.beam.sdk.io.gcp.bigtable.changestreams.action.ActionFactory
class ActionFactory extends Object implements Serializable- serialVersionUID:
- -6780082495458582986L
-
-
Package org.apache.beam.sdk.io.gcp.bigtable.changestreams.dao
-
Class org.apache.beam.sdk.io.gcp.bigtable.changestreams.dao.DaoFactory
class DaoFactory extends Object implements Serializable- serialVersionUID:
- -3423959768580600281L
-
Serialized Fields
-
changeStreamConfig
BigtableConfig changeStreamConfig
-
changeStreamName
String changeStreamName
-
metadataTableConfig
BigtableConfig metadataTableConfig
-
metadataTableId
String metadataTableId
-
readChangeStreamTimeout
@Nullable Duration readChangeStreamTimeout
-
tableId
String tableId
-
-
-
Package org.apache.beam.sdk.io.gcp.bigtable.changestreams.dofn
-
Class org.apache.beam.sdk.io.gcp.bigtable.changestreams.dofn.DetectNewPartitionsDoFn
class DetectNewPartitionsDoFn extends DoFn<InitialPipelineState,PartitionRecord> implements Serializable - serialVersionUID:
- 8052524268978107367L
-
Serialized Fields
-
actionFactory
ActionFactory actionFactory
-
daoFactory
DaoFactory daoFactory
-
detectNewPartitionsAction
DetectNewPartitionsAction detectNewPartitionsAction
-
endTime
Instant endTime
-
metrics
ChangeStreamMetrics metrics
-
-
Class org.apache.beam.sdk.io.gcp.bigtable.changestreams.dofn.FilterForMutationDoFn
class FilterForMutationDoFn extends DoFn<KV<ByteString,com.google.cloud.bigtable.data.v2.models.ChangeStreamRecord>, KV<ByteString, com.google.cloud.bigtable.data.v2.models.ChangeStreamMutation>> implements Serializable -
Class org.apache.beam.sdk.io.gcp.bigtable.changestreams.dofn.InitializeDoFn
class InitializeDoFn extends DoFn<byte[],InitialPipelineState> implements Serializable - serialVersionUID:
- 1868189906451252363L
-
Serialized Fields
-
daoFactory
DaoFactory daoFactory
-
existingPipelineOptions
BigtableIO.ExistingPipelineOptions existingPipelineOptions
-
startTime
Instant startTime
-
-
Class org.apache.beam.sdk.io.gcp.bigtable.changestreams.dofn.ReadChangeStreamPartitionDoFn
class ReadChangeStreamPartitionDoFn extends DoFn<PartitionRecord,KV<ByteString, com.google.cloud.bigtable.data.v2.models.ChangeStreamRecord>> implements Serializable - serialVersionUID:
- 4418739381635104479L
-
Serialized Fields
-
actionFactory
ActionFactory actionFactory
-
backlogReplicationAdjustment
Duration backlogReplicationAdjustment
-
clock
org.apache.beam.sdk.util.SerializableSupplier<Instant> clock
-
daoFactory
DaoFactory daoFactory
-
metrics
ChangeStreamMetrics metrics
-
readChangeStreamPartitionAction
ReadChangeStreamPartitionAction readChangeStreamPartitionAction
-
sizeEstimator
SizeEstimator<KV<ByteString,
com.google.cloud.bigtable.data.v2.models.ChangeStreamRecord>> sizeEstimator
-
-
-
Package org.apache.beam.sdk.io.gcp.bigtable.changestreams.estimator
-
Class org.apache.beam.sdk.io.gcp.bigtable.changestreams.estimator.CoderSizeEstimator
class CoderSizeEstimator extends Object implements Serializable- serialVersionUID:
- 5564948506493524158L
-
Exception Class org.apache.beam.sdk.io.gcp.bigtable.changestreams.estimator.EncodingException
class EncodingException extends RuntimeException implements Serializable
-
-
Package org.apache.beam.sdk.io.gcp.bigtable.changestreams.model
-
Class org.apache.beam.sdk.io.gcp.bigtable.changestreams.model.DetectNewPartitionsState
class DetectNewPartitionsState extends Object implements Serializable- serialVersionUID:
- 6587699311321738060L
-
Class org.apache.beam.sdk.io.gcp.bigtable.changestreams.model.InitialPipelineState
class InitialPipelineState extends Object implements Serializable- serialVersionUID:
- 7685843906645495071L
-
Serialized Fields
-
resume
boolean resume
-
startTime
Instant startTime
-
-
Class org.apache.beam.sdk.io.gcp.bigtable.changestreams.model.NewPartition
class NewPartition extends Object implements Serializable- serialVersionUID:
- -6530725494713332884L
-
Serialized Fields
-
Class org.apache.beam.sdk.io.gcp.bigtable.changestreams.model.PartitionRecord
class PartitionRecord extends Object implements Serializable- serialVersionUID:
- -4524061648930484599L
-
Serialized Fields
-
changeStreamContinuationTokens
List<com.google.cloud.bigtable.data.v2.models.ChangeStreamContinuationToken> changeStreamContinuationTokens
-
endTime
Instant endTime
-
parentLowWatermark
Instant parentLowWatermark
-
parentPartitions
List<NewPartition> parentPartitions
-
partition
com.google.cloud.bigtable.data.v2.models.Range.ByteStringRange partition
-
startTime
Instant startTime
-
uuid
String uuid
-
-
Class org.apache.beam.sdk.io.gcp.bigtable.changestreams.model.StreamPartitionWithWatermark
class StreamPartitionWithWatermark extends Object implements Serializable- serialVersionUID:
- -318960470803696894L
-
Serialized Fields
-
partition
com.google.cloud.bigtable.data.v2.models.Range.ByteStringRange partition
-
watermark
Instant watermark
-
-
-
Package org.apache.beam.sdk.io.gcp.bigtable.changestreams.restriction
-
Class org.apache.beam.sdk.io.gcp.bigtable.changestreams.restriction.StreamProgress
class StreamProgress extends Object implements Serializable- serialVersionUID:
- -5384329262726188695L
-
Serialized Fields
-
closeStream
@Nullable com.google.cloud.bigtable.data.v2.models.CloseStream closeStream
-
currentToken
@Nullable com.google.cloud.bigtable.data.v2.models.ChangeStreamContinuationToken currentToken
-
estimatedLowWatermark
@Nullable Instant estimatedLowWatermark
-
failToLock
boolean failToLock
-
isHeartbeat
boolean isHeartbeat
-
lastRunTimestamp
@Nullable Instant lastRunTimestamp
-
throughputEstimate
@Nullable BigDecimal throughputEstimate
-
-
-
Package org.apache.beam.sdk.io.gcp.datastore
-
Class org.apache.beam.sdk.io.gcp.datastore.DatastoreV1.DeleteEntity
class DeleteEntity extends PTransform<PCollection<com.google.datastore.v1.Entity>,PDone> implements Serializable -
Serialized Fields
-
inner
DatastoreV1.DeleteEntityWithSummary inner
-
-
-
Class org.apache.beam.sdk.io.gcp.datastore.DatastoreV1.DeleteEntityWithSummary
class DeleteEntityWithSummary extends org.apache.beam.sdk.io.gcp.datastore.DatastoreV1.Mutate<com.google.datastore.v1.Entity> implements Serializable -
Class org.apache.beam.sdk.io.gcp.datastore.DatastoreV1.DeleteKey
class DeleteKey extends PTransform<PCollection<com.google.datastore.v1.Key>,PDone> implements Serializable -
Serialized Fields
-
inner
DatastoreV1.DeleteKeyWithSummary inner
-
-
-
Class org.apache.beam.sdk.io.gcp.datastore.DatastoreV1.DeleteKeyWithSummary
class DeleteKeyWithSummary extends org.apache.beam.sdk.io.gcp.datastore.DatastoreV1.Mutate<com.google.datastore.v1.Key> implements Serializable -
Class org.apache.beam.sdk.io.gcp.datastore.DatastoreV1.Read
class Read extends PTransform<PBegin,PCollection<com.google.datastore.v1.Entity>> implements Serializable -
Class org.apache.beam.sdk.io.gcp.datastore.DatastoreV1.Write
class Write extends PTransform<PCollection<com.google.datastore.v1.Entity>,PDone> implements Serializable -
Serialized Fields
-
inner
DatastoreV1.WriteWithSummary inner
-
-
-
Class org.apache.beam.sdk.io.gcp.datastore.DatastoreV1.WriteSuccessSummary
class WriteSuccessSummary extends Object implements Serializable-
Serialized Fields
-
numBytes
long numBytes
-
numWrites
int numWrites
-
-
-
Class org.apache.beam.sdk.io.gcp.datastore.DatastoreV1.WriteWithSummary
class WriteWithSummary extends org.apache.beam.sdk.io.gcp.datastore.DatastoreV1.Mutate<com.google.datastore.v1.Entity> implements Serializable -
Class org.apache.beam.sdk.io.gcp.datastore.DataStoreV1SchemaIOProvider.DataStoreV1SchemaIO
class DataStoreV1SchemaIO extends Object implements Serializable -
Class org.apache.beam.sdk.io.gcp.datastore.EntityToRow
class EntityToRow extends PTransform<PCollection<com.google.datastore.v1.Entity>,PCollection<Row>> implements Serializable -
Class org.apache.beam.sdk.io.gcp.datastore.RampupThrottlingFn
-
Serialized Fields
-
firstInstantSideInput
PCollectionView<Instant> firstInstantSideInput
-
numWorkers
ValueProvider<Integer> numWorkers
-
throttlingMsecs
Counter throttlingMsecs
-
-
-
Class org.apache.beam.sdk.io.gcp.datastore.RowToEntity
class RowToEntity extends PTransform<PCollection<Row>,PCollection<com.google.datastore.v1.Entity>> implements Serializable
-
-
Package org.apache.beam.sdk.io.gcp.firestore
-
Class org.apache.beam.sdk.io.gcp.firestore.FirestoreV1.BatchGetDocuments
class BatchGetDocuments extends org.apache.beam.sdk.io.gcp.firestore.FirestoreV1.ReadTransform<PCollection<com.google.firestore.v1.BatchGetDocumentsRequest>,PCollection<com.google.firestore.v1.BatchGetDocumentsResponse>, FirestoreV1.BatchGetDocuments, FirestoreV1.BatchGetDocuments.Builder> implements Serializable -
Class org.apache.beam.sdk.io.gcp.firestore.FirestoreV1.BatchWriteWithDeadLetterQueue
class BatchWriteWithDeadLetterQueue extends org.apache.beam.sdk.io.gcp.firestore.FirestoreV1.Transform<PCollection<com.google.firestore.v1.Write>,PCollection<FirestoreV1.WriteFailure>, FirestoreV1.BatchWriteWithDeadLetterQueue, FirestoreV1.BatchWriteWithDeadLetterQueue.Builder> implements Serializable -
Class org.apache.beam.sdk.io.gcp.firestore.FirestoreV1.BatchWriteWithSummary
class BatchWriteWithSummary extends org.apache.beam.sdk.io.gcp.firestore.FirestoreV1.Transform<PCollection<com.google.firestore.v1.Write>,PCollection<FirestoreV1.WriteSuccessSummary>, FirestoreV1.BatchWriteWithSummary, FirestoreV1.BatchWriteWithSummary.Builder> implements Serializable -
Exception Class org.apache.beam.sdk.io.gcp.firestore.FirestoreV1.FailedWritesException
class FailedWritesException extends RuntimeException implements Serializable-
Serialized Fields
-
writeFailures
List<FirestoreV1.WriteFailure> writeFailures
-
-
-
Class org.apache.beam.sdk.io.gcp.firestore.FirestoreV1.ListCollectionIds
class ListCollectionIds extends org.apache.beam.sdk.io.gcp.firestore.FirestoreV1.ReadTransform<PCollection<com.google.firestore.v1.ListCollectionIdsRequest>,PCollection<String>, FirestoreV1.ListCollectionIds, FirestoreV1.ListCollectionIds.Builder> implements Serializable -
Class org.apache.beam.sdk.io.gcp.firestore.FirestoreV1.ListDocuments
class ListDocuments extends org.apache.beam.sdk.io.gcp.firestore.FirestoreV1.ReadTransform<PCollection<com.google.firestore.v1.ListDocumentsRequest>,PCollection<com.google.firestore.v1.Document>, FirestoreV1.ListDocuments, FirestoreV1.ListDocuments.Builder> implements Serializable -
Class org.apache.beam.sdk.io.gcp.firestore.FirestoreV1.PartitionQuery
class PartitionQuery extends org.apache.beam.sdk.io.gcp.firestore.FirestoreV1.ReadTransform<PCollection<com.google.firestore.v1.PartitionQueryRequest>,PCollection<com.google.firestore.v1.RunQueryRequest>, FirestoreV1.PartitionQuery, FirestoreV1.PartitionQuery.Builder> implements Serializable -
Serialized Fields
-
nameOnlyQuery
boolean nameOnlyQuery
-
-
-
Class org.apache.beam.sdk.io.gcp.firestore.FirestoreV1.RunQuery
class RunQuery extends org.apache.beam.sdk.io.gcp.firestore.FirestoreV1.ReadTransform<PCollection<com.google.firestore.v1.RunQueryRequest>,PCollection<com.google.firestore.v1.RunQueryResponse>, FirestoreV1.RunQuery, FirestoreV1.RunQuery.Builder> implements Serializable -
Class org.apache.beam.sdk.io.gcp.firestore.FirestoreV1.WriteFailure
class WriteFailure extends Object implements Serializable-
Serialized Fields
-
status
com.google.rpc.Status status
-
write
com.google.firestore.v1.Write write
-
writeResult
com.google.firestore.v1.WriteResult writeResult
-
-
-
Class org.apache.beam.sdk.io.gcp.firestore.FirestoreV1.WriteSuccessSummary
class WriteSuccessSummary extends Object implements Serializable-
Serialized Fields
-
numBytes
long numBytes
-
numWrites
int numWrites
-
-
-
Class org.apache.beam.sdk.io.gcp.firestore.RpcQosOptions
class RpcQosOptions extends Object implements Serializable-
Serialized Fields
-
batchInitialCount
int batchInitialCount
-
batchMaxBytes
long batchMaxBytes
-
batchMaxCount
int batchMaxCount
-
batchTargetLatency
Duration batchTargetLatency
-
hintMaxNumWorkers
int hintMaxNumWorkers
-
initialBackoff
Duration initialBackoff
-
maxAttempts
int maxAttempts
-
overloadRatio
double overloadRatio
-
samplePeriod
Duration samplePeriod
-
samplePeriodBucketSize
Duration samplePeriodBucketSize
-
shouldReportDiagnosticMetrics
boolean shouldReportDiagnosticMetrics
-
throttleDuration
Duration throttleDuration
-
-
-
-
Package org.apache.beam.sdk.io.gcp.healthcare
-
Class org.apache.beam.sdk.io.gcp.healthcare.DicomIO.ReadStudyMetadata
class ReadStudyMetadata extends PTransform<PCollection<String>,DicomIO.ReadStudyMetadata.Result> implements Serializable -
Class org.apache.beam.sdk.io.gcp.healthcare.FhirBundleParameter
class FhirBundleParameter extends Object implements Serializable -
Class org.apache.beam.sdk.io.gcp.healthcare.FhirBundleResponse
class FhirBundleResponse extends Object implements Serializable -
Class org.apache.beam.sdk.io.gcp.healthcare.FhirIO.Deidentify
-
Serialized Fields
-
deidConfig
ValueProvider<DeidentifyConfig> deidConfig
-
destinationFhirStore
ValueProvider<String> destinationFhirStore
-
sourceFhirStore
ValueProvider<String> sourceFhirStore
-
-
-
Class org.apache.beam.sdk.io.gcp.healthcare.FhirIO.Deidentify.DeidentifyFn
-
Serialized Fields
-
client
HealthcareApiClient client
-
deidConfigJson
String deidConfigJson
-
destinationFhirStore
ValueProvider<String> destinationFhirStore
-
-
-
Class org.apache.beam.sdk.io.gcp.healthcare.FhirIO.ExecuteBundles
class ExecuteBundles extends PTransform<PCollection<FhirBundleParameter>,FhirIO.ExecuteBundlesResult> implements Serializable -
Serialized Fields
-
fhirStore
ValueProvider<String> fhirStore
-
-
-
Class org.apache.beam.sdk.io.gcp.healthcare.FhirIO.Export
-
Serialized Fields
-
exportUri
ValueProvider<String> exportUri
-
fhirStore
ValueProvider<String> fhirStore
-
-
-
Class org.apache.beam.sdk.io.gcp.healthcare.FhirIO.Export.ExportResourcesFn
-
Serialized Fields
-
client
HealthcareApiClient client
-
exportUri
ValueProvider<String> exportUri
-
-
-
Class org.apache.beam.sdk.io.gcp.healthcare.FhirIO.Import
class Import extends FhirIO.Write implements Serializable-
Serialized Fields
-
contentStructure
FhirIO.Import.ContentStructure contentStructure
-
deadLetterGcsPath
ValueProvider<String> deadLetterGcsPath
-
fhirStore
ValueProvider<String> fhirStore
-
tempGcsPath
ValueProvider<String> tempGcsPath
-
-
-
Class org.apache.beam.sdk.io.gcp.healthcare.FhirIO.Read
-
Class org.apache.beam.sdk.io.gcp.healthcare.FhirIO.Search
class Search extends PTransform<PCollection<FhirSearchParameter<T>>,FhirIO.Search.Result> implements Serializable -
Serialized Fields
-
fhirStore
ValueProvider<String> fhirStore
-
-
-
Class org.apache.beam.sdk.io.gcp.healthcare.FhirIO.Write
class Write extends PTransform<PCollection<String>,FhirIO.Write.AbstractResult> implements Serializable -
Class org.apache.beam.sdk.io.gcp.healthcare.FhirIOPatientEverything
class FhirIOPatientEverything extends PTransform<PCollection<FhirIOPatientEverything.PatientEverythingParameter>,FhirIOPatientEverything.Result> implements Serializable -
Class org.apache.beam.sdk.io.gcp.healthcare.FhirIOPatientEverything.PatientEverythingParameter
class PatientEverythingParameter extends Object implements Serializable -
Class org.apache.beam.sdk.io.gcp.healthcare.FhirSearchParameterCoder
-
Serialized Fields
-
originalCoder
NullableCoder<Map<String,
T>> originalCoder
-
-
-
Class org.apache.beam.sdk.io.gcp.healthcare.HealthcareIOErrorCoder
-
Class org.apache.beam.sdk.io.gcp.healthcare.HealthcareIOErrorToTableRow
class HealthcareIOErrorToTableRow extends Object implements Serializable -
Class org.apache.beam.sdk.io.gcp.healthcare.HL7v2IO.HL7v2Read
class HL7v2Read extends PTransform<PCollection<HL7v2ReadParameter>,HL7v2IO.HL7v2Read.Result> implements Serializable -
Class org.apache.beam.sdk.io.gcp.healthcare.HL7v2IO.HL7v2Read.FetchHL7v2Message
class FetchHL7v2Message extends PTransform<PCollection<HL7v2ReadParameter>,HL7v2IO.HL7v2Read.Result> implements Serializable -
Class org.apache.beam.sdk.io.gcp.healthcare.HL7v2IO.HL7v2Read.FetchHL7v2Message.HL7v2MessageGetFn
-
Serialized Fields
-
client
org.apache.beam.sdk.io.gcp.healthcare.HL7v2IO.HL7v2MessageClient client
-
-
-
Class org.apache.beam.sdk.io.gcp.healthcare.HL7v2IO.ListHL7v2Messages
class ListHL7v2Messages extends PTransform<PBegin,PCollection<HL7v2Message>> implements Serializable -
Serialized Fields
-
filter
ValueProvider<String> filter
-
hl7v2Stores
ValueProvider<List<String>> hl7v2Stores
-
initialSplitDuration
Duration initialSplitDuration
-
-
-
Class org.apache.beam.sdk.io.gcp.healthcare.HL7v2IO.Read
-
Class org.apache.beam.sdk.io.gcp.healthcare.HL7v2IO.Read.FetchHL7v2Message
class FetchHL7v2Message extends PTransform<PCollection<String>,HL7v2IO.Read.Result> implements Serializable -
Class org.apache.beam.sdk.io.gcp.healthcare.HL7v2IO.Read.FetchHL7v2Message.HL7v2MessageGetFn
-
Serialized Fields
-
client
org.apache.beam.sdk.io.gcp.healthcare.HL7v2IO.HL7v2MessageClient client
-
-
-
Class org.apache.beam.sdk.io.gcp.healthcare.HL7v2IO.Write
class Write extends PTransform<PCollection<HL7v2Message>,HL7v2IO.Write.Result> implements Serializable -
Class org.apache.beam.sdk.io.gcp.healthcare.HL7v2MessageCoder
-
Class org.apache.beam.sdk.io.gcp.healthcare.HL7v2ReadParameter
class HL7v2ReadParameter extends Object implements Serializable -
Class org.apache.beam.sdk.io.gcp.healthcare.HL7v2ReadResponseCoder
-
Class org.apache.beam.sdk.io.gcp.healthcare.HttpHealthcareApiClient
class HttpHealthcareApiClient extends Object implements Serializable -
Exception Class org.apache.beam.sdk.io.gcp.healthcare.HttpHealthcareApiClient.HealthcareHttpException
class HealthcareHttpException extends Exception implements Serializable-
Serialized Fields
-
statusCode
int statusCode
-
-
-
Class org.apache.beam.sdk.io.gcp.healthcare.JsonArrayCoder
-
-
Package org.apache.beam.sdk.io.gcp.pubsub
-
Class org.apache.beam.sdk.io.gcp.pubsub.ExternalWrite.ParsePubsubMessageProtoAsPayloadFromWindowedValue
class ParsePubsubMessageProtoAsPayloadFromWindowedValue extends Object implements Serializable -
Class org.apache.beam.sdk.io.gcp.pubsub.PreparePubsubWriteDoFn
-
Serialized Fields
-
badRecordRouter
BadRecordRouter badRecordRouter
-
formatFunction
SerializableFunction<ValueInSingleWindow<InputT>,
PubsubMessage> formatFunction -
inputCoder
Coder<InputT> inputCoder
-
logOrderingKeyUnconfigured
boolean logOrderingKeyUnconfigured
-
maxPublishBatchSize
int maxPublishBatchSize
-
outputTag
TupleTag<PubsubMessage> outputTag
-
topicFunction
@Nullable SerializableFunction<ValueInSingleWindow<InputT>,
PubsubIO.PubsubTopic> topicFunction -
usesOrderingKey
boolean usesOrderingKey
-
-
-
Class org.apache.beam.sdk.io.gcp.pubsub.PubsubClient.IncomingMessage
class IncomingMessage extends Object implements Serializable -
Class org.apache.beam.sdk.io.gcp.pubsub.PubsubClient.OutgoingMessage
class OutgoingMessage extends Object implements Serializable -
Class org.apache.beam.sdk.io.gcp.pubsub.PubsubClient.ProjectPath
class ProjectPath extends Object implements Serializable-
Serialized Fields
-
projectId
String projectId
-
-
-
Class org.apache.beam.sdk.io.gcp.pubsub.PubsubClient.SchemaPath
class SchemaPath extends Object implements Serializable -
Class org.apache.beam.sdk.io.gcp.pubsub.PubsubClient.SubscriptionPath
class SubscriptionPath extends Object implements Serializable -
Class org.apache.beam.sdk.io.gcp.pubsub.PubsubClient.TopicPath
class TopicPath extends Object implements Serializable-
Serialized Fields
-
path
String path
-
-
-
Class org.apache.beam.sdk.io.gcp.pubsub.PubsubIO.PubsubSubscription
class PubsubSubscription extends Object implements Serializable -
Class org.apache.beam.sdk.io.gcp.pubsub.PubsubIO.PubsubTopic
class PubsubTopic extends Object implements Serializable -
Class org.apache.beam.sdk.io.gcp.pubsub.PubsubIO.Read
-
Class org.apache.beam.sdk.io.gcp.pubsub.PubsubIO.Write
-
Class org.apache.beam.sdk.io.gcp.pubsub.PubsubIO.Write.PubsubBoundedWriter
-
Serialized Fields
-
maxPublishBatchByteSize
int maxPublishBatchByteSize
-
maxPublishBatchSize
int maxPublishBatchSize
-
-
-
Class org.apache.beam.sdk.io.gcp.pubsub.PubsubMessagePayloadOnlyCoder
-
Class org.apache.beam.sdk.io.gcp.pubsub.PubsubMessages.DeserializeBytesIntoPubsubMessagePayloadOnly
class DeserializeBytesIntoPubsubMessagePayloadOnly extends Object implements Serializable -
Class org.apache.beam.sdk.io.gcp.pubsub.PubsubMessages.ParsePayloadAsPubsubMessageProto
class ParsePayloadAsPubsubMessageProto extends Object implements Serializable -
Class org.apache.beam.sdk.io.gcp.pubsub.PubsubMessages.ParsePubsubMessageProtoAsPayload
class ParsePubsubMessageProtoAsPayload extends Object implements Serializable -
Exception Class org.apache.beam.sdk.io.gcp.pubsub.PubsubMessageToRow.ParseException
class ParseException extends RuntimeException implements Serializable -
Class org.apache.beam.sdk.io.gcp.pubsub.PubsubMessageWithAttributesAndMessageIdAndOrderingKeyCoder
class PubsubMessageWithAttributesAndMessageIdAndOrderingKeyCoder extends CustomCoder<PubsubMessage> implements Serializable -
Class org.apache.beam.sdk.io.gcp.pubsub.PubsubMessageWithAttributesAndMessageIdCoder
class PubsubMessageWithAttributesAndMessageIdCoder extends CustomCoder<PubsubMessage> implements Serializable -
Class org.apache.beam.sdk.io.gcp.pubsub.PubsubMessageWithAttributesCoder
-
Class org.apache.beam.sdk.io.gcp.pubsub.PubsubMessageWithMessageIdCoder
-
Class org.apache.beam.sdk.io.gcp.pubsub.PubsubMessageWithTopicCoder
-
Class org.apache.beam.sdk.io.gcp.pubsub.PubsubTestClient
class PubsubTestClient extends PubsubClient implements Serializable -
Class org.apache.beam.sdk.io.gcp.pubsub.PubsubUnboundedSink
class PubsubUnboundedSink extends PTransform<PCollection<PubsubMessage>,PDone> implements Serializable -
Serialized Fields
-
idAttribute
@Nullable String idAttribute
Pubsub metadata field holding id for each element, or null if need to generate a unique id ourselves. -
maxLatency
Duration maxLatency
Longest delay between receiving a message and pushing it to Pubsub. -
numShards
int numShards
Number of 'shards' to use so that latency in Pubsub publish can be hidden. Generally this should be a small multiple of the number of available cores. Too smoll a number results in too much time lost to blocking Pubsub calls. To large a number results in too many single-element batches being sent to Pubsub with high per-batch overhead. -
publishBatchBytes
int publishBatchBytes
Maximum size of a publish batch, in bytes. -
publishBatchSize
int publishBatchSize
Maximum number of messages per publish. -
publishBatchWithOrderingKey
boolean publishBatchWithOrderingKey
Publish messages with an ordering key. Currently unsupported with DataflowRunner's Pubsub sink override. -
pubsubFactory
PubsubClient.PubsubClientFactory pubsubFactory
Which factory to use for creating Pubsub transport. -
pubsubRootUrl
String pubsubRootUrl
-
recordIdMethod
org.apache.beam.sdk.io.gcp.pubsub.PubsubUnboundedSink.RecordIdMethod recordIdMethod
How record ids should be generated for each record (ifPubsubUnboundedSink.idAttribute
is non- null). -
timestampAttribute
@Nullable String timestampAttribute
Pubsub metadata field holding timestamp of each element, or null if should use Pubsub message publish timestamp instead. -
topic
@Nullable ValueProvider<PubsubClient.TopicPath> topic
Pubsub topic to publish to. If null, that indicates that the PubsubMessage instead contains the topic.
-
-
-
Class org.apache.beam.sdk.io.gcp.pubsub.PubsubUnboundedSource
class PubsubUnboundedSource extends PTransform<PBegin,PCollection<PubsubMessage>> implements Serializable -
Serialized Fields
-
clock
@Nullable com.google.api.client.util.Clock clock
For testing only: Clock to use for all timekeeping. If null use system clock. -
idAttribute
@Nullable String idAttribute
Pubsub metadata field holding id for each element, or null if need to generate a unique id ourselves. -
needsAttributes
boolean needsAttributes
Whether this source should load the attributes of the PubsubMessage, or only the payload. -
needsMessageId
boolean needsMessageId
Whether this source should include the messageId from PubSub. -
needsOrderingKey
boolean needsOrderingKey
Whether this source should include the orderingKey from PubSub. -
project
@Nullable ValueProvider<PubsubClient.ProjectPath> project
Project under which to create a subscription if only thePubsubUnboundedSource.topic
was given. -
pubsubFactory
PubsubClient.PubsubClientFactory pubsubFactory
Factory for creating underlying Pubsub transport. -
subscription
@Nullable ValueProvider<PubsubClient.SubscriptionPath> subscription
Subscription to read from. If null thenPubsubUnboundedSource.topic
must be given. OtherwisePubsubUnboundedSource.topic
must be null.If no subscription is given a random one will be created when the transorm is applied. This field will be update with that subscription's path. The created subscription is never deleted.
-
timestampAttribute
@Nullable String timestampAttribute
Pubsub metadata field holding timestamp of each element, or null if should use Pubsub message publish timestamp instead. -
topic
@Nullable ValueProvider<PubsubClient.TopicPath> topic
Topic to read from. If null, thenPubsubUnboundedSource.subscription
must be given. OtherwisePubsubUnboundedSource.subscription
must be null.
-
-
-
Class org.apache.beam.sdk.io.gcp.pubsub.PubsubWriteSchemaTransformProvider.ErrorFn
-
-
Package org.apache.beam.sdk.io.gcp.pubsublite
-
Class org.apache.beam.sdk.io.gcp.pubsublite.PublisherOptions
class PublisherOptions extends Object implements Serializable- serialVersionUID:
- 275311613L
-
Class org.apache.beam.sdk.io.gcp.pubsublite.PubsubLiteReadSchemaTransformProvider.ErrorFn
class ErrorFn extends DoFn<com.google.cloud.pubsublite.proto.SequencedMessage,Row> implements Serializable -
Serialized Fields
-
-
Class org.apache.beam.sdk.io.gcp.pubsublite.PubsubLiteWriteSchemaTransformProvider.ErrorCounterFn
class ErrorCounterFn extends DoFn<Row,com.google.cloud.pubsublite.proto.PubSubMessage> implements Serializable -
Class org.apache.beam.sdk.io.gcp.pubsublite.PubsubLiteWriteSchemaTransformProvider.SetUuidFromPubSubMessage
class SetUuidFromPubSubMessage extends PTransform<PCollection<com.google.cloud.pubsublite.proto.PubSubMessage>,PCollection<com.google.cloud.pubsublite.proto.PubSubMessage>> implements Serializable -
Serialized Fields
-
attributeId
String attributeId
-
-
-
Class org.apache.beam.sdk.io.gcp.pubsublite.PubsubLiteWriteSchemaTransformProvider.SetUuidFromPubSubMessage.SetUuidFn
class SetUuidFn extends DoFn<com.google.cloud.pubsublite.proto.PubSubMessage,com.google.cloud.pubsublite.proto.PubSubMessage> implements Serializable -
Serialized Fields
-
attributeId
String attributeId
-
-
-
Class org.apache.beam.sdk.io.gcp.pubsublite.SubscriberOptions
class SubscriberOptions extends Object implements Serializable- serialVersionUID:
- 269598118L
-
Class org.apache.beam.sdk.io.gcp.pubsublite.UuidDeduplicationOptions
class UuidDeduplicationOptions extends Object implements Serializable- serialVersionUID:
- 9837489720893L
-
-
Package org.apache.beam.sdk.io.gcp.pubsublite.internal
-
Class org.apache.beam.sdk.io.gcp.pubsublite.internal.AddUuidsTransform
class AddUuidsTransform extends PTransform<PCollection<com.google.cloud.pubsublite.proto.PubSubMessage>,PCollection<com.google.cloud.pubsublite.proto.PubSubMessage>> implements Serializable -
Class org.apache.beam.sdk.io.gcp.pubsublite.internal.ManagedFactoryImpl
class ManagedFactoryImpl extends Object implements Serializable-
Serialized Fields
-
instances
Map<SubscriptionPartition,
T extends AutoCloseable> instances -
newInstance
SerializableFunction<SubscriptionPartition,
T extends AutoCloseable> newInstance
-
-
-
Class org.apache.beam.sdk.io.gcp.pubsublite.internal.OffsetByteRangeCoder
class OffsetByteRangeCoder extends AtomicCoder<org.apache.beam.sdk.io.gcp.pubsublite.internal.OffsetByteRange> implements Serializable -
Class org.apache.beam.sdk.io.gcp.pubsublite.internal.ProtoFromBytes
class ProtoFromBytes extends PTransform<PCollection<byte[]>,PCollection<T extends Message>> implements Serializable -
Class org.apache.beam.sdk.io.gcp.pubsublite.internal.ProtoToBytes
class ProtoToBytes extends PTransform<PCollection<T extends Message>,PCollection<byte[]>> implements Serializable -
Class org.apache.beam.sdk.io.gcp.pubsublite.internal.PubsubLiteSink
class PubsubLiteSink extends DoFn<com.google.cloud.pubsublite.proto.PubSubMessage,Void> implements Serializable -
Serialized Fields
-
options
PublisherOptions options
-
-
-
Class org.apache.beam.sdk.io.gcp.pubsublite.internal.SubscribeTransform
class SubscribeTransform extends PTransform<PBegin,PCollection<com.google.cloud.pubsublite.proto.SequencedMessage>> implements Serializable -
Serialized Fields
-
options
SubscriberOptions options
-
-
-
Class org.apache.beam.sdk.io.gcp.pubsublite.internal.SubscriptionPartitionCoder
-
Class org.apache.beam.sdk.io.gcp.pubsublite.internal.UnboundedSourceImpl
class UnboundedSourceImpl extends UnboundedSource<com.google.cloud.pubsublite.proto.SequencedMessage,CheckpointMarkImpl> implements Serializable -
Serialized Fields
-
partition
org.apache.beam.vendor.guava.v32_1_2_jre.com.google.common.base.Optional<com.google.cloud.pubsublite.Partition> partition
-
readerFactory
org.apache.beam.sdk.io.gcp.pubsublite.internal.UnboundedSourceImpl.BacklogReaderFactory readerFactory
-
subscriberFactory
org.apache.beam.sdk.io.gcp.pubsublite.internal.UnboundedSourceImpl.SubscriberFactory subscriberFactory
-
subscriberOptions
SubscriberOptions subscriberOptions
-
-
-
Class org.apache.beam.sdk.io.gcp.pubsublite.internal.UuidCoder
-
Class org.apache.beam.sdk.io.gcp.pubsublite.internal.UuidDeduplicationTransform
class UuidDeduplicationTransform extends PTransform<PCollection<com.google.cloud.pubsublite.proto.SequencedMessage>,PCollection<com.google.cloud.pubsublite.proto.SequencedMessage>> implements Serializable -
Serialized Fields
-
options
UuidDeduplicationOptions options
-
-
-
-
Package org.apache.beam.sdk.io.gcp.spanner
-
Class org.apache.beam.sdk.io.gcp.spanner.BatchSpannerRead.PartitionedReadOperation
class PartitionedReadOperation extends Object implements Serializable -
Class org.apache.beam.sdk.io.gcp.spanner.MutationGroup
class MutationGroup extends Object implements Serializable-
Serialized Fields
-
mutations
org.apache.beam.vendor.guava.v32_1_2_jre.com.google.common.collect.ImmutableList<Mutation> mutations
-
-
-
Class org.apache.beam.sdk.io.gcp.spanner.ReadOperation
class ReadOperation extends Object implements Serializable -
Class org.apache.beam.sdk.io.gcp.spanner.ReadSpannerSchema
-
Serialized Fields
-
allowedTableNames
Set<String> allowedTableNames
-
config
SpannerConfig config
-
dialectView
PCollectionView<Dialect> dialectView
-
-
-
Class org.apache.beam.sdk.io.gcp.spanner.SpannerConfig
class SpannerConfig extends Object implements Serializable -
Class org.apache.beam.sdk.io.gcp.spanner.SpannerIO.CreateTransaction
class CreateTransaction extends PTransform<PInput,PCollectionView<Transaction>> implements Serializable -
Class org.apache.beam.sdk.io.gcp.spanner.SpannerIO.Read
-
Class org.apache.beam.sdk.io.gcp.spanner.SpannerIO.ReadAll
class ReadAll extends PTransform<PCollection<ReadOperation>,PCollection<Struct>> implements Serializable -
Class org.apache.beam.sdk.io.gcp.spanner.SpannerIO.ReadChangeStream
class ReadChangeStream extends PTransform<PBegin,PCollection<DataChangeRecord>> implements Serializable -
Class org.apache.beam.sdk.io.gcp.spanner.SpannerIO.Write
-
Class org.apache.beam.sdk.io.gcp.spanner.SpannerIO.WriteGrouped
class WriteGrouped extends PTransform<PCollection<MutationGroup>,SpannerWriteResult> implements Serializable -
Serialized Fields
-
spec
SpannerIO.Write spec
-
-
-
Class org.apache.beam.sdk.io.gcp.spanner.SpannerReadSchemaTransformProvider.ErrorFn
-
Class org.apache.beam.sdk.io.gcp.spanner.SpannerReadSchemaTransformProvider.SpannerReadSchemaTransformConfiguration
class SpannerReadSchemaTransformConfiguration extends Object implements Serializable -
Class org.apache.beam.sdk.io.gcp.spanner.SpannerSchema
class SpannerSchema extends Object implements Serializable -
Class org.apache.beam.sdk.io.gcp.spanner.SpannerSchema.Column
class Column extends Object implements Serializable -
Class org.apache.beam.sdk.io.gcp.spanner.SpannerSchema.KeyPart
class KeyPart extends Object implements Serializable -
Exception Class org.apache.beam.sdk.io.gcp.spanner.SpannerSchemaRetrievalException
class SpannerSchemaRetrievalException extends RuntimeException implements Serializable -
Class org.apache.beam.sdk.io.gcp.spanner.SpannerWriteSchemaTransformProvider.SpannerWriteSchemaTransformConfiguration
class SpannerWriteSchemaTransformConfiguration extends Object implements Serializable -
Class org.apache.beam.sdk.io.gcp.spanner.Transaction
class Transaction extends Object implements Serializable
-
-
Package org.apache.beam.sdk.io.gcp.spanner.changestreams
-
Class org.apache.beam.sdk.io.gcp.spanner.changestreams.ChangeStreamMetrics
class ChangeStreamMetrics extends Object implements Serializable- serialVersionUID:
- 8187140831756972470L
-
Serialized Fields
-
enabledMetrics
Set<MetricName> enabledMetrics
If a metric is not within this set it will not be measured. Metrics enabled by default are described inChangeStreamMetrics
default constructor.
-
-
Class org.apache.beam.sdk.io.gcp.spanner.changestreams.SpannerChangestreamsReadSchemaTransformProvider.DataChangeRecordToRow
-
Class org.apache.beam.sdk.io.gcp.spanner.changestreams.SpannerChangestreamsReadSchemaTransformProvider.SpannerChangestreamsReadConfiguration
class SpannerChangestreamsReadConfiguration extends Object implements Serializable
-
-
Package org.apache.beam.sdk.io.gcp.spanner.changestreams.action
-
Class org.apache.beam.sdk.io.gcp.spanner.changestreams.action.ActionFactory
class ActionFactory extends Object implements Serializable- serialVersionUID:
- -4060958761369602619L
-
-
Package org.apache.beam.sdk.io.gcp.spanner.changestreams.cache
-
Class org.apache.beam.sdk.io.gcp.spanner.changestreams.cache.CacheFactory
class CacheFactory extends Object implements Serializable- serialVersionUID:
- -8722905670370252723L
-
Serialized Fields
-
cacheId
long cacheId
-
daoFactory
DaoFactory daoFactory
-
refreshRate
Duration refreshRate
-
-
-
Package org.apache.beam.sdk.io.gcp.spanner.changestreams.dao
-
Class org.apache.beam.sdk.io.gcp.spanner.changestreams.dao.DaoFactory
class DaoFactory extends Object implements Serializable- serialVersionUID:
- 7929063669009832487L
-
Serialized Fields
-
changeStreamName
String changeStreamName
-
changeStreamSpannerConfig
SpannerConfig changeStreamSpannerConfig
-
jobName
String jobName
-
metadataDatabaseDialect
Dialect metadataDatabaseDialect
-
metadataSpannerConfig
SpannerConfig metadataSpannerConfig
-
partitionMetadataTableNames
PartitionMetadataTableNames partitionMetadataTableNames
-
rpcPriority
Options.RpcPriority rpcPriority
-
spannerChangeStreamDatabaseDialect
Dialect spannerChangeStreamDatabaseDialect
-
-
Class org.apache.beam.sdk.io.gcp.spanner.changestreams.dao.PartitionMetadataTableNames
class PartitionMetadataTableNames extends Object implements Serializable- serialVersionUID:
- 8848098877671834584L
-
-
Package org.apache.beam.sdk.io.gcp.spanner.changestreams.dofn
-
Class org.apache.beam.sdk.io.gcp.spanner.changestreams.dofn.CleanUpReadChangeStreamDoFn
class CleanUpReadChangeStreamDoFn extends DoFn<byte[],Void> implements Serializable - serialVersionUID:
- -2016761780280479411L
-
Serialized Fields
-
daoFactory
DaoFactory daoFactory
-
-
Class org.apache.beam.sdk.io.gcp.spanner.changestreams.dofn.DetectNewPartitionsDoFn
class DetectNewPartitionsDoFn extends DoFn<PartitionMetadata,PartitionMetadata> implements Serializable - serialVersionUID:
- 1523712495885011374L
-
Serialized Fields
-
actionFactory
ActionFactory actionFactory
-
averagePartitionBytesSize
long averagePartitionBytesSize
-
averagePartitionBytesSizeSet
boolean averagePartitionBytesSizeSet
-
cacheFactory
CacheFactory cacheFactory
-
daoFactory
DaoFactory daoFactory
-
mapperFactory
MapperFactory mapperFactory
-
metrics
ChangeStreamMetrics metrics
-
resumeDuration
Duration resumeDuration
-
-
Class org.apache.beam.sdk.io.gcp.spanner.changestreams.dofn.InitializeDoFn
class InitializeDoFn extends DoFn<byte[],PartitionMetadata> implements Serializable - serialVersionUID:
- -8921188388649003102L
-
Serialized Fields
-
daoFactory
DaoFactory daoFactory
-
endTimestamp
com.google.cloud.Timestamp endTimestamp
-
mapperFactory
MapperFactory mapperFactory
-
startTimestamp
com.google.cloud.Timestamp startTimestamp
-
-
Class org.apache.beam.sdk.io.gcp.spanner.changestreams.dofn.PostProcessingMetricsDoFn
class PostProcessingMetricsDoFn extends DoFn<DataChangeRecord,DataChangeRecord> implements Serializable - serialVersionUID:
- -1515578871387565606L
-
Serialized Fields
-
metrics
ChangeStreamMetrics metrics
-
-
Class org.apache.beam.sdk.io.gcp.spanner.changestreams.dofn.ReadChangeStreamPartitionDoFn
class ReadChangeStreamPartitionDoFn extends DoFn<PartitionMetadata,DataChangeRecord> implements Serializable - serialVersionUID:
- -7574596218085711975L
-
Serialized Fields
-
actionFactory
ActionFactory actionFactory
-
daoFactory
DaoFactory daoFactory
-
mapperFactory
MapperFactory mapperFactory
-
metrics
ChangeStreamMetrics metrics
-
throughputEstimator
ThroughputEstimator<DataChangeRecord> throughputEstimator
Needs to be set through theReadChangeStreamPartitionDoFn.setThroughputEstimator(BytesThroughputEstimator)
call.
-
-
-
Package org.apache.beam.sdk.io.gcp.spanner.changestreams.estimator
-
Class org.apache.beam.sdk.io.gcp.spanner.changestreams.estimator.BytesThroughputEstimator
class BytesThroughputEstimator extends Object implements Serializable- serialVersionUID:
- -3597929310338724800L
-
Serialized Fields
-
deque
Deque<org.apache.beam.sdk.io.gcp.spanner.changestreams.estimator.BytesThroughputEstimator.ThroughputEntry> deque
-
sizeEstimator
SizeEstimator<T> sizeEstimator
-
windowSizeSeconds
int windowSizeSeconds
-
-
Exception Class org.apache.beam.sdk.io.gcp.spanner.changestreams.estimator.EncodingException
class EncodingException extends RuntimeException implements Serializable -
Class org.apache.beam.sdk.io.gcp.spanner.changestreams.estimator.NullThroughputEstimator
class NullThroughputEstimator extends Object implements Serializable- serialVersionUID:
- -4487552302910442742L
-
Class org.apache.beam.sdk.io.gcp.spanner.changestreams.estimator.SizeEstimator
class SizeEstimator extends Object implements Serializable- serialVersionUID:
- 8422268027457798184L
-
-
Package org.apache.beam.sdk.io.gcp.spanner.changestreams.mapper
-
Class org.apache.beam.sdk.io.gcp.spanner.changestreams.mapper.MapperFactory
class MapperFactory extends Object implements Serializable- serialVersionUID:
- -813434573067800902L
-
Serialized Fields
-
spannerChangeStreamDatabaseDialect
Dialect spannerChangeStreamDatabaseDialect
-
-
-
Package org.apache.beam.sdk.io.gcp.spanner.changestreams.model
-
Class org.apache.beam.sdk.io.gcp.spanner.changestreams.model.ChangeStreamRecordMetadata
class ChangeStreamRecordMetadata extends Object implements Serializable- serialVersionUID:
- -7294067549709034080L
-
Serialized Fields
-
numberOfRecordsRead
long numberOfRecordsRead
-
partitionCreatedAt
com.google.cloud.Timestamp partitionCreatedAt
-
partitionEndTimestamp
com.google.cloud.Timestamp partitionEndTimestamp
-
partitionRunningAt
com.google.cloud.Timestamp partitionRunningAt
-
partitionScheduledAt
com.google.cloud.Timestamp partitionScheduledAt
-
partitionStartTimestamp
com.google.cloud.Timestamp partitionStartTimestamp
-
partitionToken
String partitionToken
-
queryStartedAt
com.google.cloud.Timestamp queryStartedAt
-
recordReadAt
com.google.cloud.Timestamp recordReadAt
-
recordStreamEndedAt
com.google.cloud.Timestamp recordStreamEndedAt
-
recordStreamStartedAt
com.google.cloud.Timestamp recordStreamStartedAt
-
recordTimestamp
com.google.cloud.Timestamp recordTimestamp
-
totalStreamTimeMillis
long totalStreamTimeMillis
-
-
Class org.apache.beam.sdk.io.gcp.spanner.changestreams.model.ChildPartition
class ChildPartition extends Object implements Serializable- serialVersionUID:
- -650413326832931368L
-
Class org.apache.beam.sdk.io.gcp.spanner.changestreams.model.ChildPartitionsRecord
class ChildPartitionsRecord extends Object implements Serializable- serialVersionUID:
- 5442772555232576887L
-
Serialized Fields
-
childPartitions
List<ChildPartition> childPartitions
-
metadata
ChangeStreamRecordMetadata metadata
-
recordSequence
String recordSequence
-
startTimestamp
com.google.cloud.Timestamp startTimestamp
-
-
Class org.apache.beam.sdk.io.gcp.spanner.changestreams.model.ColumnType
class ColumnType extends Object implements Serializable- serialVersionUID:
- 6861617019875340414L
-
Class org.apache.beam.sdk.io.gcp.spanner.changestreams.model.DataChangeRecord
class DataChangeRecord extends Object implements Serializable- serialVersionUID:
- 1138762498767540898L
-
Serialized Fields
-
commitTimestamp
com.google.cloud.Timestamp commitTimestamp
-
isLastRecordInTransactionInPartition
boolean isLastRecordInTransactionInPartition
-
isSystemTransaction
boolean isSystemTransaction
-
metadata
ChangeStreamRecordMetadata metadata
-
mods
List<Mod> mods
-
modType
ModType modType
-
numberOfPartitionsInTransaction
long numberOfPartitionsInTransaction
-
numberOfRecordsInTransaction
long numberOfRecordsInTransaction
-
partitionToken
String partitionToken
-
recordSequence
String recordSequence
-
rowType
List<ColumnType> rowType
-
serverTransactionId
String serverTransactionId
-
tableName
String tableName
-
transactionTag
String transactionTag
-
valueCaptureType
ValueCaptureType valueCaptureType
-
-
Class org.apache.beam.sdk.io.gcp.spanner.changestreams.model.HeartbeatRecord
class HeartbeatRecord extends Object implements Serializable- serialVersionUID:
- 5331450064150969956L
-
Serialized Fields
-
metadata
ChangeStreamRecordMetadata metadata
-
timestamp
com.google.cloud.Timestamp timestamp
-
-
Class org.apache.beam.sdk.io.gcp.spanner.changestreams.model.Mod
class Mod extends Object implements Serializable- serialVersionUID:
- 7362322548913179939L
-
Class org.apache.beam.sdk.io.gcp.spanner.changestreams.model.PartitionEndRecord
class PartitionEndRecord extends Object implements Serializable- serialVersionUID:
- 5406538761724655621L
-
Serialized Fields
-
endTimestamp
com.google.cloud.Timestamp endTimestamp
-
metadata
ChangeStreamRecordMetadata metadata
-
recordSequence
String recordSequence
-
-
Class org.apache.beam.sdk.io.gcp.spanner.changestreams.model.PartitionEventRecord
class PartitionEventRecord extends Object implements Serializable- serialVersionUID:
- 6431436477387396791L
-
Serialized Fields
-
commitTimestamp
com.google.cloud.Timestamp commitTimestamp
-
metadata
ChangeStreamRecordMetadata metadata
-
recordSequence
String recordSequence
-
-
Class org.apache.beam.sdk.io.gcp.spanner.changestreams.model.PartitionMetadata
class PartitionMetadata extends Object implements Serializable- serialVersionUID:
- 995720273301116075L
-
Serialized Fields
-
createdAt
com.google.cloud.Timestamp createdAt
-
endTimestamp
com.google.cloud.Timestamp endTimestamp
-
finishedAt
com.google.cloud.Timestamp finishedAt
-
heartbeatMillis
long heartbeatMillis
-
parentTokens
HashSet<String> parentTokens
-
partitionToken
String partitionToken
-
runningAt
com.google.cloud.Timestamp runningAt
-
scheduledAt
com.google.cloud.Timestamp scheduledAt
-
startTimestamp
com.google.cloud.Timestamp startTimestamp
-
state
PartitionMetadata.State state
-
watermark
com.google.cloud.Timestamp watermark
-
-
Class org.apache.beam.sdk.io.gcp.spanner.changestreams.model.PartitionStartRecord
class PartitionStartRecord extends Object implements Serializable- serialVersionUID:
- 1446342293580399634L
-
Serialized Fields
-
metadata
ChangeStreamRecordMetadata metadata
-
partitionTokens
List<String> partitionTokens
-
recordSequence
String recordSequence
-
startTimestamp
com.google.cloud.Timestamp startTimestamp
-
-
Class org.apache.beam.sdk.io.gcp.spanner.changestreams.model.TypeCode
class TypeCode extends Object implements Serializable- serialVersionUID:
- -1935648338090036611L
-
Serialized Fields
-
code
String code
-
-
-
Package org.apache.beam.sdk.io.gcp.spanner.changestreams.restriction
-
Class org.apache.beam.sdk.io.gcp.spanner.changestreams.restriction.TimestampRange
class TimestampRange extends Object implements Serializable- serialVersionUID:
- -3597929310338724839L
-
Serialized Fields
-
from
com.google.cloud.Timestamp from
-
to
com.google.cloud.Timestamp to
-
-
-
Package org.apache.beam.sdk.io.gcp.testing
-
Class org.apache.beam.sdk.io.gcp.testing.BigqueryMatcher
class BigqueryMatcher extends TypeSafeMatcher<BigqueryMatcher.TableAndQuery> implements Serializable-
Serialized Fields
-
actualChecksum
String actualChecksum
-
bigqueryClient
BigqueryClient bigqueryClient
-
expectedChecksum
String expectedChecksum
-
-
-
Class org.apache.beam.sdk.io.gcp.testing.FakeBigQueryServices
class FakeBigQueryServices extends Object implements Serializable-
Serialized Fields
-
datasetService
FakeDatasetService datasetService
-
jobService
BigQueryServices.JobService jobService
-
storageClient
BigQueryServices.StorageClient storageClient
-
-
-
Class org.apache.beam.sdk.io.gcp.testing.FakeBigQueryServices.FakeBigQueryServerStream
class FakeBigQueryServerStream extends Object implements Serializable -
Class org.apache.beam.sdk.io.gcp.testing.FakeDatasetService
class FakeDatasetService extends Object implements Serializable -
Class org.apache.beam.sdk.io.gcp.testing.FakeJobService
class FakeJobService extends Object implements Serializable-
Serialized Fields
-
datasetService
FakeDatasetService datasetService
-
numFailures
int numFailures
-
numFailuresExpected
int numFailuresExpected
-
-
-
-
Package org.apache.beam.sdk.io.googleads
-
Class org.apache.beam.sdk.io.googleads.DefaultGoogleAdsClientFactory
class DefaultGoogleAdsClientFactory extends Object implements Serializable -
Class org.apache.beam.sdk.io.googleads.GoogleAdsV19.Read
class Read extends PTransform<PCollection<String>,PCollection<com.google.ads.googleads.v19.services.GoogleAdsRow>> implements Serializable -
Class org.apache.beam.sdk.io.googleads.GoogleAdsV19.ReadAll
class ReadAll extends PTransform<PCollection<com.google.ads.googleads.v19.services.SearchGoogleAdsStreamRequest>,PCollection<com.google.ads.googleads.v19.services.GoogleAdsRow>> implements Serializable
-
-
Package org.apache.beam.sdk.io.hadoop
-
Class org.apache.beam.sdk.io.hadoop.SerializableConfiguration
class SerializableConfiguration extends Object implements Externalizable- serialVersionUID:
- 0L
-
Serialization Methods
-
readExternal
- Throws:
IOException
ClassNotFoundException
-
writeExternal
- Throws:
IOException
-
-
Class org.apache.beam.sdk.io.hadoop.WritableCoder
class WritableCoder extends CustomCoder<T extends org.apache.hadoop.io.Writable> implements Serializable- serialVersionUID:
- 0L
-
-
Package org.apache.beam.sdk.io.hadoop.format
-
Class org.apache.beam.sdk.io.hadoop.format.HadoopFormatIO.HadoopInputFormatBoundedSource
-
Serialized Fields
-
boundedSourceEstimatedSize
long boundedSourceEstimatedSize
-
conf
SerializableConfiguration conf
-
inputSplit
HadoopFormatIO.SerializableSplit inputSplit
-
keyCoder
Coder<K> keyCoder
-
keyTranslationFunction
@Nullable SimpleFunction<?,
K> keyTranslationFunction -
skipKeyClone
boolean skipKeyClone
-
skipValueClone
boolean skipValueClone
-
valueCoder
Coder<V> valueCoder
-
valueTranslationFunction
@Nullable SimpleFunction<?,
V> valueTranslationFunction
-
-
-
Class org.apache.beam.sdk.io.hadoop.format.HadoopFormatIO.Read
-
Class org.apache.beam.sdk.io.hadoop.format.HadoopFormatIO.SerializableSplit
class SerializableSplit extends Object implements Serializable-
Serialization Methods
-
readObject
- Throws:
IOException
-
writeObject
- Throws:
IOException
-
-
Serialized Fields
-
inputSplit
org.apache.hadoop.mapreduce.InputSplit inputSplit
-
-
-
Class org.apache.beam.sdk.io.hadoop.format.HadoopFormatIO.Write
-
Serialized Fields
-
configTransform
@Nullable PTransform<PCollection<? extends KV<KeyT,
ValueT>>, PCollectionView<org.apache.hadoop.conf.Configuration>> configTransform -
externalSynchronization
ExternalSynchronization externalSynchronization
-
withPartitioning
boolean withPartitioning
-
-
-
Class org.apache.beam.sdk.io.hadoop.format.HDFSSynchronization
class HDFSSynchronization extends Object implements Serializable-
Serialized Fields
-
fileSystemFactory
org.apache.beam.sdk.io.hadoop.format.HDFSSynchronization.ThrowingFunction<org.apache.hadoop.conf.Configuration,
FileSystem, IOException> fileSystemFactory -
locksDir
String locksDir
-
-
-
-
Package org.apache.beam.sdk.io.hbase
-
Class org.apache.beam.sdk.io.hbase.HBaseIO.Read
class Read extends PTransform<PBegin,PCollection<org.apache.hadoop.hbase.client.Result>> implements Serializable -
Serialization Methods
-
writeReplace
The writeReplace method allows the developer to provide a replacement object that will be serialized instead of the original one. We use this to keep the enclosed class immutable. For more details on the technique see this article.
-
-
Serialized Fields
-
configuration
org.apache.hadoop.conf.Configuration configuration
-
scan
org.apache.hadoop.hbase.client.Scan scan
-
tableId
String tableId
-
-
-
Class org.apache.beam.sdk.io.hbase.HBaseIO.ReadAll
class ReadAll extends PTransform<PCollection<HBaseIO.Read>,PCollection<org.apache.hadoop.hbase.client.Result>> implements Serializable -
Class org.apache.beam.sdk.io.hbase.HBaseIO.Write
class Write extends PTransform<PCollection<org.apache.hadoop.hbase.client.Mutation>,PDone> implements Serializable -
Serialization Methods
-
writeReplace
The writeReplace method allows the developer to provide a replacement object that will be serialized instead of the original one. We use this to keep the enclosed class immutable. For more details on the technique see this article.
-
-
Serialized Fields
-
configuration
org.apache.hadoop.conf.Configuration configuration
-
tableId
String tableId
-
-
-
Class org.apache.beam.sdk.io.hbase.HBaseIO.WriteRowMutations
class WriteRowMutations extends PTransform<PCollection<KV<byte[],org.apache.hadoop.hbase.client.RowMutations>>, PDone> implements Serializable -
Serialization Methods
-
writeReplace
The writeReplace method allows the developer to provide a replacement object that will be serialized instead of the original one. We use this to keep the enclosed class immutable. For more details on the technique see this article.
-
-
Serialized Fields
-
configuration
org.apache.hadoop.conf.Configuration configuration
-
tableId
String tableId
-
-
-
-
Package org.apache.beam.sdk.io.hcatalog
-
Class org.apache.beam.sdk.io.hcatalog.HCatalogIO.Read
class Read extends PTransform<PBegin,PCollection<org.apache.hive.hcatalog.data.HCatRecord>> implements Serializable -
Class org.apache.beam.sdk.io.hcatalog.HCatalogIO.Write
class Write extends PTransform<PCollection<org.apache.hive.hcatalog.data.HCatRecord>,PDone> implements Serializable
-
-
Package org.apache.beam.sdk.io.hdfs
-
Class org.apache.beam.sdk.io.hdfs.HadoopFileSystemModule
class HadoopFileSystemModule extends SimpleModule implements Serializable
-
-
Package org.apache.beam.sdk.io.iceberg
-
Class org.apache.beam.sdk.io.iceberg.IcebergCatalogConfig
class IcebergCatalogConfig extends Object implements Serializable -
Class org.apache.beam.sdk.io.iceberg.IcebergIO.ReadRows
-
Class org.apache.beam.sdk.io.iceberg.IcebergIO.WriteRows
-
Class org.apache.beam.sdk.io.iceberg.IcebergScanConfig
class IcebergScanConfig extends Object implements Serializable -
Exception Class org.apache.beam.sdk.io.iceberg.TableAlreadyExistsException
class TableAlreadyExistsException extends RuntimeException implements Serializable
-
-
Package org.apache.beam.sdk.io.influxdb
-
Class org.apache.beam.sdk.io.influxdb.InfluxDbIO.DataSourceConfiguration
class DataSourceConfiguration extends Object implements Serializable -
Class org.apache.beam.sdk.io.influxdb.InfluxDbIO.Read
-
Class org.apache.beam.sdk.io.influxdb.InfluxDbIO.Write
-
-
Package org.apache.beam.sdk.io.jdbc
-
Class org.apache.beam.sdk.io.jdbc.JdbcIO.DataSourceConfiguration
class DataSourceConfiguration extends Object implements Serializable -
Class org.apache.beam.sdk.io.jdbc.JdbcIO.DataSourceProviderFromDataSourceConfiguration
class DataSourceProviderFromDataSourceConfiguration extends Object implements Serializable-
Serialized Fields
-
config
JdbcIO.DataSourceConfiguration config
-
-
-
Class org.apache.beam.sdk.io.jdbc.JdbcIO.DefaultRetryStrategy
class DefaultRetryStrategy extends Object implements Serializable -
Class org.apache.beam.sdk.io.jdbc.JdbcIO.PoolableDataSourceProvider
class PoolableDataSourceProvider extends Object implements Serializable-
Serialized Fields
-
config
JdbcIO.DataSourceProviderFromDataSourceConfiguration config
-
-
-
Class org.apache.beam.sdk.io.jdbc.JdbcIO.Read
-
Class org.apache.beam.sdk.io.jdbc.JdbcIO.ReadAll
class ReadAll extends PTransform<PCollection<ParameterT>,PCollection<OutputT>> implements Serializable -
Class org.apache.beam.sdk.io.jdbc.JdbcIO.ReadRows
-
Class org.apache.beam.sdk.io.jdbc.JdbcIO.ReadWithPartitions
-
Class org.apache.beam.sdk.io.jdbc.JdbcIO.RetryConfiguration
class RetryConfiguration extends Object implements Serializable -
Class org.apache.beam.sdk.io.jdbc.JdbcIO.Write
-
Serialized Fields
-
inner
JdbcIO.WriteVoid<T> inner
-
-
-
Class org.apache.beam.sdk.io.jdbc.JdbcIO.WriteVoid
-
Class org.apache.beam.sdk.io.jdbc.JdbcIO.WriteWithResults
class WriteWithResults extends PTransform<PCollection<T>,PCollection<V extends JdbcWriteResult>> implements Serializable -
Class org.apache.beam.sdk.io.jdbc.JdbcReadSchemaTransformProvider.JdbcReadSchemaTransform
class JdbcReadSchemaTransform extends SchemaTransform implements Serializable-
Serialized Fields
-
config
JdbcReadSchemaTransformProvider.JdbcReadSchemaTransformConfiguration config
-
jdbcType
String jdbcType
-
-
-
Class org.apache.beam.sdk.io.jdbc.JdbcReadSchemaTransformProvider.JdbcReadSchemaTransformConfiguration
class JdbcReadSchemaTransformConfiguration extends Object implements Serializable -
Class org.apache.beam.sdk.io.jdbc.JdbcWriteSchemaTransformProvider.JdbcWriteSchemaTransform
class JdbcWriteSchemaTransform extends SchemaTransform implements Serializable-
Serialized Fields
-
config
JdbcWriteSchemaTransformProvider.JdbcWriteSchemaTransformConfiguration config
-
jdbcType
String jdbcType
-
-
-
Class org.apache.beam.sdk.io.jdbc.JdbcWriteSchemaTransformProvider.JdbcWriteSchemaTransformConfiguration
class JdbcWriteSchemaTransformConfiguration extends Object implements Serializable -
Class org.apache.beam.sdk.io.jdbc.SchemaUtil.BeamRowMapper
class BeamRowMapper extends Object implements Serializable
-
-
Package org.apache.beam.sdk.io.jms
-
Class org.apache.beam.sdk.io.jms.DefaultAutoscaler
class DefaultAutoscaler extends Object implements Serializable -
Class org.apache.beam.sdk.io.jms.JmsIO.Read
-
Class org.apache.beam.sdk.io.jms.JmsIO.Write
-
Exception Class org.apache.beam.sdk.io.jms.JmsIOException
class JmsIOException extends RuntimeException implements Serializable -
Class org.apache.beam.sdk.io.jms.JmsRecord
class JmsRecord extends Object implements Serializable-
Serialized Fields
-
jmsCorrelationID
String jmsCorrelationID
-
jmsDeliveryMode
int jmsDeliveryMode
-
jmsDestination
javax.jms.Destination jmsDestination
-
jmsExpiration
long jmsExpiration
-
jmsMessageID
@Nullable String jmsMessageID
-
jmsPriority
int jmsPriority
-
jmsRedelivered
boolean jmsRedelivered
-
jmsReplyTo
@Nullable javax.jms.Destination jmsReplyTo
-
jmsTimestamp
long jmsTimestamp
-
jmsType
String jmsType
-
properties
Map<String,
Object> properties -
text
String text
-
-
-
Class org.apache.beam.sdk.io.jms.RetryConfiguration
class RetryConfiguration extends Object implements Serializable -
Class org.apache.beam.sdk.io.jms.TextMessageMapper
class TextMessageMapper extends Object implements Serializable
-
-
Package org.apache.beam.sdk.io.json
-
Package org.apache.beam.sdk.io.json.providers
-
Class org.apache.beam.sdk.io.json.providers.JsonWriteTransformProvider.JsonWriteTransform
class JsonWriteTransform extends SchemaTransform implements Serializable-
Serialized Fields
-
configuration
JsonWriteTransformProvider.JsonWriteConfiguration configuration
-
-
-
-
Package org.apache.beam.sdk.io.kafka
-
Class org.apache.beam.sdk.io.kafka.CheckStopReadingFnWrapper
class CheckStopReadingFnWrapper extends Object implements Serializable-
Serialized Fields
-
serializableFunction
SerializableFunction<TopicPartition,
Boolean> serializableFunction
-
-
-
Class org.apache.beam.sdk.io.kafka.ConfluentSchemaRegistryDeserializerProvider
class ConfluentSchemaRegistryDeserializerProvider extends Object implements Serializable -
Class org.apache.beam.sdk.io.kafka.KafkaCheckpointMark.PartitionMark
class PartitionMark extends Object implements Serializable-
Serialized Fields
-
nextOffset
long nextOffset
-
partition
int partition
-
topic
String topic
-
watermarkMillis
long watermarkMillis
-
-
-
Class org.apache.beam.sdk.io.kafka.KafkaCommitOffset
class KafkaCommitOffset extends PTransform<PCollection<KV<KafkaSourceDescriptor,KafkaRecord<K, V>>>, PCollection<Void>> implements Serializable -
Serialized Fields
-
readSourceDescriptors
KafkaIO.ReadSourceDescriptors<K,
V> readSourceDescriptors -
use259implementation
boolean use259implementation
-
-
-
Class org.apache.beam.sdk.io.kafka.KafkaIO.Read
-
Class org.apache.beam.sdk.io.kafka.KafkaIO.ReadSourceDescriptors
class ReadSourceDescriptors extends PTransform<PCollection<KafkaSourceDescriptor>,PCollection<KafkaRecord<K, V>>> implements Serializable -
Serialized Fields
-
records
TupleTag<KV<KafkaSourceDescriptor,
KafkaRecord<K, V>>> records
-
-
-
Class org.apache.beam.sdk.io.kafka.KafkaIO.TypedWithoutMetadata
-
Serialized Fields
-
read
KafkaIO.Read<K,
V> read
-
-
-
Class org.apache.beam.sdk.io.kafka.KafkaIO.Write
-
Class org.apache.beam.sdk.io.kafka.KafkaIO.WriteRecords
class WriteRecords extends PTransform<PCollection<ProducerRecord<K,V>>, PDone> implements Serializable -
Class org.apache.beam.sdk.io.kafka.KafkaReadSchemaTransformProvider.ErrorFn
class ErrorFn extends DoFn<byte[],Row> implements Serializable -
Serialized Fields
-
errorCounter
Counter errorCounter
-
errorSchema
Schema errorSchema
-
errorsInBundle
Long errorsInBundle
-
handleErrors
boolean handleErrors
-
valueMapper
SerializableFunction<byte[],
Row> valueMapper
-
-
-
Class org.apache.beam.sdk.io.kafka.KafkaRecordCoder
-
Class org.apache.beam.sdk.io.kafka.KafkaSourceDescriptor
class KafkaSourceDescriptor extends Object implements Serializable-
Serialized Fields
-
topicPartition
@Nullable TopicPartition topicPartition
-
-
-
Class org.apache.beam.sdk.io.kafka.KafkaWriteSchemaTransformProvider.KafkaWriteSchemaTransform.ErrorCounterFn
-
Serialized Fields
-
errorCounter
Counter errorCounter
-
errorSchema
Schema errorSchema
-
errorsInBundle
Long errorsInBundle
-
handleErrors
boolean handleErrors
-
toBytesFn
SerializableFunction<Row,
byte[]> toBytesFn
-
-
-
Class org.apache.beam.sdk.io.kafka.KafkaWriteSchemaTransformProvider.KafkaWriteSchemaTransformConfiguration
class KafkaWriteSchemaTransformConfiguration extends Object implements Serializable -
Class org.apache.beam.sdk.io.kafka.ProducerRecordCoder
-
Class org.apache.beam.sdk.io.kafka.TopicPartitionCoder
-
-
Package org.apache.beam.sdk.io.kudu
-
Package org.apache.beam.sdk.io.mongodb
-
Class org.apache.beam.sdk.io.mongodb.AggregationQuery
class AggregationQuery extends Object implements Serializable -
Class org.apache.beam.sdk.io.mongodb.FindQuery
class FindQuery extends Object implements Serializable -
Class org.apache.beam.sdk.io.mongodb.MongoDbGridFSIO.ConnectionConfiguration
class ConnectionConfiguration extends Object implements Serializable -
Class org.apache.beam.sdk.io.mongodb.MongoDbGridFSIO.Read
-
Class org.apache.beam.sdk.io.mongodb.MongoDbGridFSIO.Read.BoundedGridFSSource
-
Serialized Fields
-
objectIds
@Nullable List<ObjectId> objectIds
-
spec
MongoDbGridFSIO.Read<?> spec
-
-
-
Class org.apache.beam.sdk.io.mongodb.MongoDbGridFSIO.Write
-
Class org.apache.beam.sdk.io.mongodb.MongoDbIO.Read
-
Class org.apache.beam.sdk.io.mongodb.MongoDbIO.Write
-
Class org.apache.beam.sdk.io.mongodb.UpdateConfiguration
class UpdateConfiguration extends Object implements Serializable -
Class org.apache.beam.sdk.io.mongodb.UpdateField
class UpdateField extends Object implements Serializable
-
-
Package org.apache.beam.sdk.io.mqtt
-
Class org.apache.beam.sdk.io.mqtt.MqttIO.ConnectionConfiguration
class ConnectionConfiguration extends Object implements Serializable -
Class org.apache.beam.sdk.io.mqtt.MqttIO.Read
-
Class org.apache.beam.sdk.io.mqtt.MqttIO.Write
-
-
Package org.apache.beam.sdk.io.neo4j
-
Class org.apache.beam.sdk.io.neo4j.Neo4jIO.DriverConfiguration
class DriverConfiguration extends Object implements Serializable -
Class org.apache.beam.sdk.io.neo4j.Neo4jIO.DriverProviderFromDriverConfiguration
class DriverProviderFromDriverConfiguration extends Object implements Serializable-
Serialized Fields
-
config
Neo4jIO.DriverConfiguration config
-
-
-
Class org.apache.beam.sdk.io.neo4j.Neo4jIO.ReadAll
class ReadAll extends PTransform<PCollection<ParameterT>,PCollection<OutputT>> implements Serializable -
Class org.apache.beam.sdk.io.neo4j.Neo4jIO.WriteUnwind
-
-
Package org.apache.beam.sdk.io.parquet
-
Class org.apache.beam.sdk.io.parquet.ParquetIO.Parse
-
Class org.apache.beam.sdk.io.parquet.ParquetIO.ParseFiles
class ParseFiles extends PTransform<PCollection<FileIO.ReadableFile>,PCollection<T>> implements Serializable -
Class org.apache.beam.sdk.io.parquet.ParquetIO.Read
-
Class org.apache.beam.sdk.io.parquet.ParquetIO.ReadFiles
class ReadFiles extends PTransform<PCollection<FileIO.ReadableFile>,PCollection<GenericRecord>> implements Serializable -
Class org.apache.beam.sdk.io.parquet.ParquetIO.Sink
class Sink extends Object implements Serializable
-
-
Package org.apache.beam.sdk.io.pulsar
-
Class org.apache.beam.sdk.io.pulsar.PulsarIO.Read
-
Class org.apache.beam.sdk.io.pulsar.PulsarIO.Write
-
Class org.apache.beam.sdk.io.pulsar.PulsarMessageCoder
-
Class org.apache.beam.sdk.io.pulsar.PulsarSourceDescriptor
class PulsarSourceDescriptor extends Object implements Serializable -
Class org.apache.beam.sdk.io.pulsar.ReadFromPulsarDoFn
-
Serialized Fields
-
admin
org.apache.pulsar.client.admin.PulsarAdmin admin
-
adminUrl
String adminUrl
-
client
org.apache.pulsar.client.api.PulsarClient client
-
clientUrl
String clientUrl
-
extractOutputTimestampFn
SerializableFunction<org.apache.pulsar.client.api.Message<byte[]>,
Instant> extractOutputTimestampFn -
pulsarClientSerializableFunction
SerializableFunction<String,
org.apache.pulsar.client.api.PulsarClient> pulsarClientSerializableFunction
-
-
-
Class org.apache.beam.sdk.io.pulsar.WriteToPulsarDoFn
class WriteToPulsarDoFn extends DoFn<byte[],Void> implements Serializable
-
-
Package org.apache.beam.sdk.io.rabbitmq
-
Class org.apache.beam.sdk.io.rabbitmq.RabbitMqIO.Read
-
Class org.apache.beam.sdk.io.rabbitmq.RabbitMqIO.Write
-
Class org.apache.beam.sdk.io.rabbitmq.RabbitMqMessage
class RabbitMqMessage extends Object implements Serializable-
Serialized Fields
-
appId
@Nullable String appId
-
body
byte[] body
-
clusterId
@Nullable String clusterId
-
contentEncoding
String contentEncoding
-
contentType
String contentType
-
correlationId
@Nullable String correlationId
-
deliveryMode
Integer deliveryMode
-
expiration
String expiration
-
headers
Map<String,
Object> headers -
messageId
String messageId
-
priority
Integer priority
-
replyTo
@Nullable String replyTo
-
routingKey
@Nullable String routingKey
-
timestamp
Date timestamp
-
type
@Nullable String type
-
userId
@Nullable String userId
-
-
-
-
Package org.apache.beam.sdk.io.range
-
Class org.apache.beam.sdk.io.range.ByteKey
class ByteKey extends Object implements Serializable-
Serialized Fields
-
value
org.apache.beam.vendor.grpc.v1p69p0.com.google.protobuf.ByteString value
-
-
-
Class org.apache.beam.sdk.io.range.ByteKeyRange
class ByteKeyRange extends Object implements Serializable -
Class org.apache.beam.sdk.io.range.OffsetRange
class OffsetRange extends Object implements Serializable-
Serialized Fields
-
from
long from
-
to
long to
-
-
-
Class org.apache.beam.sdk.io.range.OffsetRange.Coder
-
-
Package org.apache.beam.sdk.io.redis
-
Class org.apache.beam.sdk.io.redis.RedisConnectionConfiguration
class RedisConnectionConfiguration extends Object implements Serializable -
Class org.apache.beam.sdk.io.redis.RedisCursor
class RedisCursor extends Object implements Serializable-
Serialized Fields
-
cursor
String cursor
-
dbSize
long dbSize
-
isStart
boolean isStart
-
-
-
Class org.apache.beam.sdk.io.redis.RedisIO.Read
-
Class org.apache.beam.sdk.io.redis.RedisIO.ReadKeyPatterns
class ReadKeyPatterns extends PTransform<PCollection<String>,PCollection<KV<String, String>>> implements Serializable -
Class org.apache.beam.sdk.io.redis.RedisIO.Write
-
Class org.apache.beam.sdk.io.redis.RedisIO.WriteStreams
class WriteStreams extends PTransform<PCollection<KV<String,Map<String, String>>>, PDone> implements Serializable
-
-
Package org.apache.beam.sdk.io.singlestore
-
Class org.apache.beam.sdk.io.singlestore.SingleStoreIO.DataSourceConfiguration
class DataSourceConfiguration extends Object implements Serializable -
Class org.apache.beam.sdk.io.singlestore.SingleStoreIO.Read
-
Exception Class org.apache.beam.sdk.io.singlestore.SingleStoreIO.Read.SingleStoreRowMapperInitializationException
class SingleStoreRowMapperInitializationException extends RuntimeException implements Serializable -
Class org.apache.beam.sdk.io.singlestore.SingleStoreIO.ReadWithPartitions
-
Class org.apache.beam.sdk.io.singlestore.SingleStoreIO.Write
-
-
Package org.apache.beam.sdk.io.snowflake
-
Class org.apache.beam.sdk.io.snowflake.SnowflakeIO.Concatenate
class Concatenate extends Combine.CombineFn<String,List<String>, List<String>> implements Serializable -
Class org.apache.beam.sdk.io.snowflake.SnowflakeIO.DataSourceConfiguration
class DataSourceConfiguration extends Object implements Serializable -
Class org.apache.beam.sdk.io.snowflake.SnowflakeIO.DataSourceProviderFromDataSourceConfiguration
class DataSourceProviderFromDataSourceConfiguration extends Object implements Serializable-
Serialized Fields
-
config
SnowflakeIO.DataSourceConfiguration config
-
-
-
Class org.apache.beam.sdk.io.snowflake.SnowflakeIO.Read
-
Class org.apache.beam.sdk.io.snowflake.SnowflakeIO.Read.CleanTmpFilesFromGcsFn
-
Serialized Fields
-
stagingBucketDir
ValueProvider<String> stagingBucketDir
-
tmpDirName
String tmpDirName
-
-
-
Class org.apache.beam.sdk.io.snowflake.SnowflakeIO.Read.MapCsvToStringArrayFn
-
Serialized Fields
-
quoteChar
ValueProvider<String> quoteChar
-
-
-
Class org.apache.beam.sdk.io.snowflake.SnowflakeIO.Write
-
-
Package org.apache.beam.sdk.io.snowflake.data
-
Class org.apache.beam.sdk.io.snowflake.data.SnowflakeColumn
class SnowflakeColumn extends Object implements Serializable-
Serialized Fields
-
dataType
SnowflakeDataType dataType
-
isNullable
boolean isNullable
-
name
String name
-
-
-
Class org.apache.beam.sdk.io.snowflake.data.SnowflakeTableSchema
class SnowflakeTableSchema extends Object implements Serializable-
Serialized Fields
-
columns
SnowflakeColumn[] columns
-
-
-
-
Package org.apache.beam.sdk.io.snowflake.data.datetime
-
Class org.apache.beam.sdk.io.snowflake.data.datetime.SnowflakeDate
class SnowflakeDate extends Object implements Serializable -
Class org.apache.beam.sdk.io.snowflake.data.datetime.SnowflakeDateTime
class SnowflakeDateTime extends SnowflakeTimestampNTZ implements Serializable -
Class org.apache.beam.sdk.io.snowflake.data.datetime.SnowflakeTime
class SnowflakeTime extends Object implements Serializable -
Class org.apache.beam.sdk.io.snowflake.data.datetime.SnowflakeTimestamp
class SnowflakeTimestamp extends SnowflakeTimestampNTZ implements Serializable -
Class org.apache.beam.sdk.io.snowflake.data.datetime.SnowflakeTimestampLTZ
class SnowflakeTimestampLTZ extends Object implements Serializable -
Class org.apache.beam.sdk.io.snowflake.data.datetime.SnowflakeTimestampNTZ
class SnowflakeTimestampNTZ extends Object implements Serializable -
Class org.apache.beam.sdk.io.snowflake.data.datetime.SnowflakeTimestampTZ
class SnowflakeTimestampTZ extends Object implements Serializable
-
-
Package org.apache.beam.sdk.io.snowflake.data.geospatial
-
Class org.apache.beam.sdk.io.snowflake.data.geospatial.SnowflakeGeography
class SnowflakeGeography extends Object implements Serializable
-
-
Package org.apache.beam.sdk.io.snowflake.data.logical
-
Class org.apache.beam.sdk.io.snowflake.data.logical.SnowflakeBoolean
class SnowflakeBoolean extends Object implements Serializable
-
-
Package org.apache.beam.sdk.io.snowflake.data.numeric
-
Class org.apache.beam.sdk.io.snowflake.data.numeric.SnowflakeDecimal
class SnowflakeDecimal extends SnowflakeNumber implements Serializable -
Class org.apache.beam.sdk.io.snowflake.data.numeric.SnowflakeDouble
class SnowflakeDouble extends SnowflakeFloat implements Serializable -
Class org.apache.beam.sdk.io.snowflake.data.numeric.SnowflakeFloat
class SnowflakeFloat extends Object implements Serializable -
Class org.apache.beam.sdk.io.snowflake.data.numeric.SnowflakeInteger
class SnowflakeInteger extends SnowflakeNumber implements Serializable -
Class org.apache.beam.sdk.io.snowflake.data.numeric.SnowflakeNumber
class SnowflakeNumber extends Object implements Serializable-
Serialized Fields
-
precision
int precision
-
scale
int scale
-
-
-
Class org.apache.beam.sdk.io.snowflake.data.numeric.SnowflakeNumeric
class SnowflakeNumeric extends SnowflakeNumber implements Serializable -
Class org.apache.beam.sdk.io.snowflake.data.numeric.SnowflakeReal
class SnowflakeReal extends SnowflakeFloat implements Serializable
-
-
Package org.apache.beam.sdk.io.snowflake.data.structured
-
Class org.apache.beam.sdk.io.snowflake.data.structured.SnowflakeArray
class SnowflakeArray extends Object implements Serializable -
Class org.apache.beam.sdk.io.snowflake.data.structured.SnowflakeObject
class SnowflakeObject extends Object implements Serializable -
Class org.apache.beam.sdk.io.snowflake.data.structured.SnowflakeVariant
class SnowflakeVariant extends Object implements Serializable
-
-
Package org.apache.beam.sdk.io.snowflake.data.text
-
Class org.apache.beam.sdk.io.snowflake.data.text.SnowflakeBinary
class SnowflakeBinary extends Object implements Serializable-
Serialized Fields
-
size
Long size
-
-
-
Class org.apache.beam.sdk.io.snowflake.data.text.SnowflakeChar
class SnowflakeChar extends SnowflakeVarchar implements Serializable -
Class org.apache.beam.sdk.io.snowflake.data.text.SnowflakeString
class SnowflakeString extends SnowflakeVarchar implements Serializable -
Class org.apache.beam.sdk.io.snowflake.data.text.SnowflakeText
class SnowflakeText extends SnowflakeVarchar implements Serializable -
Class org.apache.beam.sdk.io.snowflake.data.text.SnowflakeVarBinary
class SnowflakeVarBinary extends SnowflakeBinary implements Serializable -
Class org.apache.beam.sdk.io.snowflake.data.text.SnowflakeVarchar
class SnowflakeVarchar extends Object implements Serializable-
Serialized Fields
-
length
Long length
-
-
-
-
Package org.apache.beam.sdk.io.snowflake.services
-
Class org.apache.beam.sdk.io.snowflake.services.SnowflakeServicesImpl
class SnowflakeServicesImpl extends Object implements Serializable
-
-
Package org.apache.beam.sdk.io.solace
-
Class org.apache.beam.sdk.io.solace.RetryCallableManager
class RetryCallableManager extends Object implements Serializable -
Class org.apache.beam.sdk.io.solace.SolaceIO.Read
-
Serialized Fields
-
configurationBuilder
org.apache.beam.sdk.io.solace.SolaceIO.Read.Configuration.Builder<T> configurationBuilder
-
-
-
Class org.apache.beam.sdk.io.solace.SolaceIO.Write
-
-
Package org.apache.beam.sdk.io.solace.broker
-
Class org.apache.beam.sdk.io.solace.broker.BasicAuthJcsmpSessionServiceFactory
class BasicAuthJcsmpSessionServiceFactory extends SessionServiceFactory implements Serializable -
Class org.apache.beam.sdk.io.solace.broker.BasicAuthSempClient
class BasicAuthSempClient extends Object implements Serializable-
Serialized Fields
-
sempBasicAuthClientExecutor
SempBasicAuthClientExecutor sempBasicAuthClientExecutor
-
-
-
Class org.apache.beam.sdk.io.solace.broker.BasicAuthSempClientFactory
class BasicAuthSempClientFactory extends Object implements Serializable -
Class org.apache.beam.sdk.io.solace.broker.GCPSecretSessionServiceFactory
class GCPSecretSessionServiceFactory extends SessionServiceFactory implements Serializable -
Class org.apache.beam.sdk.io.solace.broker.JcsmpSessionService
class JcsmpSessionService extends SessionService implements Serializable-
Serialized Fields
-
publishedResultsQueue
Queue<Solace.PublishResult> publishedResultsQueue
-
retryCallableManager
RetryCallableManager retryCallableManager
-
-
-
Class org.apache.beam.sdk.io.solace.broker.SempBasicAuthClientExecutor
class SempBasicAuthClientExecutor extends Object implements Serializable-
Serialized Fields
-
baseUrl
String baseUrl
-
cookieManagerKey
org.apache.beam.sdk.io.solace.broker.SempBasicAuthClientExecutor.CookieManagerKey cookieManagerKey
-
messageVpn
String messageVpn
-
objectMapper
ObjectMapper objectMapper
-
password
String password
-
username
String username
-
-
-
Class org.apache.beam.sdk.io.solace.broker.SessionService
class SessionService extends Object implements Serializable -
Class org.apache.beam.sdk.io.solace.broker.SessionServiceFactory
class SessionServiceFactory extends Object implements Serializable-
Serialized Fields
-
queue
@Nullable Queue queue
A reference to a Queue object. This is set when the pipeline is constructed (in theSolaceIO.Read.expand(org.apache.beam.sdk.values.PBegin)
method). This could be used to associate the created SessionService with a specific queue for message handling. -
submissionMode
@Nullable SolaceIO.SubmissionMode submissionMode
The write submission mode. This is set when the writers are created. This property is used only by the write connector.
-
-
-
-
Package org.apache.beam.sdk.io.solace.read
-
Class org.apache.beam.sdk.io.solace.read.UnboundedSolaceSource
- serialVersionUID:
- 42L
-
Serialized Fields
-
coder
Coder<T> coder
-
enableDeduplication
boolean enableDeduplication
-
maxNumConnections
@Nullable Integer maxNumConnections
-
parseFn
SerializableFunction<@Nullable BytesXMLMessage,
@Nullable T> parseFn -
queue
Queue queue
-
sempClientFactory
SempClientFactory sempClientFactory
-
sessionServiceFactory
SessionServiceFactory sessionServiceFactory
-
timestampFn
SerializableFunction<T,
Instant> timestampFn -
watermarkIdleDurationThreshold
Duration watermarkIdleDurationThreshold
-
-
-
Package org.apache.beam.sdk.io.solace.write
-
Class org.apache.beam.sdk.io.solace.write.AddShardKeyDoFn
-
Serialized Fields
-
shardCount
int shardCount
-
shardKey
int shardKey
-
-
-
Class org.apache.beam.sdk.io.solace.write.RecordToPublishResultDoFn
class RecordToPublishResultDoFn extends DoFn<Solace.Record,Solace.PublishResult> implements Serializable -
Class org.apache.beam.sdk.io.solace.write.UnboundedBatchedSolaceWriter
class UnboundedBatchedSolaceWriter extends UnboundedSolaceWriter implements Serializable -
Class org.apache.beam.sdk.io.solace.write.UnboundedSolaceWriter
class UnboundedSolaceWriter extends DoFn<KV<Integer,Solace.Record>, Solace.PublishResult> implements Serializable -
Serialized Fields
-
batchToEmit
List<Solace.Record> batchToEmit
-
bundleTimestamp
@Nullable Instant bundleTimestamp
-
currentBundleProducerIndex
int currentBundleProducerIndex
-
deliveryMode
DeliveryMode deliveryMode
-
destinationFn
SerializableFunction<Solace.Record,
Destination> destinationFn -
latencyErrors
Distribution latencyErrors
-
latencyPublish
Distribution latencyPublish
-
producersMapCardinality
int producersMapCardinality
-
publishLatencyMetrics
boolean publishLatencyMetrics
-
sessionServiceFactory
SessionServiceFactory sessionServiceFactory
-
submissionMode
SolaceIO.SubmissionMode submissionMode
-
writerTransformUuid
UUID writerTransformUuid
-
-
-
Class org.apache.beam.sdk.io.solace.write.UnboundedStreamingSolaceWriter
class UnboundedStreamingSolaceWriter extends UnboundedSolaceWriter implements Serializable-
Serialized Fields
-
currentKeySpec
StateSpec<ValueState<Integer>> currentKeySpec
-
rejectedByBroker
Counter rejectedByBroker
-
sentToBroker
Counter sentToBroker
-
-
-
-
Package org.apache.beam.sdk.io.solr
-
Class org.apache.beam.sdk.io.solr.SolrIO.ConnectionConfiguration
class ConnectionConfiguration extends Object implements Serializable -
Class org.apache.beam.sdk.io.solr.SolrIO.Read
class Read extends PTransform<PBegin,PCollection<org.apache.solr.common.SolrDocument>> implements Serializable -
Class org.apache.beam.sdk.io.solr.SolrIO.ReadAll
class ReadAll extends PTransform<PCollection<SolrIO.Read>,PCollection<org.apache.solr.common.SolrDocument>> implements Serializable -
Class org.apache.beam.sdk.io.solr.SolrIO.ReplicaInfo
class ReplicaInfo extends Object implements Serializable -
Class org.apache.beam.sdk.io.solr.SolrIO.RetryConfiguration
class RetryConfiguration extends Object implements Serializable -
Class org.apache.beam.sdk.io.solr.SolrIO.Write
class Write extends PTransform<PCollection<org.apache.solr.common.SolrInputDocument>,PDone> implements Serializable
-
-
Package org.apache.beam.sdk.io.sparkreceiver
-
Class org.apache.beam.sdk.io.sparkreceiver.ReceiverBuilder
class ReceiverBuilder extends Object implements Serializable -
Class org.apache.beam.sdk.io.sparkreceiver.SparkReceiverIO.Read
-
-
Package org.apache.beam.sdk.io.splunk
-
Class org.apache.beam.sdk.io.splunk.SplunkEventCoder
-
Class org.apache.beam.sdk.io.splunk.SplunkIO.Write
class Write extends PTransform<PCollection<SplunkEvent>,PCollection<SplunkWriteError>> implements Serializable
-
-
Package org.apache.beam.sdk.io.thrift
-
Class org.apache.beam.sdk.io.thrift.ThriftCoder
-
Class org.apache.beam.sdk.io.thrift.ThriftIO.ReadFiles
class ReadFiles extends PTransform<PCollection<FileIO.ReadableFile>,PCollection<T>> implements Serializable -
Class org.apache.beam.sdk.io.thrift.ThriftIO.Sink
class Sink extends Object implements Serializable -
Class org.apache.beam.sdk.io.thrift.ThriftSchema
class ThriftSchema extends GetterBasedSchemaProviderV2 implements Serializable-
Serialized Fields
-
typedefs
Map<String,
Schema.FieldType> typedefs
-
-
-
-
Package org.apache.beam.sdk.io.tika
-
Class org.apache.beam.sdk.io.tika.ParseResult
class ParseResult extends Object implements Serializable -
Class org.apache.beam.sdk.io.tika.TikaIO.Parse
-
Class org.apache.beam.sdk.io.tika.TikaIO.ParseFiles
class ParseFiles extends PTransform<PCollection<FileIO.ReadableFile>,PCollection<ParseResult>> implements Serializable
-
-
Package org.apache.beam.sdk.io.xml
-
Class org.apache.beam.sdk.io.xml.JAXBCoder
-
Serialized Fields
-
jaxbClass
Class<T> jaxbClass
-
jaxbMarshaller
org.apache.beam.sdk.util.EmptyOnDeserializationThreadLocal<Marshaller> jaxbMarshaller
-
jaxbUnmarshaller
org.apache.beam.sdk.util.EmptyOnDeserializationThreadLocal<Unmarshaller> jaxbUnmarshaller
-
-
-
Class org.apache.beam.sdk.io.xml.XmlIO.Read
-
Class org.apache.beam.sdk.io.xml.XmlIO.ReadFiles
class ReadFiles extends PTransform<PCollection<FileIO.ReadableFile>,PCollection<T>> implements Serializable -
Class org.apache.beam.sdk.io.xml.XmlIO.Sink
class Sink extends Object implements Serializable -
Class org.apache.beam.sdk.io.xml.XmlIO.Write
-
Class org.apache.beam.sdk.io.xml.XmlSource
-
Serialized Fields
-
configuration
org.apache.beam.sdk.io.xml.XmlIO.MappingConfiguration<T> configuration
-
-
-
-
Package org.apache.beam.sdk.managed
-
Package org.apache.beam.sdk.metrics
-
Class org.apache.beam.sdk.metrics.DelegatingCounter
class DelegatingCounter extends Object implements Serializable-
Serialized Fields
-
name
MetricName name
-
perWorkerCounter
boolean perWorkerCounter
-
processWideContainer
boolean processWideContainer
-
-
-
Class org.apache.beam.sdk.metrics.DelegatingDistribution
class DelegatingDistribution extends Object implements Serializable-
Serialized Fields
-
name
MetricName name
-
processWideContainer
boolean processWideContainer
-
-
-
Class org.apache.beam.sdk.metrics.DelegatingGauge
class DelegatingGauge extends Object implements Serializable-
Serialized Fields
-
name
MetricName name
-
processWideContainer
boolean processWideContainer
-
-
-
Class org.apache.beam.sdk.metrics.DelegatingHistogram
class DelegatingHistogram extends Object implements Serializable-
Serialized Fields
-
bucketType
org.apache.beam.sdk.util.HistogramData.BucketType bucketType
-
name
MetricName name
-
processWideContainer
boolean processWideContainer
-
-
-
Class org.apache.beam.sdk.metrics.LabeledMetricNameUtilsTest
class LabeledMetricNameUtilsTest extends Object implements Serializable -
Class org.apache.beam.sdk.metrics.MetricKey
class MetricKey extends Object implements Serializable -
Class org.apache.beam.sdk.metrics.MetricName
class MetricName extends Object implements Serializable -
Class org.apache.beam.sdk.metrics.MetricsTest
class MetricsTest extends Object implements Serializable -
Class org.apache.beam.sdk.metrics.MetricsTest.AttemptedMetricTests
class AttemptedMetricTests extends org.apache.beam.sdk.metrics.MetricsTest.SharedTestBase implements Serializable -
Class org.apache.beam.sdk.metrics.MetricsTest.BasicTests
class BasicTests extends org.apache.beam.sdk.metrics.MetricsTest.SharedTestBase implements Serializable -
Class org.apache.beam.sdk.metrics.MetricsTest.CommittedMetricTests
class CommittedMetricTests extends org.apache.beam.sdk.metrics.MetricsTest.SharedTestBase implements Serializable -
Class org.apache.beam.sdk.metrics.MetricsTest.CountingSourceWithMetrics
-
Serialized Fields
-
end
int end
-
start
int start
-
-
-
Class org.apache.beam.sdk.metrics.NoOpCounter
class NoOpCounter extends Object implements Serializable -
Class org.apache.beam.sdk.metrics.NoOpHistogram
class NoOpHistogram extends Object implements Serializable
-
-
Package org.apache.beam.sdk.options
-
Class org.apache.beam.sdk.options.PipelineOptionsFactoryTest.ComplexType2Deserializer1
class ComplexType2Deserializer1 extends StdDeserializer<org.apache.beam.sdk.options.PipelineOptionsFactoryTest.ComplexType2> implements Serializable -
Class org.apache.beam.sdk.options.PipelineOptionsFactoryTest.ComplexType2Deserializer2
class ComplexType2Deserializer2 extends StdDeserializer<org.apache.beam.sdk.options.PipelineOptionsFactoryTest.ComplexType2> implements Serializable -
Class org.apache.beam.sdk.options.PipelineOptionsFactoryTest.ComplexType2Serializer1
class ComplexType2Serializer1 extends StdSerializer<org.apache.beam.sdk.options.PipelineOptionsFactoryTest.ComplexType2> implements Serializable -
Class org.apache.beam.sdk.options.PipelineOptionsFactoryTest.RegisteredTestModule
class RegisteredTestModule extends SimpleModule implements Serializable -
Class org.apache.beam.sdk.options.ProxyInvocationHandlerTest.JacksonObjectDeserializer
class JacksonObjectDeserializer extends StdDeserializer<org.apache.beam.sdk.options.ProxyInvocationHandlerTest.JacksonObject> implements Serializable -
Class org.apache.beam.sdk.options.ProxyInvocationHandlerTest.JacksonObjectSerializer
class JacksonObjectSerializer extends StdSerializer<org.apache.beam.sdk.options.ProxyInvocationHandlerTest.JacksonObject> implements Serializable -
Class org.apache.beam.sdk.options.SdkHarnessOptions.SdkHarnessLogLevelOverrides
class SdkHarnessLogLevelOverrides extends HashMap<String,SdkHarnessOptions.LogLevel> implements Serializable -
Class org.apache.beam.sdk.options.ValueProvider.NestedValueProvider
class NestedValueProvider extends Object implements Serializable-
Serialized Fields
-
translator
SerializableFunction<X,
T> translator -
value
ValueProvider<X> value
-
-
-
Class org.apache.beam.sdk.options.ValueProvider.RuntimeValueProvider
class RuntimeValueProvider extends Object implements Serializable -
Class org.apache.beam.sdk.options.ValueProvider.StaticValueProvider
class StaticValueProvider extends Object implements Serializable
-
-
Package org.apache.beam.sdk.providers
-
Class org.apache.beam.sdk.providers.GenerateSequenceSchemaTransformProvider.GenerateSequenceSchemaTransform
class GenerateSequenceSchemaTransform extends SchemaTransform implements Serializable-
Serialized Fields
-
configuration
GenerateSequenceSchemaTransformProvider.GenerateSequenceConfiguration configuration
-
-
-
-
Package org.apache.beam.sdk.schemas
-
Class org.apache.beam.sdk.schemas.AutoValueSchema
class AutoValueSchema extends GetterBasedSchemaProviderV2 implements Serializable -
Class org.apache.beam.sdk.schemas.AutoValueSchema.AbstractGetterTypeSupplier
class AbstractGetterTypeSupplier extends Object implements Serializable -
Class org.apache.beam.sdk.schemas.CachingFactory
class CachingFactory extends Object implements Serializable -
Class org.apache.beam.sdk.schemas.FieldAccessDescriptor
class FieldAccessDescriptor extends Object implements Serializable -
Class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor
class FieldDescriptor extends Object implements Serializable -
Class org.apache.beam.sdk.schemas.FieldAccessDescriptor.FieldDescriptor.Qualifier
class Qualifier extends Object implements Serializable -
Class org.apache.beam.sdk.schemas.FieldValueTypeInformation
class FieldValueTypeInformation extends Object implements Serializable -
Class org.apache.beam.sdk.schemas.GetterBasedSchemaProvider
class GetterBasedSchemaProvider extends Object implements Serializable -
Class org.apache.beam.sdk.schemas.GetterBasedSchemaProviderV2
class GetterBasedSchemaProviderV2 extends GetterBasedSchemaProvider implements Serializable -
Class org.apache.beam.sdk.schemas.JavaBeanSchema
class JavaBeanSchema extends GetterBasedSchemaProviderV2 implements Serializable -
Class org.apache.beam.sdk.schemas.JavaBeanSchema.GetterTypeSupplier
class GetterTypeSupplier extends Object implements Serializable -
Class org.apache.beam.sdk.schemas.JavaBeanSchema.SetterTypeSupplier
class SetterTypeSupplier extends Object implements Serializable -
Class org.apache.beam.sdk.schemas.JavaFieldSchema
class JavaFieldSchema extends GetterBasedSchemaProviderV2 implements Serializable -
Class org.apache.beam.sdk.schemas.JavaFieldSchema.JavaFieldTypeSupplier
class JavaFieldTypeSupplier extends Object implements Serializable -
Exception Class org.apache.beam.sdk.schemas.NoSuchSchemaException
class NoSuchSchemaException extends Exception implements Serializable -
Class org.apache.beam.sdk.schemas.Schema
class Schema extends Object implements Serializable-
Serialized Fields
-
encodingPositions
Map<String,
Integer> encodingPositions -
encodingPositionsOverridden
boolean encodingPositionsOverridden
-
fieldIndices
org.apache.beam.vendor.guava.v32_1_2_jre.com.google.common.collect.BiMap<String,
Integer> fieldIndices -
fields
List<Schema.Field> fields
-
hashCode
int hashCode
-
options
Schema.Options options
-
uuid
@Nullable UUID uuid
-
-
-
Class org.apache.beam.sdk.schemas.Schema.Field
class Field extends Object implements Serializable -
Class org.apache.beam.sdk.schemas.Schema.FieldType
class FieldType extends Object implements Serializable -
Class org.apache.beam.sdk.schemas.Schema.Options
class Options extends Object implements Serializable -
Class org.apache.beam.sdk.schemas.SchemaCoder
-
Serialized Fields
-
fromRowFunction
SerializableFunction<Row,
T> fromRowFunction -
schema
Schema schema
-
toRowFunction
SerializableFunction<T,
Row> toRowFunction -
typeDescriptor
TypeDescriptor<T> typeDescriptor
-
-
-
Class org.apache.beam.sdk.schemas.SchemaRegistryTest.Provider
class Provider extends Object implements Serializable -
Class org.apache.beam.sdk.schemas.SchemaRegistryTest.TestDefaultSchemaProvider
class TestDefaultSchemaProvider extends Object implements Serializable
-
-
Package org.apache.beam.sdk.schemas.annotations
-
Class org.apache.beam.sdk.schemas.annotations.DefaultSchema.DefaultSchemaProvider
class DefaultSchemaProvider extends Object implements Serializable-
Serialized Fields
-
cachedProviders
Map<TypeDescriptor,
org.apache.beam.sdk.schemas.annotations.DefaultSchema.DefaultSchemaProvider.ProviderAndDescriptor> cachedProviders
-
-
-
-
Package org.apache.beam.sdk.schemas.io
-
Class org.apache.beam.sdk.schemas.io.DeadLetteredTransform
class DeadLetteredTransform extends PTransform<PCollection<? extends InputT>,PCollection<OutputT>> implements Serializable -
Serialized Fields
-
deadLetter
PTransform<PCollection<Failure>,
PDone> deadLetter -
transform
SimpleFunction<InputT,
OutputT> transform
-
-
-
Exception Class org.apache.beam.sdk.schemas.io.InvalidConfigurationException
class InvalidConfigurationException extends IllegalArgumentException implements Serializable -
Exception Class org.apache.beam.sdk.schemas.io.InvalidLocationException
class InvalidLocationException extends IllegalArgumentException implements Serializable -
Exception Class org.apache.beam.sdk.schemas.io.InvalidSchemaException
class InvalidSchemaException extends IllegalArgumentException implements Serializable
-
-
Package org.apache.beam.sdk.schemas.io.payloads
-
Package org.apache.beam.sdk.schemas.logicaltypes
-
Class org.apache.beam.sdk.schemas.logicaltypes.Date
class Date extends Object implements Serializable -
Class org.apache.beam.sdk.schemas.logicaltypes.DateTime
class DateTime extends Object implements Serializable -
Class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType
class EnumerationType extends Object implements Serializable -
Class org.apache.beam.sdk.schemas.logicaltypes.EnumerationType.Value
class Value extends Object implements Serializable-
Serialized Fields
-
value
int value
-
-
-
Class org.apache.beam.sdk.schemas.logicaltypes.FixedBytes
class FixedBytes extends PassThroughLogicalType<byte[]> implements Serializable -
Class org.apache.beam.sdk.schemas.logicaltypes.FixedPrecisionNumeric
-
Serialized Fields
-
precision
int precision
-
scale
int scale
-
-
-
Class org.apache.beam.sdk.schemas.logicaltypes.FixedString
-
Class org.apache.beam.sdk.schemas.logicaltypes.MicrosInstant
class MicrosInstant extends Object implements Serializable-
Serialized Fields
-
schema
Schema schema
-
-
-
Class org.apache.beam.sdk.schemas.logicaltypes.NanosDuration
class NanosDuration extends org.apache.beam.sdk.schemas.logicaltypes.NanosType<Duration> implements Serializable -
Class org.apache.beam.sdk.schemas.logicaltypes.NanosInstant
class NanosInstant extends org.apache.beam.sdk.schemas.logicaltypes.NanosType<Instant> implements Serializable -
Class org.apache.beam.sdk.schemas.logicaltypes.OneOfType
class OneOfType extends Object implements Serializable-
Serialized Fields
-
enumerationType
EnumerationType enumerationType
-
oneOfSchema
Schema oneOfSchema
-
schemaProtoRepresentation
byte[] schemaProtoRepresentation
-
-
-
Class org.apache.beam.sdk.schemas.logicaltypes.PassThroughLogicalType
class PassThroughLogicalType extends Object implements Serializable-
Serialized Fields
-
argument
Object argument
-
argumentType
Schema.FieldType argumentType
-
fieldType
Schema.FieldType fieldType
-
identifier
String identifier
-
-
-
Class org.apache.beam.sdk.schemas.logicaltypes.PythonCallable
class PythonCallable extends Object implements Serializable -
Class org.apache.beam.sdk.schemas.logicaltypes.SchemaLogicalType
class SchemaLogicalType extends Object implements Serializable -
Class org.apache.beam.sdk.schemas.logicaltypes.Time
class Time extends Object implements Serializable -
Class org.apache.beam.sdk.schemas.logicaltypes.UnknownLogicalType
-
Serialized Fields
-
payload
byte[] payload
-
-
-
Class org.apache.beam.sdk.schemas.logicaltypes.UuidLogicalType
class UuidLogicalType extends Object implements Serializable -
Class org.apache.beam.sdk.schemas.logicaltypes.VariableBytes
class VariableBytes extends PassThroughLogicalType<byte[]> implements Serializable -
Class org.apache.beam.sdk.schemas.logicaltypes.VariableString
-
-
Package org.apache.beam.sdk.schemas.transforms
-
Class org.apache.beam.sdk.schemas.transforms.AddFields.Inner
-
Serialized Fields
-
newFields
List<org.apache.beam.sdk.schemas.transforms.AddFields.Inner.NewField> newFields
-
-
-
Class org.apache.beam.sdk.schemas.transforms.Cast
-
Class org.apache.beam.sdk.schemas.transforms.Cast.CompatibilityError
class CompatibilityError extends Object implements Serializable -
Class org.apache.beam.sdk.schemas.transforms.Cast.Narrowing
class Narrowing extends Object implements Serializable-
Serialized Fields
-
fold
org.apache.beam.sdk.schemas.transforms.Cast.Narrowing.Fold fold
-
-
-
Class org.apache.beam.sdk.schemas.transforms.Cast.Widening
class Widening extends Object implements Serializable-
Serialized Fields
-
fold
org.apache.beam.sdk.schemas.transforms.Cast.Widening.Fold fold
-
-
-
Class org.apache.beam.sdk.schemas.transforms.CoGroup.By
class By extends Object implements Serializable -
Class org.apache.beam.sdk.schemas.transforms.CoGroup.ExpandCrossProduct
class ExpandCrossProduct extends PTransform<PCollectionTuple,PCollection<Row>> implements Serializable -
Serialized Fields
-
joinArgs
org.apache.beam.sdk.schemas.transforms.CoGroup.JoinArguments joinArgs
-
-
-
Class org.apache.beam.sdk.schemas.transforms.CoGroup.Impl
-
Serialized Fields
-
joinArgs
org.apache.beam.sdk.schemas.transforms.CoGroup.JoinArguments joinArgs
-
keyFieldName
String keyFieldName
-
-
-
Class org.apache.beam.sdk.schemas.transforms.DropFields.Inner
-
Serialized Fields
-
fieldsToDrop
FieldAccessDescriptor fieldsToDrop
-
-
-
Class org.apache.beam.sdk.schemas.transforms.Filter.Inner
-
Serialized Fields
-
filters
List<org.apache.beam.sdk.schemas.transforms.Filter.Inner.FilterDescription<?>> filters
-
-
-
Class org.apache.beam.sdk.schemas.transforms.Group.AggregateCombiner
class AggregateCombiner extends PTransform<PCollection<InputT>,PCollection<Row>> implements Serializable -
Class org.apache.beam.sdk.schemas.transforms.Group.ByFields
-
Class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields
-
Class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsByFields.Fanout
class Fanout extends Object implements Serializable -
Class org.apache.beam.sdk.schemas.transforms.Group.CombineFieldsGlobally
-
Serialized Fields
-
fanout
int fanout
-
schemaAggregateFn
org.apache.beam.sdk.schemas.transforms.SchemaAggregateFn.Inner schemaAggregateFn
-
-
-
Class org.apache.beam.sdk.schemas.transforms.Group.CombineGlobally
class CombineGlobally extends PTransform<PCollection<InputT>,PCollection<OutputT>> implements Serializable -
Serialized Fields
-
combineFn
Combine.CombineFn<InputT,
?, OutputT> combineFn -
fanout
int fanout
-
-
-
Class org.apache.beam.sdk.schemas.transforms.Group.Global
class Global extends PTransform<PCollection<InputT>,PCollection<Iterable<InputT>>> implements Serializable -
Class org.apache.beam.sdk.schemas.transforms.GroupTest
class GroupTest extends Object implements Serializable -
Class org.apache.beam.sdk.schemas.transforms.GroupTest.MultipleFieldCombineFn
-
Class org.apache.beam.sdk.schemas.transforms.Join.FieldsEqual.Impl
class Impl extends Object implements Serializable-
Serialized Fields
-
lhs
FieldAccessDescriptor lhs
-
rhs
FieldAccessDescriptor rhs
-
-
-
Class org.apache.beam.sdk.schemas.transforms.Join.Impl
-
Serialized Fields
-
joinType
org.apache.beam.sdk.schemas.transforms.Join.JoinType joinType
-
predicate
@Nullable Join.FieldsEqual.Impl predicate
-
-
-
Class org.apache.beam.sdk.schemas.transforms.RenameFields.Inner
-
Serialized Fields
-
renames
List<org.apache.beam.sdk.schemas.transforms.RenameFields.RenamePair> renames
-
-
-
Class org.apache.beam.sdk.schemas.transforms.SchemaTransform
class SchemaTransform extends PTransform<PCollectionRowTuple,PCollectionRowTuple> implements Serializable -
Class org.apache.beam.sdk.schemas.transforms.Select.Fields
-
Class org.apache.beam.sdk.schemas.transforms.Select.Flattened
-
Class org.apache.beam.sdk.schemas.transforms.TypedSchemaTransformProviderTest.FakeSchemaTransform
class FakeSchemaTransform extends SchemaTransform implements Serializable-
Serialized Fields
-
config
org.apache.beam.sdk.schemas.transforms.TypedSchemaTransformProviderTest.Configuration config
-
-
-
Class org.apache.beam.sdk.schemas.transforms.WithKeys
-
Serialized Fields
-
fieldAccessDescriptor
FieldAccessDescriptor fieldAccessDescriptor
-
-
-
-
Package org.apache.beam.sdk.schemas.transforms.providers
-
Class org.apache.beam.sdk.schemas.transforms.providers.ErrorHandling
class ErrorHandling extends Object implements Serializable -
Class org.apache.beam.sdk.schemas.transforms.providers.JavaExplodeTransformProvider.ExplodeTransform
class ExplodeTransform extends SchemaTransform implements Serializable-
Serialized Fields
-
configuration
JavaExplodeTransformProvider.Configuration configuration
-
-
-
Class org.apache.beam.sdk.schemas.transforms.providers.JavaFilterTransformProvider.JavaFilterTransform
class JavaFilterTransform extends SchemaTransform implements Serializable-
Serialized Fields
-
configuration
JavaFilterTransformProvider.Configuration configuration
-
-
-
Class org.apache.beam.sdk.schemas.transforms.providers.JavaMapToFieldsTransformProvider.JavaMapToFieldsTransform
class JavaMapToFieldsTransform extends SchemaTransform implements Serializable-
Serialized Fields
-
configuration
JavaMapToFieldsTransformProvider.Configuration configuration
-
-
-
Class org.apache.beam.sdk.schemas.transforms.providers.JavaRowUdf
class JavaRowUdf extends Object implements Serializable-
Serialized Fields
-
config
JavaRowUdf.Configuration config
-
inputSchema
Schema inputSchema
-
outputType
Schema.FieldType outputType
-
-
-
Class org.apache.beam.sdk.schemas.transforms.providers.JavaRowUdf.Configuration
class Configuration extends Object implements Serializable -
Class org.apache.beam.sdk.schemas.transforms.providers.LoggingTransformProvider.LoggingTransform
class LoggingTransform extends SchemaTransform implements Serializable-
Serialized Fields
-
configuration
LoggingTransformProvider.Configuration configuration
-
-
-
Exception Class org.apache.beam.sdk.schemas.transforms.providers.StringCompiler.CompileException
class CompileException extends Exception implements Serializable-
Serialized Fields
-
diagnostics
DiagnosticCollector<?> diagnostics
-
-
-
-
Package org.apache.beam.sdk.schemas.utils
-
Class org.apache.beam.sdk.schemas.utils.ByteBuddyUtils.TransformingMap
class TransformingMap extends Object implements Serializable -
Class org.apache.beam.sdk.schemas.utils.ConvertHelpers.ConvertedSchemaInformation
class ConvertedSchemaInformation extends Object implements Serializable-
Serialized Fields
-
outputSchemaCoder
@Nullable SchemaCoder<T> outputSchemaCoder
-
unboxedType
@Nullable Schema.FieldType unboxedType
-
-
-
Class org.apache.beam.sdk.schemas.utils.SchemaZipFold
class SchemaZipFold extends Object implements Serializable -
Class org.apache.beam.sdk.schemas.utils.SelectHelpers.RowSelectorContainer
class RowSelectorContainer extends Object implements Serializable-
Serialized Fields
-
fieldAccessDescriptor
FieldAccessDescriptor fieldAccessDescriptor
-
inputSchema
Schema inputSchema
-
optimized
boolean optimized
-
-
-
-
Package org.apache.beam.sdk.state
-
Package org.apache.beam.sdk.testing
-
Class org.apache.beam.sdk.testing.CoderPropertiesTest.BadCoderThatConsumesMoreBytes
class BadCoderThatConsumesMoreBytes extends org.apache.beam.sdk.testing.CoderPropertiesTest.NonDeterministicCoder implements Serializable -
Class org.apache.beam.sdk.testing.CoderPropertiesTest.ClosingCoder
-
Class org.apache.beam.sdk.testing.CoderPropertiesTest.NonDeterministicCoder
-
Class org.apache.beam.sdk.testing.FileChecksumMatcher
class FileChecksumMatcher extends TypeSafeMatcher<org.apache.beam.sdk.util.ShardedFile> implements Serializable -
Class org.apache.beam.sdk.testing.GatherAllPanesTest
class GatherAllPanesTest extends Object implements Serializable -
Class org.apache.beam.sdk.testing.PAssert.DefaultConcludeTransform
class DefaultConcludeTransform extends PTransform<PCollection<SuccessOrFailure>,PCollection<Void>> implements Serializable -
Class org.apache.beam.sdk.testing.PAssert.GroupThenAssert
-
Serialized Fields
-
checkerFn
SerializableFunction<Iterable<T>,
Void> checkerFn -
paneExtractor
SimpleFunction<Iterable<ValueInSingleWindow<T>>,
Iterable<T>> paneExtractor -
rewindowingStrategy
org.apache.beam.sdk.testing.PAssert.AssertionWindows rewindowingStrategy
-
site
PAssert.PAssertionSite site
-
-
-
Class org.apache.beam.sdk.testing.PAssert.GroupThenAssertForSingleton
-
Serialized Fields
-
checkerFn
SerializableFunction<T,
Void> checkerFn -
paneExtractor
SimpleFunction<Iterable<ValueInSingleWindow<T>>,
Iterable<T>> paneExtractor -
rewindowingStrategy
org.apache.beam.sdk.testing.PAssert.AssertionWindows rewindowingStrategy
-
site
PAssert.PAssertionSite site
-
-
-
Class org.apache.beam.sdk.testing.PAssert.MatcherCheckerFn
class MatcherCheckerFn extends Object implements Serializable-
Serialized Fields
-
matcher
SerializableMatcher<T> matcher
-
-
-
Class org.apache.beam.sdk.testing.PAssert.OneSideInputAssert
-
Serialized Fields
-
checkerFn
SerializableFunction<ActualT,
Void> checkerFn -
site
PAssert.PAssertionSite site
-
-
-
Class org.apache.beam.sdk.testing.PAssert.PAssertionSite
class PAssertionSite extends Object implements Serializable-
Serialized Fields
-
creationStackTrace
StackTraceElement[] creationStackTrace
-
message
String message
-
-
-
Class org.apache.beam.sdk.testing.PAssertTest
class PAssertTest extends Object implements Serializable -
Class org.apache.beam.sdk.testing.SerializableMatchers
class SerializableMatchers extends Object implements Serializable -
Class org.apache.beam.sdk.testing.SerializableMatchersTest
class SerializableMatchersTest extends Object implements Serializable -
Class org.apache.beam.sdk.testing.SuccessOrFailure
class SuccessOrFailure extends Object implements Serializable-
Serialized Fields
-
isSuccess
boolean isSuccess
-
site
@Nullable PAssert.PAssertionSite site
-
throwable
@Nullable org.apache.beam.sdk.util.SerializableThrowable throwable
-
-
-
Exception Class org.apache.beam.sdk.testing.TestPipeline.AbandonedNodeException
class AbandonedNodeException extends RuntimeException implements Serializable -
Exception Class org.apache.beam.sdk.testing.TestPipeline.PipelineRunMissingException
class PipelineRunMissingException extends RuntimeException implements Serializable -
Class org.apache.beam.sdk.testing.TestPipelineOptions.AlwaysPassMatcher
-
Class org.apache.beam.sdk.testing.TestPipelineTest
class TestPipelineTest extends Object implements Serializable -
Class org.apache.beam.sdk.testing.TestPipelineTest.NewProviderTest
class NewProviderTest extends Object implements Serializable -
Class org.apache.beam.sdk.testing.TestPipelineTest.TestPipelineCreationTest.TestMatcher
-
Serialized Fields
-
uuid
UUID uuid
-
-
-
Class org.apache.beam.sdk.testing.TestPipelineTest.TestPipelineEnforcementsTest
class TestPipelineEnforcementsTest extends Object implements Serializable -
Class org.apache.beam.sdk.testing.TestStream
-
Serialized Fields
-
coder
Coder<T> coder
-
events
List<TestStream.Event<T>> events
-
-
-
Class org.apache.beam.sdk.testing.TestStream.TestStreamCoder
-
Serialized Fields
-
elementCoder
TimestampedValue.TimestampedValueCoder<T> elementCoder
-
-
-
Class org.apache.beam.sdk.testing.TestStreamTest
class TestStreamTest extends Object implements Serializable
-
-
Package org.apache.beam.sdk.transforms
-
Class org.apache.beam.sdk.transforms.ApproximateQuantiles.ApproximateQuantilesCombineFn
class ApproximateQuantilesCombineFn extends Combine.AccumulatingCombineFn<T,org.apache.beam.sdk.transforms.ApproximateQuantiles.QuantileState<T, ComparatorT extends Comparator<T> & Serializable>, List<T>> implements Serializable -
Serialized Fields
-
bufferSize
int bufferSize
The size of the buffers, corresponding to k in the referenced paper. -
compareFn
ComparatorT extends Comparator<T> & Serializable compareFn
The comparison function to use. -
maxNumElements
long maxNumElements
-
numBuffers
int numBuffers
The number of buffers, corresponding to b in the referenced paper. -
numQuantiles
int numQuantiles
Number of quantiles to produce. The size of the final output list, including the minimum and maximum, is numQuantiles.
-
-
-
Class org.apache.beam.sdk.transforms.ApproximateUnique.ApproximateUniqueCombineFn
class ApproximateUniqueCombineFn extends Combine.CombineFn<T,ApproximateUnique.ApproximateUniqueCombineFn.LargestUnique, Long> implements Serializable -
Class org.apache.beam.sdk.transforms.ApproximateUnique.ApproximateUniqueCombineFn.LargestUnique
class LargestUnique extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.ApproximateUnique.Globally
-
Class org.apache.beam.sdk.transforms.ApproximateUnique.PerKey
class PerKey extends PTransform<PCollection<KV<K,V>>, PCollection<KV<K, Long>>> implements Serializable -
Class org.apache.beam.sdk.transforms.ApproximateUniqueTest
class ApproximateUniqueTest extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.ApproximateUniqueTest.ApproximateUniqueMiscTest
class ApproximateUniqueMiscTest extends org.apache.beam.sdk.transforms.ApproximateUniqueTest implements Serializable -
Class org.apache.beam.sdk.transforms.ApproximateUniqueTest.ApproximateUniqueVariationsTest
class ApproximateUniqueVariationsTest extends org.apache.beam.sdk.transforms.ApproximateUniqueTest implements Serializable-
Serialized Fields
-
sampleSize
int sampleSize
-
-
-
Class org.apache.beam.sdk.transforms.ApproximateUniqueTest.ApproximateUniqueWithDuplicatesTest
class ApproximateUniqueWithDuplicatesTest extends org.apache.beam.sdk.transforms.ApproximateUniqueTest implements Serializable-
Serialized Fields
-
elementCount
int elementCount
-
sampleSize
int sampleSize
-
uniqueCount
int uniqueCount
-
-
-
Class org.apache.beam.sdk.transforms.Combine.AccumulatingCombineFn
class AccumulatingCombineFn extends Combine.CombineFn<InputT,AccumT extends Combine.AccumulatingCombineFn.Accumulator<InputT, AccumT, OutputT>, OutputT> implements Serializable -
Class org.apache.beam.sdk.transforms.Combine.BinaryCombineDoubleFn
class BinaryCombineDoubleFn extends Combine.CombineFn<Double,double[], Double> implements Serializable -
Class org.apache.beam.sdk.transforms.Combine.BinaryCombineFn
-
Class org.apache.beam.sdk.transforms.Combine.BinaryCombineIntegerFn
class BinaryCombineIntegerFn extends Combine.CombineFn<Integer,int[], Integer> implements Serializable -
Class org.apache.beam.sdk.transforms.Combine.BinaryCombineLongFn
-
Class org.apache.beam.sdk.transforms.Combine.CombineFn
-
Class org.apache.beam.sdk.transforms.Combine.Globally
-
Serialized Fields
-
fanout
int fanout
-
fn
CombineFnBase.GlobalCombineFn<? super InputT,
?, OutputT> fn -
fnDisplayData
DisplayData.ItemSpec<? extends Class<?>> fnDisplayData
-
insertDefault
boolean insertDefault
-
sideInputs
List<PCollectionView<?>> sideInputs
-
-
-
Class org.apache.beam.sdk.transforms.Combine.GloballyAsSingletonView
class GloballyAsSingletonView extends PTransform<PCollection<InputT>,PCollectionView<OutputT>> implements Serializable -
Serialized Fields
-
fanout
int fanout
-
fn
CombineFnBase.GlobalCombineFn<? super InputT,
?, OutputT> fn -
fnDisplayData
DisplayData.ItemSpec<? extends Class<?>> fnDisplayData
-
insertDefault
boolean insertDefault
-
-
-
Class org.apache.beam.sdk.transforms.Combine.GroupedValues
class GroupedValues extends PTransform<PCollection<? extends KV<K,? extends Iterable<InputT>>>, PCollection<KV<K, OutputT>>> implements Serializable -
Serialized Fields
-
fn
CombineFnBase.GlobalCombineFn<? super InputT,
?, OutputT> fn -
fnDisplayData
DisplayData.ItemSpec<? extends Class<?>> fnDisplayData
-
sideInputs
List<PCollectionView<?>> sideInputs
-
-
-
Class org.apache.beam.sdk.transforms.Combine.IterableCombineFn
-
Serialized Fields
-
bufferSize
int bufferSize
The number of values to accumulate before invoking the combiner function to combine them. -
combiner
SerializableFunction<Iterable<V>,
V> combiner The combiner function.
-
-
-
Class org.apache.beam.sdk.transforms.Combine.PerKey
class PerKey extends PTransform<PCollection<KV<K,InputT>>, PCollection<KV<K, OutputT>>> implements Serializable -
Serialized Fields
-
fewKeys
boolean fewKeys
-
fn
CombineFnBase.GlobalCombineFn<? super InputT,
?, OutputT> fn -
fnDisplayData
DisplayData.ItemSpec<? extends Class<?>> fnDisplayData
-
sideInputs
List<PCollectionView<?>> sideInputs
-
-
-
Class org.apache.beam.sdk.transforms.Combine.PerKeyWithHotKeyFanout
class PerKeyWithHotKeyFanout extends PTransform<PCollection<KV<K,InputT>>, PCollection<KV<K, OutputT>>> implements Serializable -
Serialized Fields
-
fewKeys
boolean fewKeys
-
fn
CombineFnBase.GlobalCombineFn<? super InputT,
?, OutputT> fn -
fnDisplayData
DisplayData.ItemSpec<? extends Class<?>> fnDisplayData
-
hotKeyFanout
SerializableFunction<? super K,
Integer> hotKeyFanout -
sideInputs
List<PCollectionView<?>> sideInputs
-
-
-
Class org.apache.beam.sdk.transforms.Combine.SimpleCombineFn
-
Class org.apache.beam.sdk.transforms.CombineFns.CoCombineResult
class CoCombineResult extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFn
class ComposedCombineFn extends Combine.CombineFn<DataT,Object[], CombineFns.CoCombineResult> implements Serializable -
Serialized Fields
-
combineFnCount
int combineFnCount
-
combineFns
List<Combine.CombineFn<Object,
Object, Object>> combineFns -
combineInputCoders
List<org.apache.beam.vendor.guava.v32_1_2_jre.com.google.common.base.Optional<Coder>> combineInputCoders
-
extractInputFns
List<SerializableFunction<DataT,
Object>> extractInputFns -
outputTags
List<TupleTag<?>> outputTags
-
-
-
Class org.apache.beam.sdk.transforms.CombineFns.ComposedCombineFnWithContext
class ComposedCombineFnWithContext extends CombineWithContext.CombineFnWithContext<DataT,Object[], CombineFns.CoCombineResult> implements Serializable -
Serialized Fields
-
combineFnCount
int combineFnCount
-
combineFnWithContexts
List<CombineWithContext.CombineFnWithContext<Object,
Object, Object>> combineFnWithContexts -
combineInputCoders
List<org.apache.beam.vendor.guava.v32_1_2_jre.com.google.common.base.Optional<Coder>> combineInputCoders
-
extractInputFns
List<SerializableFunction<DataT,
Object>> extractInputFns -
outputTags
List<TupleTag<?>> outputTags
-
-
-
Class org.apache.beam.sdk.transforms.CombineTest
class CombineTest extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.CombineTest.WindowingTests
class WindowingTests extends org.apache.beam.sdk.transforms.CombineTest.SharedTestBase implements Serializable -
Class org.apache.beam.sdk.transforms.CombineWithContext.CombineFnWithContext
class CombineFnWithContext extends org.apache.beam.sdk.transforms.CombineFnBase.AbstractGlobalCombineFn<InputT,AccumT, OutputT> implements Serializable -
Class org.apache.beam.sdk.transforms.Contextful
class Contextful extends Object implements Serializable-
Serialized Fields
-
closure
ClosureT closure
-
requirements
Requirements requirements
-
-
-
Class org.apache.beam.sdk.transforms.Create.OfValueProvider
-
Serialized Fields
-
coder
Coder<T> coder
-
provider
ValueProvider<T> provider
-
-
-
Class org.apache.beam.sdk.transforms.Create.TimestampedValues
-
Class org.apache.beam.sdk.transforms.Create.Values
-
Class org.apache.beam.sdk.transforms.Create.WindowedValues
-
Serialized Fields
-
windowCoder
org.apache.beam.vendor.guava.v32_1_2_jre.com.google.common.base.Optional<Coder<? extends BoundedWindow>> windowCoder
-
-
-
Class org.apache.beam.sdk.transforms.Deduplicate.KeyedValues
class KeyedValues extends PTransform<PCollection<KV<K,V>>, PCollection<KV<K, V>>> implements Serializable -
Serialized Fields
-
duration
Duration duration
-
timeDomain
TimeDomain timeDomain
-
-
-
Class org.apache.beam.sdk.transforms.Deduplicate.Values
-
Serialized Fields
-
duration
Duration duration
-
timeDomain
TimeDomain timeDomain
-
-
-
Class org.apache.beam.sdk.transforms.Deduplicate.WithRepresentativeValues
class WithRepresentativeValues extends PTransform<PCollection<T>,PCollection<T>> implements Serializable -
Serialized Fields
-
coder
@Nullable Coder<IdT> coder
-
duration
Duration duration
-
fn
SerializableFunction<T,
IdT> fn -
timeDomain
TimeDomain timeDomain
-
type
@Nullable TypeDescriptor<IdT> type
-
-
-
Class org.apache.beam.sdk.transforms.Distinct
-
Class org.apache.beam.sdk.transforms.Distinct.WithRepresentativeValues
class WithRepresentativeValues extends PTransform<PCollection<T>,PCollection<T>> implements Serializable -
Serialized Fields
-
fn
SerializableFunction<T,
IdT> fn -
representativeType
TypeDescriptor<IdT> representativeType
-
-
-
Class org.apache.beam.sdk.transforms.DoFn
class DoFn extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.DoFnSchemaInformation
class DoFnSchemaInformation extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.DoFnTest
class DoFnTest extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.Filter
-
Serialized Fields
-
predicate
ProcessFunction<T,
Boolean> predicate -
predicateDescription
String predicateDescription
-
-
-
Class org.apache.beam.sdk.transforms.FilterTest
class FilterTest extends Object implements Serializable-
Serialized Fields
-
p
TestPipeline p
-
-
-
Class org.apache.beam.sdk.transforms.FlatMapElements
class FlatMapElements extends PTransform<PCollection<? extends InputT>,PCollection<OutputT>> implements Serializable -
Class org.apache.beam.sdk.transforms.FlatMapElements.FlatMapWithFailures
class FlatMapWithFailures extends PTransform<PCollection<InputT>,WithFailures.Result<PCollection<OutputT>, FailureT>> implements Serializable -
Serialized Fields
-
exceptionHandler
@Nullable ProcessFunction<WithFailures.ExceptionElement<InputT>,
FailureT> exceptionHandler -
fn
@Nullable Object fn
-
-
-
Class org.apache.beam.sdk.transforms.FlatMapElementsTest
class FlatMapElementsTest extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.Flatten.Iterables
class Iterables extends PTransform<PCollection<? extends Iterable<T>>,PCollection<T>> implements Serializable -
Class org.apache.beam.sdk.transforms.Flatten.PCollections
-
Class org.apache.beam.sdk.transforms.FlattenTest
class FlattenTest extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.GroupByKey
class GroupByKey extends PTransform<PCollection<KV<K,V>>, PCollection<KV<K, Iterable<V>>>> implements Serializable -
Serialized Fields
-
fewKeys
boolean fewKeys
-
-
-
Class org.apache.beam.sdk.transforms.GroupByKeyTest
class GroupByKeyTest extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.GroupByKeyTest.BasicTests
class BasicTests extends org.apache.beam.sdk.transforms.GroupByKeyTest.SharedTestBase implements Serializable -
Class org.apache.beam.sdk.transforms.GroupByKeyTest.DeterministicKeyCoder
class DeterministicKeyCoder extends AtomicCoder<org.apache.beam.sdk.transforms.GroupByKeyTest.BadEqualityKey> implements Serializable -
Class org.apache.beam.sdk.transforms.GroupIntoBatches
class GroupIntoBatches extends PTransform<PCollection<KV<K,InputT>>, PCollection<KV<K, Iterable<InputT>>>> implements Serializable -
Serialized Fields
-
params
GroupIntoBatches.BatchingParams<InputT> params
-
-
-
Class org.apache.beam.sdk.transforms.GroupIntoBatches.BatchingParams
class BatchingParams extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.GroupIntoBatches.WithShardedKey
class WithShardedKey extends PTransform<PCollection<KV<K,InputT>>, PCollection<KV<org.apache.beam.sdk.util.ShardedKey<K>, Iterable<InputT>>>> implements Serializable -
Class org.apache.beam.sdk.transforms.GroupIntoBatchesTest
class GroupIntoBatchesTest extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.Impulse
-
Class org.apache.beam.sdk.transforms.InferableFunction
class InferableFunction extends Object implements Serializable-
Serialized Fields
-
fn
@Nullable ProcessFunction<InputT,
OutputT> fn
-
-
-
Class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn
class JsonToRowWithErrFn extends PTransform<PCollection<String>,JsonToRow.ParseResult> implements Serializable -
Class org.apache.beam.sdk.transforms.JsonToRow.JsonToRowWithErrFn.ParseWithError
-
Class org.apache.beam.sdk.transforms.JsonToRowTest
class JsonToRowTest extends Object implements Serializable-
Serialized Fields
-
thrown
ExpectedException thrown
-
-
-
Class org.apache.beam.sdk.transforms.Keys
class Keys extends PTransform<PCollection<? extends KV<K,?>>, PCollection<K>> implements Serializable -
Class org.apache.beam.sdk.transforms.KvSwap
-
Class org.apache.beam.sdk.transforms.LatestTest
class LatestTest extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.MapElements
class MapElements extends PTransform<PCollection<? extends InputT>,PCollection<OutputT>> implements Serializable -
Class org.apache.beam.sdk.transforms.MapElements.MapWithFailures
class MapWithFailures extends PTransform<PCollection<InputT>,WithFailures.Result<PCollection<OutputT>, FailureT>> implements Serializable -
Serialized Fields
-
exceptionHandler
@Nullable ProcessFunction<WithFailures.ExceptionElement<InputT>,
FailureT> exceptionHandler -
fn
Object fn
-
-
-
Class org.apache.beam.sdk.transforms.MapElementsTest
class MapElementsTest extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.MapKeys
class MapKeys extends PTransform<PCollection<KV<K1,V>>, PCollection<KV<K2, V>>> implements Serializable -
Serialized Fields
-
fn
@Nullable Contextful<Contextful.Fn<KV<K1,
V>, KV<K2, V>>> fn
-
-
-
Class org.apache.beam.sdk.transforms.MapValues
class MapValues extends PTransform<PCollection<KV<K,V1>>, PCollection<KV<K, V2>>> implements Serializable -
Serialized Fields
-
fn
@Nullable Contextful<Contextful.Fn<KV<K,
V1>, KV<K, V2>>> fn
-
-
-
Class org.apache.beam.sdk.transforms.ParDo.MultiOutput
class MultiOutput extends PTransform<PCollection<? extends InputT>,PCollectionTuple> implements Serializable -
Serialized Fields
-
additionalOutputTags
TupleTagList additionalOutputTags
-
fn
DoFn<InputT,
OutputT> fn -
fnDisplayData
DisplayData.ItemSpec<? extends Class<?>> fnDisplayData
-
mainOutputTag
TupleTag<OutputT> mainOutputTag
-
sideInputs
Map<String,
PCollectionView<?>> sideInputs
-
-
-
Class org.apache.beam.sdk.transforms.ParDo.SingleOutput
class SingleOutput extends PTransform<PCollection<? extends InputT>,PCollection<OutputT>> implements Serializable -
Serialized Fields
-
fn
DoFn<InputT,
OutputT> fn -
fnDisplayData
DisplayData.ItemSpec<? extends Class<?>> fnDisplayData
-
sideInputs
Map<String,
PCollectionView<?>> sideInputs
-
-
-
Class org.apache.beam.sdk.transforms.ParDoLifecycleTest
class ParDoLifecycleTest extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.ParDoSchemaTest
class ParDoSchemaTest extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.ParDoTest
class ParDoTest extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.ParDoTest.BasicTests
class BasicTests extends org.apache.beam.sdk.transforms.ParDoTest.SharedTestBase implements Serializable -
Class org.apache.beam.sdk.transforms.ParDoTest.BundleFinalizationTests
class BundleFinalizationTests extends org.apache.beam.sdk.transforms.ParDoTest.SharedTestBase implements Serializable -
Class org.apache.beam.sdk.transforms.ParDoTest.BundleFinalizationTests.SideInputBundleFinalizingDoFn
class SideInputBundleFinalizingDoFn extends org.apache.beam.sdk.transforms.ParDoTest.BundleFinalizationTests.BundleFinalizingDoFn implements Serializable-
Serialized Fields
-
view
PCollectionView<String> view
-
-
-
Class org.apache.beam.sdk.transforms.ParDoTest.BundleFinalizationTests.StatefulBundleFinalizingDoFn
class StatefulBundleFinalizingDoFn extends org.apache.beam.sdk.transforms.ParDoTest.BundleFinalizationTests.BundleFinalizingDoFn implements Serializable-
Serialized Fields
-
intState
StateSpec<ValueState<Integer>> intState
-
-
-
Class org.apache.beam.sdk.transforms.ParDoTest.BundleInvariantsTests
class BundleInvariantsTests extends org.apache.beam.sdk.transforms.ParDoTest.SharedTestBase implements Serializable -
Class org.apache.beam.sdk.transforms.ParDoTest.KeyTests
class KeyTests extends org.apache.beam.sdk.transforms.ParDoTest.SharedTestBase implements Serializable -
Class org.apache.beam.sdk.transforms.ParDoTest.LifecycleTests
class LifecycleTests extends org.apache.beam.sdk.transforms.ParDoTest.SharedTestBase implements Serializable -
Class org.apache.beam.sdk.transforms.ParDoTest.MultipleInputsAndOutputTests
class MultipleInputsAndOutputTests extends org.apache.beam.sdk.transforms.ParDoTest.SharedTestBase implements Serializable -
Class org.apache.beam.sdk.transforms.ParDoTest.OnWindowExpirationTests
class OnWindowExpirationTests extends org.apache.beam.sdk.transforms.ParDoTest.SharedTestBase implements Serializable -
Class org.apache.beam.sdk.transforms.ParDoTest.SchemaInformationTests
class SchemaInformationTests extends org.apache.beam.sdk.transforms.ParDoTest.SharedTestBase implements Serializable -
Class org.apache.beam.sdk.transforms.ParDoTest.StateCoderInferenceTests
class StateCoderInferenceTests extends org.apache.beam.sdk.transforms.ParDoTest.SharedTestBase implements Serializable -
Class org.apache.beam.sdk.transforms.ParDoTest.StateTests
class StateTests extends org.apache.beam.sdk.transforms.ParDoTest.SharedTestBase implements Serializable -
Class org.apache.beam.sdk.transforms.ParDoTest.TimerCoderInferenceTests
class TimerCoderInferenceTests extends org.apache.beam.sdk.transforms.ParDoTest.SharedTestBase implements Serializable -
Class org.apache.beam.sdk.transforms.ParDoTest.TimerFamilyTests
class TimerFamilyTests extends org.apache.beam.sdk.transforms.ParDoTest.SharedTestBase implements Serializable -
Class org.apache.beam.sdk.transforms.ParDoTest.TimerTests
class TimerTests extends org.apache.beam.sdk.transforms.ParDoTest.SharedTestBase implements Serializable -
Class org.apache.beam.sdk.transforms.ParDoTest.TimestampTests
class TimestampTests extends org.apache.beam.sdk.transforms.ParDoTest.SharedTestBase implements Serializable -
Class org.apache.beam.sdk.transforms.Partition
-
Class org.apache.beam.sdk.transforms.PartitionTest
class PartitionTest extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.PeriodicImpulse
-
Class org.apache.beam.sdk.transforms.PeriodicImpulseTest.ExtractTsDoFn
class ExtractTsDoFn extends DoFn<InputT,KV<InputT, Instant>> implements Serializable -
Class org.apache.beam.sdk.transforms.PeriodicSequence
class PeriodicSequence extends PTransform<PCollection<PeriodicSequence.SequenceDefinition>,PCollection<Instant>> implements Serializable -
Class org.apache.beam.sdk.transforms.PeriodicSequenceTest.ExtractTsDoFn
class ExtractTsDoFn extends DoFn<InputT,TimestampedValue<KV<InputT, Instant>>> implements Serializable -
Class org.apache.beam.sdk.transforms.PerKeyOrderingTest
class PerKeyOrderingTest extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.PTransform
class PTransform extends Object implements Serializable- serialVersionUID:
- 3383862966597863311L
-
Serialization Methods
-
readObject
-
writeObject
-
-
Class org.apache.beam.sdk.transforms.PTransformTest
class PTransformTest extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.Redistribute.RedistributeArbitrarily
class RedistributeArbitrarily extends PTransform<PCollection<T>,PCollection<T>> implements Serializable -
Class org.apache.beam.sdk.transforms.Redistribute.RedistributeByKey
class RedistributeByKey extends PTransform<PCollection<KV<K,V>>, PCollection<KV<K, V>>> implements Serializable -
Serialized Fields
-
allowDuplicates
boolean allowDuplicates
-
-
-
Class org.apache.beam.sdk.transforms.RedistributeTest
class RedistributeTest extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.Regex.AllMatches
class AllMatches extends PTransform<PCollection<String>,PCollection<List<String>>> implements Serializable -
Serialized Fields
-
pattern
Pattern pattern
-
-
-
Class org.apache.beam.sdk.transforms.Regex.Find
-
Serialized Fields
-
group
int group
-
pattern
Pattern pattern
-
-
-
Class org.apache.beam.sdk.transforms.Regex.FindAll
class FindAll extends PTransform<PCollection<String>,PCollection<List<String>>> implements Serializable -
Serialized Fields
-
pattern
Pattern pattern
-
-
-
Class org.apache.beam.sdk.transforms.Regex.FindKV
class FindKV extends PTransform<PCollection<String>,PCollection<KV<String, String>>> implements Serializable -
Serialized Fields
-
keyGroup
int keyGroup
-
pattern
Pattern pattern
-
valueGroup
int valueGroup
-
-
-
Class org.apache.beam.sdk.transforms.Regex.FindName
-
Class org.apache.beam.sdk.transforms.Regex.FindNameKV
class FindNameKV extends PTransform<PCollection<String>,PCollection<KV<String, String>>> implements Serializable -
Class org.apache.beam.sdk.transforms.Regex.Matches
-
Serialized Fields
-
group
int group
-
pattern
Pattern pattern
-
-
-
Class org.apache.beam.sdk.transforms.Regex.MatchesKV
class MatchesKV extends PTransform<PCollection<String>,PCollection<KV<String, String>>> implements Serializable -
Serialized Fields
-
keyGroup
int keyGroup
-
pattern
Pattern pattern
-
valueGroup
int valueGroup
-
-
-
Class org.apache.beam.sdk.transforms.Regex.MatchesName
class MatchesName extends PTransform<PCollection<String>,PCollection<String>> implements Serializable -
Class org.apache.beam.sdk.transforms.Regex.MatchesNameKV
class MatchesNameKV extends PTransform<PCollection<String>,PCollection<KV<String, String>>> implements Serializable -
Class org.apache.beam.sdk.transforms.Regex.ReplaceAll
class ReplaceAll extends PTransform<PCollection<String>,PCollection<String>> implements Serializable -
Class org.apache.beam.sdk.transforms.Regex.ReplaceFirst
class ReplaceFirst extends PTransform<PCollection<String>,PCollection<String>> implements Serializable -
Class org.apache.beam.sdk.transforms.Regex.Split
-
Serialized Fields
-
outputEmpty
boolean outputEmpty
-
pattern
Pattern pattern
-
splitLimit
int splitLimit
-
-
-
Class org.apache.beam.sdk.transforms.RegexTest
class RegexTest extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.ReifyTest
class ReifyTest extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.ReifyTimestampsTest
class ReifyTimestampsTest extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.Requirements
class Requirements extends Object implements Serializable-
Serialized Fields
-
sideInputs
Collection<PCollectionView<?>> sideInputs
-
-
-
Class org.apache.beam.sdk.transforms.Reshuffle
class Reshuffle extends PTransform<PCollection<KV<K,V>>, PCollection<KV<K, V>>> implements Serializable -
Class org.apache.beam.sdk.transforms.Reshuffle.AssignShardFn
-
Class org.apache.beam.sdk.transforms.Reshuffle.ViaRandomKey
-
Class org.apache.beam.sdk.transforms.ReshuffleTest
class ReshuffleTest extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.Sample.FixedSizedSampleFn
class FixedSizedSampleFn extends Combine.CombineFn<T,org.apache.beam.sdk.transforms.Top.BoundedHeap<KV<Integer, T>, SerializableComparator<KV<Integer, T>>>, Iterable<T>> implements Serializable -
Serialized Fields
-
rand
Random rand
-
sampleSize
int sampleSize
-
topCombineFn
Top.TopCombineFn<KV<Integer,
T>, SerializableComparator<KV<Integer, T>>> topCombineFn
-
-
-
Class org.apache.beam.sdk.transforms.SampleTest.MiscTest.VerifyCorrectSample
class VerifyCorrectSample extends Object implements Serializable-
Serialized Fields
-
expectedSize
int expectedSize
-
expectedValues
Object[] expectedValues
-
-
-
Class org.apache.beam.sdk.transforms.SimpleFunction
-
Serialized Fields
-
-
Class org.apache.beam.sdk.transforms.SplittableDoFnTest
class SplittableDoFnTest extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.SplittableDoFnTest.BundleFinalizingSplittableDoFn
-
Serialized Fields
-
uuid
UUID uuid
-
-
-
Class org.apache.beam.sdk.transforms.Tee
-
Serialized Fields
-
consumer
PTransform<PCollection<T>,
?> consumer
-
-
-
Class org.apache.beam.sdk.transforms.ToJson
-
Class org.apache.beam.sdk.transforms.ToJsonTest
class ToJsonTest extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.Top.Largest
class Largest extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.Top.Natural
class Natural extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.Top.Reversed
class Reversed extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.Top.Smallest
class Smallest extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.Top.TopCombineFn
class TopCombineFn extends Combine.AccumulatingCombineFn<T,org.apache.beam.sdk.transforms.Top.BoundedHeap<T, ComparatorT extends Comparator<T> & Serializable>, List<T>> implements Serializable -
Serialized Fields
-
compareFn
ComparatorT extends Comparator<T> & Serializable compareFn
-
count
int count
-
-
-
Class org.apache.beam.sdk.transforms.Values
class Values extends PTransform<PCollection<? extends KV<?,V>>, PCollection<V>> implements Serializable -
Class org.apache.beam.sdk.transforms.View.AsIterable
class AsIterable extends PTransform<PCollection<T>,PCollectionView<Iterable<T>>> implements Serializable -
Class org.apache.beam.sdk.transforms.View.AsList
-
Class org.apache.beam.sdk.transforms.View.AsMap
class AsMap extends PTransform<PCollection<KV<K,V>>, PCollectionView<Map<K, V>>> implements Serializable -
Serialized Fields
-
inMemory
boolean inMemory
-
-
-
Class org.apache.beam.sdk.transforms.View.AsMultimap
class AsMultimap extends PTransform<PCollection<KV<K,V>>, PCollectionView<Map<K, Iterable<V>>>> implements Serializable -
Serialized Fields
-
inMemory
boolean inMemory
-
-
-
Class org.apache.beam.sdk.transforms.View.AsSingleton
-
Class org.apache.beam.sdk.transforms.View.CreatePCollectionView
class CreatePCollectionView extends PTransform<PCollection<ElemT>,PCollection<ElemT>> implements Serializable -
Serialized Fields
-
view
PCollectionView<ViewT> view
-
-
-
Class org.apache.beam.sdk.transforms.View.ToListViewDoFn
class ToListViewDoFn extends DoFn<T,KV<Long, PCollectionViews.ValueOrMetadata<T, OffsetRange>>> implements Serializable -
Serialized Fields
-
windowsToOffsets
Map<BoundedWindow,
OffsetRange> windowsToOffsets
-
-
-
Class org.apache.beam.sdk.transforms.ViewFn
class ViewFn extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.ViewTest
class ViewTest extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.Wait.OnSignal
-
Class org.apache.beam.sdk.transforms.WaitTest
class WaitTest extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.Watch.Growth
class Growth extends PTransform<PCollection<InputT>,PCollection<KV<InputT, OutputT>>> implements Serializable -
Class org.apache.beam.sdk.transforms.Watch.Growth.PollFn
class PollFn extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.Watch.WatchGrowthFn
class WatchGrowthFn extends DoFn<InputT,KV<InputT, List<TimestampedValue<OutputT>>>> implements Serializable -
Class org.apache.beam.sdk.transforms.WatchTest
class WatchTest extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.WithFailures.ExceptionAsMapHandler
class ExceptionAsMapHandler extends SimpleFunction<WithFailures.ExceptionElement<T>,KV<T, Map<String, String>>> implements Serializable -
Class org.apache.beam.sdk.transforms.WithFailures.ThrowableHandler
class ThrowableHandler extends SimpleFunction<WithFailures.ExceptionElement<T>,KV<T, EncodableThrowable>> implements Serializable -
Class org.apache.beam.sdk.transforms.WithFailuresTest
class WithFailuresTest extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.WithKeys
-
Serialized Fields
-
fn
SerializableFunction<V,
K> fn
-
-
-
Class org.apache.beam.sdk.transforms.WithKeysTest.LengthAsKey
class LengthAsKey extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.WithTimestamps
-
Serialized Fields
-
allowedTimestampSkew
Duration allowedTimestampSkew
-
fn
SerializableFunction<T,
Instant> fn
-
-
-
Class org.apache.beam.sdk.transforms.WithTimestampsTest
class WithTimestampsTest extends Object implements Serializable
-
-
Package org.apache.beam.sdk.transforms.display
-
Class org.apache.beam.sdk.transforms.display.DisplayData
class DisplayData extends Object implements Serializable-
Serialized Fields
-
entries
org.apache.beam.vendor.guava.v32_1_2_jre.com.google.common.collect.ImmutableMap<DisplayData.Identifier,
DisplayData.Item> entries
-
-
-
Class org.apache.beam.sdk.transforms.display.DisplayData.Identifier
class Identifier extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.display.DisplayData.Item
class Item extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.display.DisplayData.ItemSpec
class ItemSpec extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.display.DisplayData.Path
class Path extends Object implements Serializable-
Serialized Fields
-
components
org.apache.beam.vendor.guava.v32_1_2_jre.com.google.common.collect.ImmutableList<String> components
-
-
-
Class org.apache.beam.sdk.transforms.display.DisplayDataEvaluatorTest
class DisplayDataEvaluatorTest extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.display.DisplayDataTest
class DisplayDataTest extends Object implements Serializable
-
-
Package org.apache.beam.sdk.transforms.errorhandling
-
Class org.apache.beam.sdk.transforms.errorhandling.BadRecord
class BadRecord extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Failure
class Failure extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.errorhandling.BadRecord.Record
class Record extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.errorhandling.BadRecordRouter.RecordingBadRecordRouter
class RecordingBadRecordRouter extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.errorhandling.BadRecordRouter.ThrowingBadRecordRouter
class ThrowingBadRecordRouter extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.errorhandling.BRHEnabledPTransform
class BRHEnabledPTransform extends PTransform<PCollection<Integer>,PCollection<Integer>> implements Serializable -
Serialized Fields
-
badRecordRouter
BadRecordRouter badRecordRouter
-
errorHandler
ErrorHandler<BadRecord,
?> errorHandler
-
-
-
Class org.apache.beam.sdk.transforms.errorhandling.BRHEnabledPTransform.OddIsBad
-
Serialized Fields
-
badRecordRouter
BadRecordRouter badRecordRouter
-
-
-
Class org.apache.beam.sdk.transforms.errorhandling.ErrorHandler.BadRecordErrorHandler
class BadRecordErrorHandler extends ErrorHandler.PTransformErrorHandler<BadRecord,OutputT extends POutput> implements Serializable -
Class org.apache.beam.sdk.transforms.errorhandling.ErrorHandler.DefaultErrorHandler
class DefaultErrorHandler extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.errorhandling.ErrorHandler.PTransformErrorHandler
class PTransformErrorHandler extends Object implements Serializable-
Serialization Methods
-
readObject
- Throws:
ClassNotFoundException
IOException
-
-
Serialized Fields
-
closed
boolean closed
-
coder
Coder<ErrorT> coder
-
sinkTransform
PTransform<PCollection<ErrorT>,
OutputT extends POutput> sinkTransform
-
-
-
Class org.apache.beam.sdk.transforms.errorhandling.ErrorHandler.PTransformErrorHandler.WriteErrorMetrics
class WriteErrorMetrics extends PTransform<PCollection<ErrorT>,PCollection<ErrorT>> implements Serializable -
Serialized Fields
-
errorCounter
Counter errorCounter
-
-
-
Class org.apache.beam.sdk.transforms.errorhandling.ErrorHandler.PTransformErrorHandler.WriteErrorMetrics.CountErrors
-
Serialized Fields
-
errorCounter
Counter errorCounter
-
-
-
Class org.apache.beam.sdk.transforms.errorhandling.ErrorHandlerTest.DummySinkTransform
-
Class org.apache.beam.sdk.transforms.errorhandling.ErrorHandlingTestUtils.EchoErrorTransform
class EchoErrorTransform extends PTransform<PCollection<BadRecord>,PCollection<BadRecord>> implements Serializable -
Class org.apache.beam.sdk.transforms.errorhandling.ErrorHandlingTestUtils.ErrorSinkTransform
class ErrorSinkTransform extends PTransform<PCollection<BadRecord>,PCollection<Long>> implements Serializable
-
-
Package org.apache.beam.sdk.transforms.join
-
Class org.apache.beam.sdk.transforms.join.CoGbkResult.CoGbkResultCoder
-
Serialized Fields
-
schema
CoGbkResultSchema schema
-
unionCoder
UnionCoder unionCoder
-
-
-
Class org.apache.beam.sdk.transforms.join.CoGbkResultSchema
class CoGbkResultSchema extends Object implements Serializable-
Serialized Fields
-
tagMap
HashMap<TupleTag<?>,
Integer> tagMap Maps TupleTags to union tags. This avoids needing to encode the tags themselves. -
tupleTagList
TupleTagList tupleTagList
-
-
-
Class org.apache.beam.sdk.transforms.join.CoGroupByKey
class CoGroupByKey extends PTransform<KeyedPCollectionTuple<K>,PCollection<KV<K, CoGbkResult>>> implements Serializable -
Class org.apache.beam.sdk.transforms.join.CoGroupByKeyTest
class CoGroupByKeyTest extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.join.UnionCoder
-
-
Package org.apache.beam.sdk.transforms.resourcehints
-
Class org.apache.beam.sdk.transforms.resourcehints.ResourceHintsTest
class ResourceHintsTest extends Object implements Serializable-
Serialized Fields
-
thrown
ExpectedException thrown
-
-
-
-
Package org.apache.beam.sdk.transforms.windowing
-
Class org.apache.beam.sdk.transforms.windowing.AfterAll
class AfterAll extends Trigger.OnceTrigger implements Serializable -
Class org.apache.beam.sdk.transforms.windowing.AfterEach
class AfterEach extends Trigger implements Serializable -
Class org.apache.beam.sdk.transforms.windowing.AfterFirst
class AfterFirst extends Trigger.OnceTrigger implements Serializable -
Class org.apache.beam.sdk.transforms.windowing.AfterPane
class AfterPane extends Trigger.OnceTrigger implements Serializable-
Serialized Fields
-
countElems
int countElems
-
-
-
Class org.apache.beam.sdk.transforms.windowing.AfterProcessingTime
class AfterProcessingTime extends Trigger.OnceTrigger implements Serializable-
Serialized Fields
-
timestampTransforms
List<TimestampTransform> timestampTransforms
-
-
-
Class org.apache.beam.sdk.transforms.windowing.AfterSynchronizedProcessingTime
class AfterSynchronizedProcessingTime extends Trigger.OnceTrigger implements Serializable -
Class org.apache.beam.sdk.transforms.windowing.AfterWatermark.AfterWatermarkEarlyAndLate
class AfterWatermarkEarlyAndLate extends Trigger implements Serializable-
Serialized Fields
-
earlyTrigger
Trigger.OnceTrigger earlyTrigger
-
lateTrigger
@Nullable Trigger.OnceTrigger lateTrigger
-
-
-
Class org.apache.beam.sdk.transforms.windowing.AfterWatermark.FromEndOfWindow
class FromEndOfWindow extends Trigger.OnceTrigger implements Serializable -
Class org.apache.beam.sdk.transforms.windowing.CalendarWindows.DaysWindows
-
Serialized Fields
-
number
int number
-
startDate
DateTime startDate
-
timeZone
DateTimeZone timeZone
-
-
-
Class org.apache.beam.sdk.transforms.windowing.CalendarWindows.MonthsWindows
-
Serialized Fields
-
dayOfMonth
int dayOfMonth
-
number
int number
-
startDate
DateTime startDate
-
timeZone
DateTimeZone timeZone
-
-
-
Class org.apache.beam.sdk.transforms.windowing.CalendarWindows.YearsWindows
-
Serialized Fields
-
dayOfMonth
int dayOfMonth
-
monthOfYear
int monthOfYear
-
number
int number
-
startDate
DateTime startDate
-
timeZone
DateTimeZone timeZone
-
-
-
Class org.apache.beam.sdk.transforms.windowing.DefaultTrigger
class DefaultTrigger extends Trigger implements Serializable -
Class org.apache.beam.sdk.transforms.windowing.FixedWindows
-
Class org.apache.beam.sdk.transforms.windowing.GlobalWindow.Coder
-
Class org.apache.beam.sdk.transforms.windowing.GlobalWindows
-
Exception Class org.apache.beam.sdk.transforms.windowing.IncompatibleWindowException
class IncompatibleWindowException extends Exception implements Serializable -
Class org.apache.beam.sdk.transforms.windowing.IntervalWindow.IntervalWindowCoder
-
Class org.apache.beam.sdk.transforms.windowing.Never.NeverTrigger
class NeverTrigger extends Trigger.OnceTrigger implements Serializable -
Class org.apache.beam.sdk.transforms.windowing.NonMergingWindowFn
-
Class org.apache.beam.sdk.transforms.windowing.OrFinallyTrigger
class OrFinallyTrigger extends Trigger implements Serializable -
Class org.apache.beam.sdk.transforms.windowing.PaneInfo.PaneInfoCoder
-
Class org.apache.beam.sdk.transforms.windowing.PartitioningWindowFn
class PartitioningWindowFn extends NonMergingWindowFn<T,W extends BoundedWindow> implements Serializable -
Class org.apache.beam.sdk.transforms.windowing.Repeatedly
class Repeatedly extends Trigger implements Serializable-
Serialized Fields
-
repeatedTrigger
Trigger repeatedTrigger
-
-
-
Class org.apache.beam.sdk.transforms.windowing.ReshuffleTrigger
class ReshuffleTrigger extends Trigger implements Serializable -
Class org.apache.beam.sdk.transforms.windowing.Sessions
-
Serialized Fields
-
gapDuration
Duration gapDuration
Duration of the gaps between sessions.
-
-
-
Class org.apache.beam.sdk.transforms.windowing.SlidingWindows
-
Class org.apache.beam.sdk.transforms.windowing.TimestampTransform
class TimestampTransform extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.windowing.TimestampTransform.AlignTo
class AlignTo extends TimestampTransform implements Serializable -
Class org.apache.beam.sdk.transforms.windowing.TimestampTransform.Delay
class Delay extends TimestampTransform implements Serializable -
Class org.apache.beam.sdk.transforms.windowing.Trigger
class Trigger extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.windowing.Trigger.OnceTrigger
class OnceTrigger extends Trigger implements Serializable -
Class org.apache.beam.sdk.transforms.windowing.Window
-
Class org.apache.beam.sdk.transforms.windowing.Window.Assign
-
Serialized Fields
-
original
@Nullable Window<T> original
-
updatedStrategy
WindowingStrategy<T,
?> updatedStrategy
-
-
-
Class org.apache.beam.sdk.transforms.windowing.WindowFn
class WindowFn extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.windowing.WindowingTest
class WindowingTest extends Object implements Serializable -
Class org.apache.beam.sdk.transforms.windowing.WindowMappingFn
class WindowMappingFn extends Object implements Serializable-
Serialized Fields
-
maximumLookback
Duration maximumLookback
-
-
-
Class org.apache.beam.sdk.transforms.windowing.WindowTest
class WindowTest extends Object implements Serializable
-
-
Package org.apache.beam.sdk.values
-
Class org.apache.beam.sdk.values.EncodableThrowable
class EncodableThrowable extends Object implements Serializable-
Serialized Fields
-
throwable
Throwable throwable
-
-
-
Class org.apache.beam.sdk.values.FailsafeValueInSingleWindow.Coder
-
Class org.apache.beam.sdk.values.KV
class KV extends Object implements Serializable -
Class org.apache.beam.sdk.values.KV.OrderByKey
class OrderByKey extends Object implements Serializable -
Class org.apache.beam.sdk.values.KV.OrderByValue
class OrderByValue extends Object implements Serializable -
Class org.apache.beam.sdk.values.PCollectionRowTupleTest
class PCollectionRowTupleTest extends Object implements Serializable -
Class org.apache.beam.sdk.values.PCollectionTupleTest
class PCollectionTupleTest extends Object implements Serializable -
Class org.apache.beam.sdk.values.PCollectionViews.InMemoryListFromMultimapViewFn
class InMemoryListFromMultimapViewFn extends ViewFn<Materializations.MultimapView<Void,T>, List<T>> implements Serializable -
Serialized Fields
-
typeDescriptorSupplier
PCollectionViews.TypeDescriptorSupplier<T> typeDescriptorSupplier
-
-
-
Class org.apache.beam.sdk.values.PCollectionViews.InMemoryListViewFn
class InMemoryListViewFn extends ViewFn<Materializations.IterableView<T>,List<T>> implements Serializable -
Serialized Fields
-
typeDescriptorSupplier
PCollectionViews.TypeDescriptorSupplier<T> typeDescriptorSupplier
-
-
-
Class org.apache.beam.sdk.values.PCollectionViews.InMemoryMapFromVoidKeyViewFn
class InMemoryMapFromVoidKeyViewFn extends ViewFn<Materializations.MultimapView<Void,KV<K, V>>, Map<K, V>> implements Serializable -
Class org.apache.beam.sdk.values.PCollectionViews.InMemoryMapViewFn
class InMemoryMapViewFn extends ViewFn<Materializations.IterableView<KV<K,V>>, Map<K, V>> implements Serializable -
Class org.apache.beam.sdk.values.PCollectionViews.InMemoryMultimapFromVoidKeyViewFn
-
Class org.apache.beam.sdk.values.PCollectionViews.InMemoryMultimapViewFn
class InMemoryMultimapViewFn extends ViewFn<Materializations.IterableView<KV<K,V>>, Map<K, Iterable<V>>> implements Serializable -
Class org.apache.beam.sdk.values.PCollectionViews.IterableBackedListViewFn
class IterableBackedListViewFn extends ViewFn<Materializations.IterableView<T>,List<T>> implements Serializable -
Serialized Fields
-
typeDescriptorSupplier
PCollectionViews.TypeDescriptorSupplier<T> typeDescriptorSupplier
-
-
-
Class org.apache.beam.sdk.values.PCollectionViews.IterableViewFn
class IterableViewFn extends ViewFn<Materializations.MultimapView<Void,T>, Iterable<T>> implements Serializable -
Serialized Fields
-
typeDescriptorSupplier
PCollectionViews.TypeDescriptorSupplier<T> typeDescriptorSupplier
Deprecated.
-
-
-
Class org.apache.beam.sdk.values.PCollectionViews.IterableViewFn2
class IterableViewFn2 extends ViewFn<Materializations.IterableView<T>,Iterable<T>> implements Serializable -
Serialized Fields
-
typeDescriptorSupplier
PCollectionViews.TypeDescriptorSupplier<T> typeDescriptorSupplier
-
-
-
Class org.apache.beam.sdk.values.PCollectionViews.ListViewFn
class ListViewFn extends ViewFn<Materializations.MultimapView<Void,T>, List<T>> implements Serializable -
Serialized Fields
-
typeDescriptorSupplier
PCollectionViews.TypeDescriptorSupplier<T> typeDescriptorSupplier
Deprecated.
-
-
-
Class org.apache.beam.sdk.values.PCollectionViews.ListViewFn2
class ListViewFn2 extends ViewFn<Materializations.MultimapView<Long,PCollectionViews.ValueOrMetadata<T, OffsetRange>>, List<T>> implements Serializable -
Serialized Fields
-
typeDescriptorSupplier
PCollectionViews.TypeDescriptorSupplier<T> typeDescriptorSupplier
-
-
-
Class org.apache.beam.sdk.values.PCollectionViews.MapViewFn
class MapViewFn extends ViewFn<Materializations.MultimapView<Void,KV<K, V>>, Map<K, V>> implements Serializable -
Serialized Fields
-
keyTypeDescriptorSupplier
PCollectionViews.TypeDescriptorSupplier<K> keyTypeDescriptorSupplier
Deprecated. -
valueTypeDescriptorSupplier
PCollectionViews.TypeDescriptorSupplier<V> valueTypeDescriptorSupplier
Deprecated.
-
-
-
Class org.apache.beam.sdk.values.PCollectionViews.MapViewFn2
class MapViewFn2 extends ViewFn<Materializations.MultimapView<K,V>, Map<K, V>> implements Serializable -
Serialized Fields
-
keyTypeDescriptorSupplier
PCollectionViews.TypeDescriptorSupplier<K> keyTypeDescriptorSupplier
-
valueTypeDescriptorSupplier
PCollectionViews.TypeDescriptorSupplier<V> valueTypeDescriptorSupplier
-
-
-
Class org.apache.beam.sdk.values.PCollectionViews.MultimapViewFn
class MultimapViewFn extends ViewFn<Materializations.MultimapView<Void,KV<K, V>>, Map<K, Iterable<V>>> implements Serializable -
Serialized Fields
-
keyTypeDescriptorSupplier
PCollectionViews.TypeDescriptorSupplier<K> keyTypeDescriptorSupplier
Deprecated. -
valueTypeDescriptorSupplier
PCollectionViews.TypeDescriptorSupplier<V> valueTypeDescriptorSupplier
Deprecated.
-
-
-
Class org.apache.beam.sdk.values.PCollectionViews.MultimapViewFn2
class MultimapViewFn2 extends ViewFn<Materializations.MultimapView<K,V>, Map<K, Iterable<V>>> implements Serializable -
Serialized Fields
-
keyTypeDescriptorSupplier
PCollectionViews.TypeDescriptorSupplier<K> keyTypeDescriptorSupplier
-
valueTypeDescriptorSupplier
PCollectionViews.TypeDescriptorSupplier<V> valueTypeDescriptorSupplier
-
-
-
Class org.apache.beam.sdk.values.PCollectionViews.SimplePCollectionView
class SimplePCollectionView extends PValueBase implements Serializable-
Serialized Fields
-
coder
@Nullable Coder<ElemT> coder
The coder for the elements underlying the view. -
tag
TupleTag<PrimitiveViewT> tag
A unique tag for the view, typed according to the elements underlying the view. -
viewFn
ViewFn<PrimitiveViewT,
ViewT> viewFn The typedViewFn
for this view. -
windowingStrategy
WindowingStrategy<?,
W extends BoundedWindow> windowingStrategy The windowing strategy for the PCollection underlying the view. -
windowMappingFn
WindowMappingFn<W extends BoundedWindow> windowMappingFn
-
-
-
Class org.apache.beam.sdk.values.PCollectionViews.SingletonViewFn
class SingletonViewFn extends ViewFn<Materializations.MultimapView<Void,T>, T> implements Serializable -
Class org.apache.beam.sdk.values.PCollectionViews.SingletonViewFn2
-
Class org.apache.beam.sdk.values.PCollectionViews.ValueOrMetadataCoder
class ValueOrMetadataCoder extends StructuredCoder<PCollectionViews.ValueOrMetadata<T,MetaT>> implements Serializable -
Class org.apache.beam.sdk.values.Row
class Row extends Object implements Serializable-
Serialized Fields
-
schema
Schema schema
-
-
-
Class org.apache.beam.sdk.values.RowWithGetters
class RowWithGetters extends Row implements Serializable -
Class org.apache.beam.sdk.values.RowWithStorage
class RowWithStorage extends Row implements Serializable -
Class org.apache.beam.sdk.values.SchemaVerification
class SchemaVerification extends Object implements Serializable -
Class org.apache.beam.sdk.values.ShardedKey
class ShardedKey extends Object implements Serializable- serialVersionUID:
- 1L
-
Serialized Fields
-
key
K key
-
shardNumber
int shardNumber
-
-
Class org.apache.beam.sdk.values.TimestampedValue.TimestampedValueCoder
-
Class org.apache.beam.sdk.values.TupleTag
class TupleTag extends Object implements Serializable-
Serialized Fields
-
generated
boolean generated
-
id
String id
-
-
-
Class org.apache.beam.sdk.values.TupleTagList
class TupleTagList extends Object implements Serializable -
Class org.apache.beam.sdk.values.TypeDescriptor
class TypeDescriptor extends Object implements Serializable-
Serialized Fields
-
token
org.apache.beam.vendor.guava.v32_1_2_jre.com.google.common.reflect.TypeToken<T> token
-
-
-
Class org.apache.beam.sdk.values.ValueInSingleWindow.Coder
-
Serialized Fields
-
valueCoder
Coder<T> valueCoder
-
windowCoder
Coder<BoundedWindow> windowCoder
-
-
-
Class org.apache.beam.sdk.values.ValueWithRecordId.StripIdsDoFn
-
Class org.apache.beam.sdk.values.ValueWithRecordId.ValueWithRecordIdCoder
class ValueWithRecordIdCoder extends StructuredCoder<ValueWithRecordId<ValueT>> implements Serializable-
Serialized Fields
-
idCoder
ByteArrayCoder idCoder
-
valueCoder
Coder<ValueT> valueCoder
-
-
-
Class org.apache.beam.sdk.values.WindowedValues.FullWindowedValueCoder
-
Serialized Fields
-
windowCoder
Coder<? extends BoundedWindow> windowCoder
-
windowsCoder
Coder<Collection<? extends BoundedWindow>> windowsCoder
-
-
-
Class org.apache.beam.sdk.values.WindowedValues.ParamWindowedValueCoder
class ParamWindowedValueCoder extends WindowedValues.FullWindowedValueCoder<T> implements Serializable- serialVersionUID:
- 1L
-
Serialization Methods
-
readObject
- Throws:
IOException
ClassNotFoundException
-
writeObject
- Throws:
IOException
-
-
Class org.apache.beam.sdk.values.WindowedValues.ValueOnlyWindowedValueCoder
class ValueOnlyWindowedValueCoder extends WindowedValues.WindowedValueCoder<T> implements Serializable -
Class org.apache.beam.sdk.values.WindowedValues.WindowedValueCoder
-
Class org.apache.beam.sdk.values.WindowingStrategy
class WindowingStrategy extends Object implements Serializable-
Serialized Fields
-
allowedLateness
Duration allowedLateness
-
allowedLatenessSpecified
boolean allowedLatenessSpecified
-
alreadyMerged
boolean alreadyMerged
-
closingBehavior
Window.ClosingBehavior closingBehavior
-
environmentId
String environmentId
-
mode
WindowingStrategy.AccumulationMode mode
-
modeSpecified
boolean modeSpecified
-
onTimeBehavior
Window.OnTimeBehavior onTimeBehavior
-
timestampCombiner
TimestampCombiner timestampCombiner
-
timestampCombinerSpecified
boolean timestampCombinerSpecified
-
trigger
Trigger trigger
-
triggerSpecified
boolean triggerSpecified
-
windowFn
WindowFn<T,
W extends BoundedWindow> windowFn
-
-
-