类分层结构
- java.lang.Object
- org.apache.flink.streaming.api.runners.python.beam.state.AbstractBeamStateHandler<S> (implements org.apache.flink.streaming.api.runners.python.beam.state.BeamStateHandler<S>)
- com.google.protobuf.AbstractMessageLite<MessageType,BuilderType> (implements com.google.protobuf.MessageLite)
- com.google.protobuf.AbstractMessage (implements com.google.protobuf.Message)
- com.google.protobuf.GeneratedMessageV3 (implements java.io.Serializable)
- com.google.protobuf.AbstractMessageLite.Builder<MessageType,BuilderType> (implements com.google.protobuf.MessageLite.Builder)
- com.google.protobuf.AbstractMessage.Builder<BuilderType> (implements com.google.protobuf.Message.Builder)
- com.google.protobuf.GeneratedMessageV3.Builder<BuilderType>
- org.apache.flink.python.env.AbstractPythonEnvironmentManager (implements org.apache.flink.python.env.PythonEnvironmentManager)
- org.apache.flink.python.env.AbstractPythonEnvironmentManager.PythonLeasedResource (implements java.lang.AutoCloseable)
- org.apache.flink.api.common.functions.AbstractRichFunction (implements org.apache.flink.api.common.functions.RichFunction, java.io.Serializable)
- org.apache.flink.streaming.api.functions.ProcessFunction<I,O>
- org.apache.flink.streaming.api.functions.source.RichParallelSourceFunction<OUT> (implements org.apache.flink.streaming.api.functions.source.ParallelSourceFunction<OUT>)
- org.apache.flink.table.runtime.arrow.sources.ArrowSourceFunction (implements org.apache.flink.streaming.api.checkpoint.CheckpointedFunction, org.apache.flink.api.java.typeutils.ResultTypeQueryable<T>)
- org.apache.flink.streaming.api.operators.AbstractStreamOperator<OUT> (implements org.apache.flink.streaming.api.operators.KeyContextHandler, java.io.Serializable, org.apache.flink.streaming.api.operators.SetupableStreamOperator<OUT>, org.apache.flink.streaming.api.operators.StreamOperator<OUT>, org.apache.flink.streaming.api.operators.StreamOperatorStateHandler.CheckpointedStreamOperator, org.apache.flink.streaming.api.operators.YieldingOperator<OUT>)
- org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator<OUT>
- org.apache.flink.streaming.api.operators.python.embedded.AbstractEmbeddedPythonFunctionOperator<OUT>
- org.apache.flink.streaming.api.operators.python.embedded.AbstractEmbeddedDataStreamPythonFunctionOperator<OUT> (implements org.apache.flink.streaming.api.operators.python.DataStreamPythonFunctionOperator<OUT>)
- org.apache.flink.streaming.api.operators.python.embedded.AbstractOneInputEmbeddedPythonFunctionOperator<IN,OUT> (implements org.apache.flink.streaming.api.operators.BoundedOneInput, org.apache.flink.streaming.api.operators.OneInputStreamOperator<IN,OUT>)
- org.apache.flink.streaming.api.operators.python.embedded.AbstractTwoInputEmbeddedPythonFunctionOperator<IN1,IN2,OUT> (implements org.apache.flink.streaming.api.operators.BoundedMultiInput, org.apache.flink.streaming.api.operators.TwoInputStreamOperator<IN1,IN2,OUT>)
- org.apache.flink.table.runtime.operators.python.AbstractEmbeddedStatelessFunctionOperator (implements org.apache.flink.streaming.api.operators.BoundedOneInput, org.apache.flink.streaming.api.operators.OneInputStreamOperator<IN,OUT>)
- org.apache.flink.streaming.api.operators.python.process.AbstractExternalPythonFunctionOperator<OUT>
- org.apache.flink.streaming.api.operators.python.process.AbstractExternalDataStreamPythonFunctionOperator<OUT> (implements org.apache.flink.streaming.api.operators.python.DataStreamPythonFunctionOperator<OUT>)
- org.apache.flink.streaming.api.operators.python.process.AbstractExternalOneInputPythonFunctionOperator<IN,OUT> (implements org.apache.flink.streaming.api.operators.BoundedOneInput, org.apache.flink.streaming.api.operators.OneInputStreamOperator<IN,OUT>)
- org.apache.flink.streaming.api.operators.python.process.AbstractExternalTwoInputPythonFunctionOperator<IN1,IN2,OUT> (implements org.apache.flink.streaming.api.operators.BoundedMultiInput, org.apache.flink.streaming.api.operators.TwoInputStreamOperator<IN1,IN2,OUT>)
- org.apache.flink.table.runtime.operators.python.AbstractOneInputPythonFunctionOperator<IN,OUT> (implements org.apache.flink.streaming.api.operators.BoundedOneInput, org.apache.flink.streaming.api.operators.OneInputStreamOperator<IN,OUT>)
- org.apache.flink.streaming.api.transformations.python.DelegateOperatorTransformation.DelegateOperator<OUT> (implements org.apache.flink.streaming.api.operators.python.DataStreamPythonFunctionOperator<OUT>)
- net.razorvine.pickle.objects.ArrayConstructor (implements net.razorvine.pickle.IObjectConstructor)
- org.apache.flink.table.runtime.typeutils.serializers.python.ArrayDataSerializer.ArrayDataSerializerSnapshot (implements org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<T>)
- org.apache.flink.table.runtime.arrow.vectors.ArrowArrayColumnVector (implements org.apache.flink.table.data.columnar.vector.ArrayColumnVector)
- org.apache.flink.table.runtime.arrow.vectors.ArrowBigIntColumnVector (implements org.apache.flink.table.data.columnar.vector.LongColumnVector)
- org.apache.flink.table.runtime.arrow.vectors.ArrowBinaryColumnVector (implements org.apache.flink.table.data.columnar.vector.BytesColumnVector)
- org.apache.flink.table.runtime.arrow.vectors.ArrowBooleanColumnVector (implements org.apache.flink.table.data.columnar.vector.BooleanColumnVector)
- org.apache.flink.table.runtime.arrow.vectors.ArrowDateColumnVector (implements org.apache.flink.table.data.columnar.vector.IntColumnVector)
- org.apache.flink.table.runtime.arrow.vectors.ArrowDecimalColumnVector (implements org.apache.flink.table.data.columnar.vector.DecimalColumnVector)
- org.apache.flink.table.runtime.arrow.vectors.ArrowDoubleColumnVector (implements org.apache.flink.table.data.columnar.vector.DoubleColumnVector)
- org.apache.flink.table.runtime.arrow.writers.ArrowFieldWriter<IN>
- org.apache.flink.table.runtime.arrow.writers.ArrayWriter<T>
- org.apache.flink.table.runtime.arrow.writers.BigIntWriter<T>
- org.apache.flink.table.runtime.arrow.writers.BinaryWriter<T>
- org.apache.flink.table.runtime.arrow.writers.BooleanWriter<T>
- org.apache.flink.table.runtime.arrow.writers.DateWriter<T>
- org.apache.flink.table.runtime.arrow.writers.DecimalWriter<T>
- org.apache.flink.table.runtime.arrow.writers.DoubleWriter<T>
- org.apache.flink.table.runtime.arrow.writers.FloatWriter<T>
- org.apache.flink.table.runtime.arrow.writers.IntWriter<T>
- org.apache.flink.table.runtime.arrow.writers.MapWriter<T>
- org.apache.flink.table.runtime.arrow.writers.NullWriter<T>
- org.apache.flink.table.runtime.arrow.writers.RowWriter<T>
- org.apache.flink.table.runtime.arrow.writers.SmallIntWriter<T>
- org.apache.flink.table.runtime.arrow.writers.TimestampWriter<T>
- org.apache.flink.table.runtime.arrow.writers.TimeWriter<T>
- org.apache.flink.table.runtime.arrow.writers.TinyIntWriter<T>
- org.apache.flink.table.runtime.arrow.writers.VarBinaryWriter<T>
- org.apache.flink.table.runtime.arrow.writers.VarCharWriter<T>
- org.apache.flink.table.runtime.arrow.vectors.ArrowFloatColumnVector (implements org.apache.flink.table.data.columnar.vector.FloatColumnVector)
- org.apache.flink.table.runtime.arrow.vectors.ArrowIntColumnVector (implements org.apache.flink.table.data.columnar.vector.IntColumnVector)
- org.apache.flink.table.runtime.arrow.vectors.ArrowMapColumnVector (implements org.apache.flink.table.data.columnar.vector.MapColumnVector)
- org.apache.flink.table.runtime.arrow.vectors.ArrowNullColumnVector (implements org.apache.flink.table.data.columnar.vector.ColumnVector)
- org.apache.flink.table.runtime.arrow.ArrowReader
- org.apache.flink.table.runtime.arrow.vectors.ArrowRowColumnVector (implements org.apache.flink.table.data.columnar.vector.RowColumnVector)
- org.apache.flink.table.runtime.arrow.serializers.ArrowSerializer
- org.apache.flink.table.runtime.arrow.vectors.ArrowSmallIntColumnVector (implements org.apache.flink.table.data.columnar.vector.ShortColumnVector)
- org.apache.flink.table.runtime.arrow.sources.ArrowTableSource (implements org.apache.flink.table.sources.StreamTableSource<T>)
- org.apache.flink.table.runtime.arrow.vectors.ArrowTimeColumnVector (implements org.apache.flink.table.data.columnar.vector.IntColumnVector)
- org.apache.flink.table.runtime.arrow.vectors.ArrowTimestampColumnVector (implements org.apache.flink.table.data.columnar.vector.TimestampColumnVector)
- org.apache.flink.table.runtime.arrow.vectors.ArrowTinyIntColumnVector (implements org.apache.flink.table.data.columnar.vector.ByteColumnVector)
- org.apache.flink.table.runtime.arrow.ArrowUtils
- org.apache.flink.table.runtime.arrow.vectors.ArrowVarBinaryColumnVector (implements org.apache.flink.table.data.columnar.vector.BytesColumnVector)
- org.apache.flink.table.runtime.arrow.vectors.ArrowVarCharColumnVector (implements org.apache.flink.table.data.columnar.vector.BytesColumnVector)
- org.apache.flink.table.runtime.arrow.ArrowWriter<IN>
- org.apache.beam.model.fnexecution.v1.BeamFnStateGrpc.BeamFnStateImplBase (implements org.apache.beam.vendor.grpc.v1p48p1.io.grpc.BindableService)
- org.apache.beam.runners.fnexecution.state.GrpcStateService (implements org.apache.beam.sdk.fn.server.FnService, org.apache.beam.runners.fnexecution.state.StateDelegator)
- org.apache.flink.streaming.api.runners.python.beam.state.BeamKeyedStateStore (implements org.apache.flink.streaming.api.runners.python.beam.state.BeamStateStore)
- org.apache.flink.streaming.api.runners.python.beam.state.BeamOperatorStateStore (implements org.apache.flink.streaming.api.runners.python.beam.state.BeamStateStore)
- org.apache.flink.streaming.api.runners.python.beam.BeamPythonFunctionRunner (implements org.apache.flink.python.PythonFunctionRunner)
- org.apache.flink.streaming.api.runners.python.beam.state.BeamStateRequestHandler (implements org.apache.beam.runners.fnexecution.state.StateRequestHandler)
- net.razorvine.pickle.objects.ByteArrayConstructor (implements net.razorvine.pickle.IObjectConstructor)
- org.apache.flink.streaming.api.utils.ByteArrayWrapper (implements java.io.Serializable)
- org.apache.flink.table.executor.python.ChainingOptimizingExecutor (implements org.apache.flink.table.delegation.Executor)
- org.apache.flink.streaming.api.utils.ClassLeakCleaner
- org.apache.flink.client.cli.CommandLineOptions
- org.apache.flink.client.cli.ProgramOptions
- org.apache.flink.python.util.CompressionUtils
- org.apache.flink.python.Constants
- org.apache.flink.streaming.api.functions.python.eventtime.CustomTimestampAssigner<T> (implements org.apache.flink.api.common.eventtime.SerializableTimestampAssigner<T>)
- org.apache.flink.streaming.api.functions.python.DataStreamPythonFunction (implements org.apache.flink.table.functions.python.PythonFunction)
- org.apache.flink.table.runtime.typeutils.serializers.python.DecimalDataSerializer.DecimalSerializerSnapshot (implements org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<T>)
- org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory (implements org.apache.beam.runners.fnexecution.control.JobBundleFactory)
- org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory.ServerInfo
- org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory.WrappedSdkHarnessClient
- org.apache.flink.python.env.embedded.EmbeddedPythonEnvironment (implements org.apache.flink.python.env.PythonEnvironment)
- org.apache.flink.fnexecution.v1.FlinkFnApi
- org.apache.flink.python.metric.process.FlinkMetricContainer
- org.apache.flink.python.metric.process.FlinkMetricContainer.FlinkDistributionGauge (implements org.apache.flink.metrics.Gauge<T>)
- org.apache.flink.python.metric.process.FlinkMetricContainer.FlinkGauge (implements org.apache.flink.metrics.Gauge<T>)
- org.apache.flink.python.util.HashMapWrapper
- org.apache.flink.streaming.api.functions.python.KeyByKeySelector (implements org.apache.flink.api.java.functions.KeySelector<IN,KEY>)
- org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor<R> (implements org.apache.flink.table.types.logical.LogicalTypeVisitor<R>)
- org.apache.flink.table.runtime.typeutils.serializers.python.MapDataSerializer.BaseMapSerializerSnapshot (implements org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<T>)
- org.apache.flink.python.metric.embedded.MetricDistribution (implements org.apache.flink.metrics.Gauge<T>)
- org.apache.flink.python.metric.embedded.MetricGauge (implements org.apache.flink.metrics.Gauge<T>)
- org.apache.flink.streaming.api.functions.python.PartitionCustomKeySelector (implements org.apache.flink.api.java.functions.KeySelector<IN,KEY>)
- org.apache.flink.python.env.process.ProcessPythonEnvironment (implements org.apache.flink.python.env.PythonEnvironment)
- org.apache.flink.api.common.python.PythonBridgeUtils
- org.apache.flink.python.PythonConfig (implements org.apache.flink.configuration.ReadableConfig)
- org.apache.flink.python.util.PythonConfigUtil
- org.apache.flink.python.util.PythonConnectorUtils
- org.apache.flink.python.util.PythonConnectorUtils.FirstColumnTopicSelectorInvocationHandler (implements java.lang.reflect.InvocationHandler, java.io.Serializable)
- org.apache.flink.python.util.PythonConnectorUtils.SecondColumnSerializationSchema<T> (implements org.apache.flink.api.common.serialization.SerializationSchema<T>)
- org.apache.flink.formats.csv.PythonCsvUtils
- org.apache.flink.python.env.PythonDependencyInfo
- org.apache.flink.python.util.PythonDependencyUtils
- org.apache.flink.client.python.PythonDriver
- org.apache.flink.table.utils.python.PythonDynamicTableFactory (implements org.apache.flink.table.factories.DynamicTableSourceFactory)
- org.apache.flink.table.utils.python.PythonDynamicTableOptions
- org.apache.flink.table.utils.python.PythonDynamicTableSource (implements org.apache.flink.table.connector.source.ScanTableSource)
- org.apache.flink.python.util.PythonEnvironmentManagerUtils
- org.apache.flink.client.python.PythonFunctionFactory.CacheKey
- org.apache.flink.client.python.PythonFunctionFactoryImpl (implements java.io.Closeable, org.apache.flink.client.python.PythonFunctionFactory)
- org.apache.flink.table.functions.python.PythonFunctionInfo (implements java.io.Serializable)
- org.apache.flink.client.python.PythonGatewayServer
- org.apache.flink.python.chain.PythonOperatorChainingOptimizer
- org.apache.flink.streaming.api.utils.PythonOperatorUtils
- org.apache.flink.python.PythonOptions
- org.apache.flink.streaming.api.runners.python.beam.PythonSharedResources (implements java.lang.AutoCloseable)
- org.apache.flink.client.python.PythonShellParser
- org.apache.flink.table.utils.python.PythonTableUtils
- org.apache.flink.streaming.api.utils.PythonTypeUtils
- org.apache.flink.table.runtime.typeutils.PythonTypeUtils
- org.apache.flink.streaming.api.utils.PythonTypeUtils.DataConverter<IN,OUT> (implements java.io.Serializable)
- org.apache.flink.table.runtime.typeutils.PythonTypeUtils.DataConverter<IN,INTER,OUT> (implements java.io.Serializable)
- org.apache.flink.streaming.api.utils.PythonTypeUtils.TypeInfoToDataConverter
- org.apache.flink.streaming.api.utils.PythonTypeUtils.TypeInfoToProtoConverter
- org.apache.flink.streaming.api.utils.PythonTypeUtils.TypeInfoToSerializerConverter
- org.apache.flink.streaming.api.functions.python.eventtime.RemoveTimestampMapFunction<T> (implements org.apache.flink.api.common.functions.MapFunction<T,O>)
- org.apache.flink.table.runtime.typeutils.serializers.python.RowDataSerializer.RowDataSerializerSnapshot (implements org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<T>)
- org.apache.flink.streaming.api.operators.python.process.collector.RunnerOutputCollector<OUT> (implements org.apache.flink.util.Collector<T>)
- org.apache.beam.sdk.fn.server.ServerFactory
- org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SharedResourceHolder
- org.apache.flink.streaming.api.graph.SimpleTransformationTranslator<OUT,T> (implements org.apache.flink.streaming.api.graph.TransformationTranslator<OUT,T>)
- org.apache.flink.streaming.runtime.translators.AbstractTwoInputTransformationTranslator<IN1,IN2,OUT,OP>
- org.apache.flink.api.common.typeutils.SimpleTypeSerializerSnapshot<T> (implements org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<T>)
- org.apache.flink.table.runtime.operators.python.utils.StreamRecordRowDataWrappingCollector (implements org.apache.flink.util.Collector<T>)
- org.apache.flink.streaming.api.operators.python.process.timer.TimerHandler
- org.apache.flink.streaming.api.operators.python.process.timer.TimerRegistration
- org.apache.flink.streaming.api.operators.python.process.timer.TimerUtils
- org.apache.flink.table.runtime.typeutils.serializers.python.TimestampSerializer.TimestampSerializerSnapshot (implements org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<T>)
- org.apache.flink.api.dag.Transformation<T>
- org.apache.flink.streaming.api.transformations.PhysicalTransformation<T>
- org.apache.flink.streaming.api.transformations.AbstractBroadcastStateTransformation<IN1,IN2,OUT>
- org.apache.flink.api.common.typeinfo.TypeInformation<T> (implements java.io.Serializable)
- org.apache.flink.api.common.typeutils.TypeSerializer<T> (implements java.io.Serializable)
- org.apache.flink.table.runtime.typeutils.ArrayDataSerializer
- org.apache.flink.table.runtime.typeutils.serializers.python.DecimalDataSerializer
- org.apache.flink.table.runtime.typeutils.MapDataSerializer
- org.apache.flink.table.runtime.typeutils.PagedTypeSerializer<T>
- org.apache.flink.table.runtime.typeutils.AbstractRowDataSerializer<T>
- org.apache.flink.table.runtime.typeutils.RowDataSerializer
- org.apache.flink.api.common.typeutils.base.TypeSerializerSingleton<T>
接口分层结构
枚举分层结构
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.