Uses of Class
org.apache.flink.types.Either
-
-
Uses of Either in org.apache.flink.api.common.typeinfo
Methods in org.apache.flink.api.common.typeinfo that return types with arguments of type Either Modifier and Type Method Description static <L,R>
TypeInformation<Either<L,R>>Types. EITHER(TypeInformation<L> leftType, TypeInformation<R> rightType)
Returns type information for Flink'sEither
type. -
Uses of Either in org.apache.flink.api.java.typeutils
Methods in org.apache.flink.api.java.typeutils that return types with arguments of type Either Modifier and Type Method Description TypeSerializer<Either<L,R>>
EitherTypeInfo. createSerializer(SerializerConfig config)
TypeInformation<Either<L,R>>
EitherTypeInfoFactory. createTypeInfo(Type t, Map<String,TypeInformation<?>> genericParameters)
Class<Either<L,R>>
EitherTypeInfo. getTypeClass()
-
Uses of Either in org.apache.flink.api.java.typeutils.runtime
Methods in org.apache.flink.api.java.typeutils.runtime that return Either Modifier and Type Method Description Either<L,R>
EitherSerializer. copy(Either<L,R> from)
Either<L,R>
EitherSerializer. copy(Either<L,R> from, Either<L,R> reuse)
Either<L,R>
EitherSerializer. createInstance()
Either<L,R>
EitherSerializer. deserialize(DataInputView source)
Either<L,R>
EitherSerializer. deserialize(Either<L,R> reuse, DataInputView source)
Methods in org.apache.flink.api.java.typeutils.runtime that return types with arguments of type Either Modifier and Type Method Description TypeSerializer<Either<L,R>>
EitherSerializer. duplicate()
TypeSerializerSchemaCompatibility<Either<L,R>>
JavaEitherSerializerSnapshot. resolveSchemaCompatibility(TypeSerializerSnapshot<Either<L,R>> oldSerializerSnapshot)
Methods in org.apache.flink.api.java.typeutils.runtime with parameters of type Either Modifier and Type Method Description Either<L,R>
EitherSerializer. copy(Either<L,R> from)
Either<L,R>
EitherSerializer. copy(Either<L,R> from, Either<L,R> reuse)
Either<L,R>
EitherSerializer. deserialize(Either<L,R> reuse, DataInputView source)
void
EitherSerializer. serialize(Either<L,R> record, DataOutputView target)
Method parameters in org.apache.flink.api.java.typeutils.runtime with type arguments of type Either Modifier and Type Method Description TypeSerializerSchemaCompatibility<Either<L,R>>
JavaEitherSerializerSnapshot. resolveSchemaCompatibility(TypeSerializerSnapshot<Either<L,R>> oldSerializerSnapshot)
-
Uses of Either in org.apache.flink.connector.file.sink.compactor.operator
Methods in org.apache.flink.connector.file.sink.compactor.operator with type parameters of type Either Modifier and Type Method Description <T extends StreamOperator<Either<CommittableMessage<FileSinkCommittable>,CompactorRequest>>>
TCompactCoordinatorStateHandlerFactory. createStreamOperator(StreamOperatorParameters<Either<CommittableMessage<FileSinkCommittable>,CompactorRequest>> parameters)
Method parameters in org.apache.flink.connector.file.sink.compactor.operator with type arguments of type Either Modifier and Type Method Description <T extends StreamOperator<Either<CommittableMessage<FileSinkCommittable>,CompactorRequest>>>
TCompactCoordinatorStateHandlerFactory. createStreamOperator(StreamOperatorParameters<Either<CommittableMessage<FileSinkCommittable>,CompactorRequest>> parameters)
void
CompactorOperatorStateHandler. processElement(StreamRecord<Either<CommittableMessage<FileSinkCommittable>,CompactorRequest>> element)
Constructor parameters in org.apache.flink.connector.file.sink.compactor.operator with type arguments of type Either Constructor Description CompactCoordinatorStateHandler(StreamOperatorParameters<Either<CommittableMessage<FileSinkCommittable>,CompactorRequest>> parameters, SimpleVersionedSerializer<FileSinkCommittable> committableSerializer)
-
Uses of Either in org.apache.flink.runtime.blob
Methods in org.apache.flink.runtime.blob that return Either Modifier and Type Method Description static <T> Either<SerializedValue<T>,PermanentBlobKey>
BlobWriter. offloadWithException(SerializedValue<T> serializedValue, JobID jobId, BlobWriter blobWriter)
static <T> Either<SerializedValue<T>,PermanentBlobKey>
BlobWriter. serializeAndTryOffload(T value, JobID jobId, BlobWriter blobWriter)
Serializes the given value and offloads it to the BlobServer if its size exceeds the minimum offloading size of the BlobServer.static <T> Either<SerializedValue<T>,PermanentBlobKey>
BlobWriter. tryOffload(SerializedValue<T> serializedValue, JobID jobId, BlobWriter blobWriter)
-
Uses of Either in org.apache.flink.runtime.deployment
Constructors in org.apache.flink.runtime.deployment with parameters of type Either Constructor Description TaskDeploymentDescriptorFactory(Either<SerializedValue<JobInformation>,PermanentBlobKey> jobInformationOrBlobKey, JobID jobID, TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionDeploymentConstraint, BlobWriter blobWriter, boolean nonFinishedHybridPartitionShouldBeUnknown, int offloadShuffleDescriptorsThreshold)
-
Uses of Either in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph that return Either Modifier and Type Method Description Either<SerializedValue<TaskInformation>,PermanentBlobKey>
ExecutionJobVertex. getTaskInformationOrBlobKey()
-
Uses of Either in org.apache.flink.runtime.io.network.partition
Methods in org.apache.flink.runtime.io.network.partition that return Either Modifier and Type Method Description Either<ExecutionState,Throwable>
PartitionProducerStateProvider.ResponseHandle. getProducerExecutionState()
-
Uses of Either in org.apache.flink.types
Subclasses of Either in org.apache.flink.types Modifier and Type Class Description static class
Either.Left<L,R>
A left value ofEither
static class
Either.Right<L,R>
A right value ofEither
Methods in org.apache.flink.types that return Either Modifier and Type Method Description static <L,R>
Either<L,R>Either. Left(L value)
Create a Left value of Eitherstatic <L,R>
Either<L,R>Either. Right(R value)
Create a Right value of EitherMethods in org.apache.flink.types with parameters of type Either Modifier and Type Method Description static <L,R>
Either.Left<L,R>Either. obtainLeft(Either<L,R> input, TypeSerializer<L> leftSerializer)
Utility function forEitherSerializer
to support object reuse.static <L,R>
Either.Right<L,R>Either. obtainRight(Either<L,R> input, TypeSerializer<R> rightSerializer)
Utility function forEitherSerializer
to support object reuse.
-