Uses of Class
org.apache.flink.util.SerializedValue
-
-
Uses of SerializedValue in org.apache.flink.api.common.accumulators
Method parameters in org.apache.flink.api.common.accumulators with type arguments of type SerializedValue Modifier and Type Method Description static Map<String,OptionalFailure<Object>>
AccumulatorHelper. deserializeAccumulators(Map<String,SerializedValue<OptionalFailure<Object>>> serializedAccumulators, ClassLoader loader)
Takes the serialized accumulator results and tries to deserialize them using the provided class loader.static Map<String,Object>
AccumulatorHelper. deserializeAndUnwrapAccumulators(Map<String,SerializedValue<OptionalFailure<Object>>> serializedAccumulators, ClassLoader loader)
Takes the serialized accumulator results and tries to deserialize them using the provided class loader, and then try to unwrap the value unchecked. -
Uses of SerializedValue in org.apache.flink.runtime.blob
Methods in org.apache.flink.runtime.blob that return types with arguments of type SerializedValue 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)
Methods in org.apache.flink.runtime.blob with parameters of type SerializedValue 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. tryOffload(SerializedValue<T> serializedValue, JobID jobId, BlobWriter blobWriter)
-
Uses of SerializedValue in org.apache.flink.runtime.checkpoint
Methods in org.apache.flink.runtime.checkpoint that return SerializedValue Modifier and Type Method Description static SerializedValue<TaskStateSnapshot>
TaskStateSnapshot. serializeTaskStateSnapshot(TaskStateSnapshot subtaskState)
Methods in org.apache.flink.runtime.checkpoint with parameters of type SerializedValue Modifier and Type Method Description void
CheckpointCoordinatorGateway. acknowledgeCheckpoint(JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointMetrics checkpointMetrics, SerializedValue<TaskStateSnapshot> subtaskState)
static TaskStateSnapshot
TaskStateSnapshot. deserializeTaskStateSnapshot(SerializedValue<TaskStateSnapshot> subtaskState, ClassLoader classLoader)
-
Uses of SerializedValue in org.apache.flink.runtime.client
Methods in org.apache.flink.runtime.client that return types with arguments of type SerializedValue Modifier and Type Method Description Map<String,SerializedValue<OptionalFailure<Object>>>
SerializedJobExecutionResult. getSerializedAccumulatorResults()
Constructor parameters in org.apache.flink.runtime.client with type arguments of type SerializedValue Constructor Description SerializedJobExecutionResult(JobID jobID, long netRuntime, Map<String,SerializedValue<OptionalFailure<Object>>> accumulators)
Creates a new SerializedJobExecutionResult. -
Uses of SerializedValue in org.apache.flink.runtime.deployment
Fields in org.apache.flink.runtime.deployment declared as SerializedValue Modifier and Type Field Description SerializedValue<T>
TaskDeploymentDescriptor.NonOffloaded. serializedValue
The serialized value.Constructors in org.apache.flink.runtime.deployment with parameters of type SerializedValue Constructor Description NonOffloaded(SerializedValue<T> serializedValue)
Constructor parameters in org.apache.flink.runtime.deployment with type arguments of type SerializedValue Constructor Description TaskDeploymentDescriptorFactory(Either<SerializedValue<JobInformation>,PermanentBlobKey> jobInformationOrBlobKey, JobID jobID, TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionDeploymentConstraint, BlobWriter blobWriter, boolean nonFinishedHybridPartitionShouldBeUnknown, int offloadShuffleDescriptorsThreshold)
-
Uses of SerializedValue in org.apache.flink.runtime.dispatcher
Methods in org.apache.flink.runtime.dispatcher with parameters of type SerializedValue Modifier and Type Method Description CompletableFuture<CoordinationResponse>
Dispatcher. deliverCoordinationRequestToCoordinator(JobID jobId, String operatorUid, SerializedValue<CoordinationRequest> serializedRequest, Duration timeout)
-
Uses of SerializedValue in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph that return SerializedValue Modifier and Type Method Description SerializedValue<ExecutionConfig>
JobInformation. getSerializedExecutionConfig()
Methods in org.apache.flink.runtime.executiongraph that return types with arguments of type SerializedValue Modifier and Type Method Description Map<String,SerializedValue<OptionalFailure<Object>>>
AccessExecutionGraph. getAccumulatorsSerialized()
Returns a map containing the serialized values of user-defined accumulators.Map<String,SerializedValue<OptionalFailure<Object>>>
ArchivedExecutionGraph. getAccumulatorsSerialized()
Map<String,SerializedValue<OptionalFailure<Object>>>
DefaultExecutionGraph. getAccumulatorsSerialized()
Gets a serialized accumulator map.Either<SerializedValue<TaskInformation>,PermanentBlobKey>
ExecutionJobVertex. getTaskInformationOrBlobKey()
Methods in org.apache.flink.runtime.executiongraph with parameters of type SerializedValue Modifier and Type Method Description protected OperatorCoordinatorHolder
ExecutionJobVertex. createOperatorCoordinatorHolder(SerializedValue<OperatorCoordinator.Provider> provider, ClassLoader classLoader, CoordinatorStore coordinatorStore, JobManagerJobMetricGroup jobManagerJobMetricGroup)
protected OperatorCoordinatorHolder
SpeculativeExecutionJobVertex. createOperatorCoordinatorHolder(SerializedValue<OperatorCoordinator.Provider> provider, ClassLoader classLoader, CoordinatorStore coordinatorStore, JobManagerJobMetricGroup jobManagerJobMetricGroup)
CompletableFuture<Acknowledge>
Execution. sendOperatorEvent(OperatorID operatorId, SerializedValue<OperatorEvent> event)
Sends the operator event to the Task on the Task Executor.Constructors in org.apache.flink.runtime.executiongraph with parameters of type SerializedValue Constructor Description JobInformation(JobID jobId, JobType jobType, String jobName, SerializedValue<ExecutionConfig> serializedExecutionConfig, Configuration jobConfiguration, Collection<PermanentBlobKey> requiredJarFileBlobKeys, Collection<URL> requiredClasspathURLs)
-
Uses of SerializedValue in org.apache.flink.runtime.jobgraph
Methods in org.apache.flink.runtime.jobgraph that return SerializedValue Modifier and Type Method Description SerializedValue<ExecutionConfig>
JobGraph. getSerializedExecutionConfig()
Returns theExecutionConfig
.Methods in org.apache.flink.runtime.jobgraph that return types with arguments of type SerializedValue Modifier and Type Method Description List<SerializedValue<OperatorCoordinator.Provider>>
JobVertex. getOperatorCoordinators()
Methods in org.apache.flink.runtime.jobgraph with parameters of type SerializedValue Modifier and Type Method Description void
JobVertex. addOperatorCoordinator(SerializedValue<OperatorCoordinator.Provider> serializedCoordinatorProvider)
-
Uses of SerializedValue in org.apache.flink.runtime.jobgraph.tasks
Methods in org.apache.flink.runtime.jobgraph.tasks that return SerializedValue Modifier and Type Method Description SerializedValue<CheckpointStorage>
JobCheckpointingSettings. getDefaultCheckpointStorage()
SerializedValue<StateBackend>
JobCheckpointingSettings. getDefaultStateBackend()
SerializedValue<MasterTriggerRestoreHook.Factory[]>
JobCheckpointingSettings. getMasterHooks()
Methods in org.apache.flink.runtime.jobgraph.tasks with parameters of type SerializedValue Modifier and Type Method Description void
AbstractInvokable. dispatchOperatorEvent(OperatorID operator, SerializedValue<OperatorEvent> event)
void
CoordinatedTask. dispatchOperatorEvent(OperatorID operator, SerializedValue<OperatorEvent> event)
void
TaskOperatorEventGateway. sendOperatorEventToCoordinator(OperatorID operator, SerializedValue<OperatorEvent> event)
Sends an event from the operator (identified by the given operator ID) to the operator coordinator (identified by the same ID).CompletableFuture<CoordinationResponse>
TaskOperatorEventGateway. sendRequestToCoordinator(OperatorID operator, SerializedValue<CoordinationRequest> request)
Sends a request from current operator to a specified operator coordinator which is identified by the given operator ID and return the response.Constructors in org.apache.flink.runtime.jobgraph.tasks with parameters of type SerializedValue Constructor Description JobCheckpointingSettings(CheckpointCoordinatorConfiguration checkpointCoordinatorConfiguration, SerializedValue<StateBackend> defaultStateBackend)
JobCheckpointingSettings(CheckpointCoordinatorConfiguration checkpointCoordinatorConfiguration, SerializedValue<StateBackend> defaultStateBackend, TernaryBoolean changelogStateBackendEnabled, SerializedValue<CheckpointStorage> defaultCheckpointStorage, SerializedValue<MasterTriggerRestoreHook.Factory[]> masterHooks)
JobCheckpointingSettings(CheckpointCoordinatorConfiguration checkpointCoordinatorConfiguration, SerializedValue<StateBackend> defaultStateBackend, TernaryBoolean changelogStateBackendEnabled, SerializedValue<CheckpointStorage> defaultCheckpointStorage, SerializedValue<MasterTriggerRestoreHook.Factory[]> masterHooks, TernaryBoolean stateBackendUseManagedMemory)
-
Uses of SerializedValue in org.apache.flink.runtime.jobmanager.slots
Methods in org.apache.flink.runtime.jobmanager.slots with parameters of type SerializedValue Modifier and Type Method Description CompletableFuture<Acknowledge>
TaskManagerGateway. sendOperatorEventToTask(ExecutionAttemptID task, OperatorID operator, SerializedValue<OperatorEvent> evt)
-
Uses of SerializedValue in org.apache.flink.runtime.jobmaster
Methods in org.apache.flink.runtime.jobmaster that return types with arguments of type SerializedValue Modifier and Type Method Description Map<String,SerializedValue<OptionalFailure<Object>>>
JobResult. getAccumulatorResults()
Method parameters in org.apache.flink.runtime.jobmaster with type arguments of type SerializedValue Modifier and Type Method Description JobResult.Builder
JobResult.Builder. accumulatorResults(Map<String,SerializedValue<OptionalFailure<Object>>> accumulatorResults)
-
Uses of SerializedValue in org.apache.flink.runtime.minicluster
Methods in org.apache.flink.runtime.minicluster with parameters of type SerializedValue Modifier and Type Method Description CompletableFuture<CoordinationResponse>
MiniCluster. deliverCoordinationRequestToCoordinator(JobID jobId, String operatorUid, SerializedValue<CoordinationRequest> serializedRequest)
-
Uses of SerializedValue in org.apache.flink.runtime.operators.coordination
Methods in org.apache.flink.runtime.operators.coordination with parameters of type SerializedValue Modifier and Type Method Description static OperatorCoordinatorHolder
OperatorCoordinatorHolder. create(SerializedValue<OperatorCoordinator.Provider> serializedProvider, ExecutionJobVertex jobVertex, ClassLoader classLoader, CoordinatorStore coordinatorStore, boolean supportsConcurrentExecutionAttempts, TaskInformation taskInformation, JobManagerJobMetricGroup metricGroup)
-
Uses of SerializedValue in org.apache.flink.runtime.rest.messages
Methods in org.apache.flink.runtime.rest.messages that return types with arguments of type SerializedValue Modifier and Type Method Description Map<String,SerializedValue<OptionalFailure<Object>>>
JobAccumulatorsInfo. getSerializedUserAccumulators()
Constructor parameters in org.apache.flink.runtime.rest.messages with type arguments of type SerializedValue Constructor Description JobAccumulatorsInfo(List<JobAccumulatorsInfo.JobAccumulator> jobAccumulators, List<JobAccumulatorsInfo.UserTaskAccumulator> userAccumulators, Map<String,SerializedValue<OptionalFailure<Object>>> serializedUserAccumulators)
-
Uses of SerializedValue in org.apache.flink.runtime.rest.messages.job.coordination
Methods in org.apache.flink.runtime.rest.messages.job.coordination that return SerializedValue Modifier and Type Method Description SerializedValue<CoordinationRequest>
ClientCoordinationRequestBody. getSerializedCoordinationRequest()
SerializedValue<CoordinationResponse>
ClientCoordinationResponseBody. getSerializedCoordinationResponse()
Constructors in org.apache.flink.runtime.rest.messages.job.coordination with parameters of type SerializedValue Constructor Description ClientCoordinationRequestBody(SerializedValue<CoordinationRequest> serializedCoordinationRequest)
ClientCoordinationResponseBody(SerializedValue<CoordinationResponse> serializedCoordinationResponse)
-
Uses of SerializedValue in org.apache.flink.runtime.rest.messages.json
Methods in org.apache.flink.runtime.rest.messages.json that return SerializedValue Modifier and Type Method Description SerializedValue<?>
SerializedValueDeserializer. deserialize(org.apache.flink.shaded.jackson2.com.fasterxml.jackson.core.JsonParser p, org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.DeserializationContext ctxt)
Methods in org.apache.flink.runtime.rest.messages.json with parameters of type SerializedValue Modifier and Type Method Description void
SerializedValueSerializer. serialize(SerializedValue<?> value, org.apache.flink.shaded.jackson2.com.fasterxml.jackson.core.JsonGenerator gen, org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.SerializerProvider provider)
-
Uses of SerializedValue in org.apache.flink.runtime.taskexecutor
Methods in org.apache.flink.runtime.taskexecutor with parameters of type SerializedValue Modifier and Type Method Description CompletableFuture<Acknowledge>
TaskExecutor. sendOperatorEventToTask(ExecutionAttemptID executionAttemptID, OperatorID operatorId, SerializedValue<OperatorEvent> evt)
CompletableFuture<Acknowledge>
TaskExecutorGateway. sendOperatorEventToTask(ExecutionAttemptID task, OperatorID operator, SerializedValue<OperatorEvent> evt)
CompletableFuture<Acknowledge>
TaskExecutorGatewayDecoratorBase. sendOperatorEventToTask(ExecutionAttemptID task, OperatorID operator, SerializedValue<OperatorEvent> evt)
CompletableFuture<Acknowledge>
TaskExecutorOperatorEventGateway. sendOperatorEventToTask(ExecutionAttemptID task, OperatorID operator, SerializedValue<OperatorEvent> evt)
Sends an operator event to an operator in a task executed by the Task Manager (Task Executor). -
Uses of SerializedValue in org.apache.flink.runtime.taskexecutor.rpc
Methods in org.apache.flink.runtime.taskexecutor.rpc with parameters of type SerializedValue Modifier and Type Method Description void
RpcTaskOperatorEventGateway. sendOperatorEventToCoordinator(OperatorID operator, SerializedValue<OperatorEvent> event)
CompletableFuture<CoordinationResponse>
RpcTaskOperatorEventGateway. sendRequestToCoordinator(OperatorID operator, SerializedValue<CoordinationRequest> request)
-
Uses of SerializedValue in org.apache.flink.runtime.taskmanager
Methods in org.apache.flink.runtime.taskmanager with parameters of type SerializedValue Modifier and Type Method Description void
Task. deliverOperatorEvent(OperatorID operator, SerializedValue<OperatorEvent> evt)
Dispatches an operator event to the invokable task. -
Uses of SerializedValue in org.apache.flink.runtime.webmonitor
Methods in org.apache.flink.runtime.webmonitor with parameters of type SerializedValue Modifier and Type Method Description default CompletableFuture<CoordinationResponse>
RestfulGateway. deliverCoordinationRequestToCoordinator(JobID jobId, String operatorUid, SerializedValue<CoordinationRequest> serializedRequest, Duration timeout)
Deliver a coordination request to a specified coordinator and return the response. -
Uses of SerializedValue in org.apache.flink.streaming.api.graph
Methods in org.apache.flink.streaming.api.graph that return SerializedValue Modifier and Type Method Description SerializedValue<ExecutionConfig>
ExecutionPlan. getSerializedExecutionConfig()
Gets the serialized execution configuration.SerializedValue<ExecutionConfig>
StreamGraph. getSerializedExecutionConfig()
Methods in org.apache.flink.streaming.api.graph with parameters of type SerializedValue Modifier and Type Method Description void
StreamConfig. setSerializedCheckpointStorage(SerializedValue<CheckpointStorage> serializedCheckpointStorage)
void
StreamConfig. setSerializedStateBackend(SerializedValue<StateBackend> serializedStateBackend, boolean useManagedMemory)
-
Uses of SerializedValue in org.apache.flink.streaming.api.graph.util
Methods in org.apache.flink.streaming.api.graph.util that return types with arguments of type SerializedValue Modifier and Type Method Description Map<JobVertexID,List<CompletableFuture<SerializedValue<OperatorCoordinator.Provider>>>>
JobVertexBuildContext. getCoordinatorSerializationFuturesPerJobVertex()
Method parameters in org.apache.flink.streaming.api.graph.util with type arguments of type SerializedValue Modifier and Type Method Description void
JobVertexBuildContext. putCoordinatorSerializationFutures(JobVertexID vertexId, List<CompletableFuture<SerializedValue<OperatorCoordinator.Provider>>> serializationFutures)
-
Uses of SerializedValue in org.apache.flink.streaming.runtime.tasks
Methods in org.apache.flink.streaming.runtime.tasks with parameters of type SerializedValue Modifier and Type Method Description void
FinishedOperatorChain. dispatchOperatorEvent(OperatorID operator, SerializedValue<OperatorEvent> event)
abstract void
OperatorChain. dispatchOperatorEvent(OperatorID operator, SerializedValue<OperatorEvent> event)
void
RegularOperatorChain. dispatchOperatorEvent(OperatorID operator, SerializedValue<OperatorEvent> event)
void
StreamTask. dispatchOperatorEvent(OperatorID operator, SerializedValue<OperatorEvent> event)
-
Uses of SerializedValue in org.apache.flink.util
Subclasses of SerializedValue in org.apache.flink.util Modifier and Type Class Description class
CompressedSerializedValue<T>
An extension ofSerializedValue
that compresses the value after the serialization.Methods in org.apache.flink.util that return SerializedValue Modifier and Type Method Description static <T> SerializedValue<T>
SerializedValue. fromBytes(byte[] serializedData)
Constructs serialized value from serialized data.
-