Modifier and Type | Method and Description |
---|---|
static <L,R> TypeInformation<Either<L,R>> |
Types.EITHER(TypeInformation<L> leftType,
TypeInformation<R> rightType)
Returns type information for Flink's
Either type. |
Modifier and Type | Method and Description |
---|---|
TypeSerializer<Either<L,R>> |
EitherTypeInfo.createSerializer(ExecutionConfig config) |
TypeInformation<Either<L,R>> |
EitherTypeInfoFactory.createTypeInfo(Type t,
Map<String,TypeInformation<?>> genericParameters) |
Class<Either<L,R>> |
EitherTypeInfo.getTypeClass() |
Modifier and Type | Method and 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) |
Modifier and Type | Method and Description |
---|---|
TypeSerializer<Either<L,R>> |
EitherSerializer.duplicate() |
TypeSerializerSchemaCompatibility<Either<L,R>> |
EitherSerializerSnapshot.resolveSchemaCompatibility(TypeSerializer<Either<L,R>> newSerializer)
Deprecated.
|
TypeSerializerSchemaCompatibility<Either<L,R>> |
EitherSerializerConfigSnapshot.resolveSchemaCompatibility(TypeSerializer<Either<L,R>> newSerializer)
Deprecated.
|
Modifier and Type | Method and 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.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) |
Modifier and Type | Method and Description |
---|---|
TypeSerializerSchemaCompatibility<Either<L,R>> |
EitherSerializerSnapshot.resolveSchemaCompatibility(TypeSerializer<Either<L,R>> newSerializer)
Deprecated.
|
TypeSerializerSchemaCompatibility<Either<L,R>> |
EitherSerializerConfigSnapshot.resolveSchemaCompatibility(TypeSerializer<Either<L,R>> newSerializer)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
Either<L,R> |
PatternStream.CoMapTimeout.map1(R value) |
Either<L,R> |
PatternStream.CoMapTimeout.map2(L value) |
Modifier and Type | Method and Description |
---|---|
<L,R> SingleOutputStreamOperator<Either<L,R>> |
PatternStream.flatSelect(PatternFlatTimeoutFunction<T,L> patternFlatTimeoutFunction,
PatternFlatSelectFunction<T,R> patternFlatSelectFunction)
Deprecated.
Use
PatternStream.flatSelect(OutputTag, PatternFlatTimeoutFunction, PatternFlatSelectFunction)
that returns timed out events as a side-output |
<L,R> SingleOutputStreamOperator<Either<L,R>> |
PatternStream.select(PatternTimeoutFunction<T,L> patternTimeoutFunction,
PatternSelectFunction<T,R> patternSelectFunction)
Deprecated.
Use
PatternStream.select(OutputTag, PatternTimeoutFunction, PatternSelectFunction)
that returns timed out events as a side-output |
Modifier and Type | Method and Description |
---|---|
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.
|
Modifier and Type | Method and Description |
---|---|
Either<SerializedValue<JobInformation>,PermanentBlobKey> |
ExecutionGraph.getJobInformationOrBlobKey() |
Either<SerializedValue<TaskInformation>,PermanentBlobKey> |
ExecutionJobVertex.getTaskInformationOrBlobKey() |
Modifier and Type | Method and Description |
---|---|
Either<ExecutionState,Throwable> |
PartitionProducerStateProvider.ResponseHandle.getProducerExecutionState() |
Modifier and Type | Class and Description |
---|---|
static class |
Either.Left<L,R>
A left value of
Either |
static class |
Either.Right<L,R>
A right value of
Either |
Modifier and Type | Method and Description |
---|---|
static <L,R> Either<L,R> |
Either.Left(L value)
Create a Left value of Either
|
static <L,R> Either<L,R> |
Either.Right(R value)
Create a Right value of Either
|
Modifier and Type | Method and Description |
---|---|
static <L,R> Either.Left<L,R> |
Either.obtainLeft(Either<L,R> input,
TypeSerializer<L> leftSerializer)
Utility function for
EitherSerializer to support object reuse. |
static <L,R> Either.Right<L,R> |
Either.obtainRight(Either<L,R> input,
TypeSerializer<R> rightSerializer)
Utility function for
EitherSerializer to support object reuse. |
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.