Modifier and Type | Method and Description |
---|---|
PermanentBlobKey |
VoidBlobWriter.putPermanent(org.apache.flink.api.common.JobID jobId,
byte[] value) |
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 |
BlobServer.putPermanent(org.apache.flink.api.common.JobID jobId,
byte[] value) |
PermanentBlobKey |
VoidBlobWriter.putPermanent(org.apache.flink.api.common.JobID jobId,
InputStream inputStream) |
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 |
BlobServer.putPermanent(org.apache.flink.api.common.JobID jobId,
InputStream inputStream) |
Modifier and Type | Method and Description |
---|---|
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 List<PermanentBlobKey> |
BlobClient.uploadJarFiles(InetSocketAddress serverAddress,
org.apache.flink.configuration.Configuration clientConfig,
org.apache.flink.api.common.JobID jobId,
List<org.apache.flink.core.fs.Path> jars)
Uploads the JAR files to the
PermanentBlobService of the BlobServer at the
given address with HA as configured. |
Modifier and Type | Method and Description |
---|---|
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.
|
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 |
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.
|
Modifier and Type | Field and Description |
---|---|
PermanentBlobKey |
TaskDeploymentDescriptor.Offloaded.serializedValueKey
The key of the offloaded value BLOB.
|
Constructor and Description |
---|
Offloaded(PermanentBlobKey serializedValueKey) |
Modifier and Type | Method and Description |
---|---|
void |
LibraryCacheManager.registerJob(org.apache.flink.api.common.JobID id,
Collection<PermanentBlobKey> requiredJarFiles,
Collection<URL> requiredClasspaths)
Registers a job with its required jar files and classpaths.
|
void |
BlobLibraryCacheManager.registerJob(org.apache.flink.api.common.JobID id,
Collection<PermanentBlobKey> requiredJarFiles,
Collection<URL> requiredClasspaths) |
void |
LibraryCacheManager.registerTask(org.apache.flink.api.common.JobID id,
ExecutionAttemptID execution,
Collection<PermanentBlobKey> requiredJarFiles,
Collection<URL> requiredClasspaths)
Registers a job task execution with its required jar files and classpaths.
|
void |
BlobLibraryCacheManager.registerTask(org.apache.flink.api.common.JobID jobId,
ExecutionAttemptID task,
Collection<PermanentBlobKey> requiredJarFiles,
Collection<URL> requiredClasspaths) |
Modifier and Type | Method and Description |
---|---|
org.apache.flink.types.Either<org.apache.flink.util.SerializedValue<JobInformation>,PermanentBlobKey> |
ExecutionGraph.getJobInformationOrBlobKey() |
Collection<PermanentBlobKey> |
JobInformation.getRequiredJarFileBlobKeys() |
Collection<PermanentBlobKey> |
ExecutionGraph.getRequiredJarFiles()
Returns a list of BLOB keys referring to the JAR files required to run this job.
|
org.apache.flink.types.Either<org.apache.flink.util.SerializedValue<TaskInformation>,PermanentBlobKey> |
ExecutionJobVertex.getTaskInformationOrBlobKey() |
Constructor and Description |
---|
JobInformation(org.apache.flink.api.common.JobID jobId,
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) |
Modifier and Type | Method and Description |
---|---|
List<PermanentBlobKey> |
JobGraph.getUserJarBlobKeys()
Returns a set of BLOB keys referring to the JAR files required to run this job.
|
Modifier and Type | Method and Description |
---|---|
void |
JobGraph.addBlob(PermanentBlobKey key)
Adds the BLOB referenced by the key to the JobGraph's dependencies.
|
Modifier and Type | Method and Description |
---|---|
Collection<PermanentBlobKey> |
ClassloadingProps.getRequiredJarFiles() |
Constructor and Description |
---|
ClassloadingProps(int blobManagerPort,
Collection<PermanentBlobKey> requiredJarFiles,
Collection<URL> requiredClasspaths)
Constructor of ClassloadingProps.
|
Copyright © 2014–2018 The Apache Software Foundation. All rights reserved.