Uses of Class
org.apache.flink.runtime.blob.PermanentBlobKey
-
-
Uses of PermanentBlobKey in org.apache.flink.runtime.blob
Methods in org.apache.flink.runtime.blob that return PermanentBlobKey Modifier and Type Method Description PermanentBlobKey
BlobServer. putPermanent(org.apache.flink.api.common.JobID jobId, byte[] value)
PermanentBlobKey
BlobServer. putPermanent(org.apache.flink.api.common.JobID jobId, InputStream inputStream)
PermanentBlobKey
BlobWriter. putPermanent(org.apache.flink.api.common.JobID jobId, byte[] value)
Uploads the data of the given byte array for the given job to the BLOB server and makes it a permanent BLOB.PermanentBlobKey
BlobWriter. putPermanent(org.apache.flink.api.common.JobID jobId, InputStream inputStream)
Uploads the data from the given input stream for the given job to the BLOB server and makes it a permanent BLOB.PermanentBlobKey
VoidBlobWriter. putPermanent(org.apache.flink.api.common.JobID jobId, byte[] value)
PermanentBlobKey
VoidBlobWriter. putPermanent(org.apache.flink.api.common.JobID jobId, InputStream inputStream)
PermanentBlobKey
BlobClient. uploadFile(org.apache.flink.api.common.JobID jobId, org.apache.flink.core.fs.Path file)
Uploads a single file to thePermanentBlobService
of the givenBlobServer
.Methods in org.apache.flink.runtime.blob that return types with arguments of type PermanentBlobKey Modifier and Type Method Description static <T> org.apache.flink.types.Either<org.apache.flink.util.SerializedValue<T>,PermanentBlobKey>
BlobWriter. offloadWithException(org.apache.flink.util.SerializedValue<T> serializedValue, org.apache.flink.api.common.JobID jobId, BlobWriter blobWriter)
static <T> org.apache.flink.types.Either<org.apache.flink.util.SerializedValue<T>,PermanentBlobKey>
BlobWriter. serializeAndTryOffload(T value, org.apache.flink.api.common.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> org.apache.flink.types.Either<org.apache.flink.util.SerializedValue<T>,PermanentBlobKey>
BlobWriter. tryOffload(org.apache.flink.util.SerializedValue<T> serializedValue, org.apache.flink.api.common.JobID jobId, BlobWriter blobWriter)
static List<PermanentBlobKey>
BlobClient. uploadFiles(InetSocketAddress serverAddress, org.apache.flink.configuration.Configuration clientConfig, org.apache.flink.api.common.JobID jobId, List<org.apache.flink.core.fs.Path> files)
Uploads the JAR files to thePermanentBlobService
of theBlobServer
at the given address with HA as configured.Methods in org.apache.flink.runtime.blob with parameters of type PermanentBlobKey Modifier and Type Method Description boolean
BlobServer. deletePermanent(org.apache.flink.api.common.JobID jobId, PermanentBlobKey key)
Delete the uploaded data with the givenJobID
andPermanentBlobKey
.boolean
BlobWriter. deletePermanent(org.apache.flink.api.common.JobID jobId, PermanentBlobKey permanentBlobKey)
Delete the uploaded data with the givenJobID
andPermanentBlobKey
.boolean
VoidBlobWriter. deletePermanent(org.apache.flink.api.common.JobID jobId, PermanentBlobKey key)
File
BlobServer. getFile(org.apache.flink.api.common.JobID jobId, PermanentBlobKey key)
Returns the path to a local copy of the file associated with the provided job ID and blob key.File
PermanentBlobCache. getFile(org.apache.flink.api.common.JobID jobId, PermanentBlobKey key)
Returns the path to a local copy of the file associated with the provided job ID and blob key.File
PermanentBlobService. getFile(org.apache.flink.api.common.JobID jobId, PermanentBlobKey key)
Returns the path to a local copy of the file associated with the provided job ID and blob key.byte[]
PermanentBlobCache. readFile(org.apache.flink.api.common.JobID jobId, PermanentBlobKey blobKey)
Returns the content of the file for the BLOB with the provided job ID the blob key.default byte[]
PermanentBlobService. readFile(org.apache.flink.api.common.JobID jobId, PermanentBlobKey key)
Returns the content of the file for the BLOB with the provided job ID the blob key. -
Uses of PermanentBlobKey in org.apache.flink.runtime.deployment
Fields in org.apache.flink.runtime.deployment declared as PermanentBlobKey Modifier and Type Field Description PermanentBlobKey
TaskDeploymentDescriptor.Offloaded. serializedValueKey
The key of the offloaded value BLOB.Method parameters in org.apache.flink.runtime.deployment with type arguments of type PermanentBlobKey Modifier and Type Method Description void
TaskDeploymentDescriptor. loadBigData(PermanentBlobService blobService, GroupCache<org.apache.flink.api.common.JobID,PermanentBlobKey,JobInformation> jobInformationCache, GroupCache<org.apache.flink.api.common.JobID,PermanentBlobKey,TaskInformation> taskInformationCache, GroupCache<org.apache.flink.api.common.JobID,PermanentBlobKey,TaskDeploymentDescriptorFactory.ShuffleDescriptorGroup> shuffleDescriptorsCache)
Loads externalized data from the BLOB store back to the object.void
InputGateDeploymentDescriptor. tryLoadAndDeserializeShuffleDescriptors(PermanentBlobService blobService, org.apache.flink.api.common.JobID jobId, GroupCache<org.apache.flink.api.common.JobID,PermanentBlobKey,TaskDeploymentDescriptorFactory.ShuffleDescriptorGroup> shuffleDescriptorsCache)
Constructors in org.apache.flink.runtime.deployment with parameters of type PermanentBlobKey Constructor Description Offloaded(PermanentBlobKey serializedValueKey)
Constructor parameters in org.apache.flink.runtime.deployment with type arguments of type PermanentBlobKey Constructor Description TaskDeploymentDescriptorFactory(org.apache.flink.types.Either<org.apache.flink.util.SerializedValue<JobInformation>,PermanentBlobKey> jobInformationOrBlobKey, org.apache.flink.api.common.JobID jobID, TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionDeploymentConstraint, BlobWriter blobWriter, boolean nonFinishedHybridPartitionShouldBeUnknown, int offloadShuffleDescriptorsThreshold)
-
Uses of PermanentBlobKey in org.apache.flink.runtime.execution.librarycache
Method parameters in org.apache.flink.runtime.execution.librarycache with type arguments of type PermanentBlobKey Modifier and Type Method Description org.apache.flink.util.UserCodeClassLoader
LibraryCacheManager.ClassLoaderHandle. getOrResolveClassLoader(Collection<PermanentBlobKey> requiredJarFiles, Collection<URL> requiredClasspaths)
Gets or resolves the user code class loader for the associated job. -
Uses of PermanentBlobKey in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph that return types with arguments of type PermanentBlobKey Modifier and Type Method Description org.apache.flink.shaded.guava32.com.google.common.collect.ImmutableCollection<PermanentBlobKey>
JobInformation. getRequiredJarFileBlobKeys()
org.apache.flink.types.Either<org.apache.flink.util.SerializedValue<TaskInformation>,PermanentBlobKey>
ExecutionJobVertex. getTaskInformationOrBlobKey()
Method parameters in org.apache.flink.runtime.executiongraph with type arguments of type PermanentBlobKey Modifier and Type Method Description void
DefaultExecutionGraph. deleteBlobs(List<PermanentBlobKey> blobKeys)
void
InternalExecutionGraphAccessor. deleteBlobs(List<PermanentBlobKey> blobKeys)
Constructor parameters in org.apache.flink.runtime.executiongraph with type arguments of type PermanentBlobKey Constructor Description JobInformation(org.apache.flink.api.common.JobID jobId, JobType jobType, String jobName, org.apache.flink.util.SerializedValue<org.apache.flink.api.common.ExecutionConfig> serializedExecutionConfig, org.apache.flink.configuration.Configuration jobConfiguration, Collection<PermanentBlobKey> requiredJarFileBlobKeys, Collection<URL> requiredClasspathURLs)
-
Uses of PermanentBlobKey in org.apache.flink.runtime.jobgraph
Methods in org.apache.flink.runtime.jobgraph that return types with arguments of type PermanentBlobKey Modifier and Type Method Description List<PermanentBlobKey>
JobGraph. getUserJarBlobKeys()
Returns a set of BLOB keys referring to the JAR files required to run this job.Methods in org.apache.flink.runtime.jobgraph with parameters of type PermanentBlobKey Modifier and Type Method Description void
JobGraph. addUserJarBlobKey(PermanentBlobKey key)
Adds the BLOB referenced by the key to the JobGraph's dependencies.void
JobGraph. setUserArtifactBlobKey(String entryName, PermanentBlobKey blobKey)
-
Uses of PermanentBlobKey in org.apache.flink.runtime.taskexecutor
Methods in org.apache.flink.runtime.taskexecutor that return types with arguments of type PermanentBlobKey Modifier and Type Method Description GroupCache<org.apache.flink.api.common.JobID,PermanentBlobKey,JobInformation>
TaskManagerServices. getJobInformationCache()
GroupCache<org.apache.flink.api.common.JobID,PermanentBlobKey,TaskDeploymentDescriptorFactory.ShuffleDescriptorGroup>
TaskManagerServices. getShuffleDescriptorCache()
GroupCache<org.apache.flink.api.common.JobID,PermanentBlobKey,TaskInformation>
TaskManagerServices. getTaskInformationCache()
-
Uses of PermanentBlobKey in org.apache.flink.streaming.api.graph
Methods in org.apache.flink.streaming.api.graph that return types with arguments of type PermanentBlobKey Modifier and Type Method Description List<PermanentBlobKey>
ExecutionPlan. getUserJarBlobKeys()
Gets the user-defined blob keys corresponding to the JAR files.List<PermanentBlobKey>
StreamGraph. getUserJarBlobKeys()
Returns a list of BLOB keys referring to the JAR files required to run this job.Methods in org.apache.flink.streaming.api.graph with parameters of type PermanentBlobKey Modifier and Type Method Description void
ExecutionPlan. addUserJarBlobKey(PermanentBlobKey permanentBlobKey)
Adds a blob key corresponding to a user JAR.void
StreamGraph. addUserJarBlobKey(PermanentBlobKey key)
void
ExecutionPlan. setUserArtifactBlobKey(String artifactName, PermanentBlobKey blobKey)
Sets a user artifact blob key for a specified user artifact.void
StreamGraph. setUserArtifactBlobKey(String entryName, PermanentBlobKey blobKey)
-