Uses of Class
org.apache.storm.generated.AuthorizationException
-
-
Uses of AuthorizationException in org.apache.storm
Methods in org.apache.storm that throw AuthorizationException Modifier and Type Method Description BeginDownloadResult
LocalCluster. beginBlobDownload(String key)
String
LocalCluster. beginCreateBlob(String key, SettableBlobMeta meta)
String
LocalCluster. beginFileUpload()
String
LocalCluster. beginUpdateBlob(String key)
void
LocalCluster. cancelBlobUpload(String session)
void
LocalCluster. debug(String name, String component, boolean enable, double samplingPercentage)
void
LocalCluster. deleteBlob(String key)
ByteBuffer
LocalCluster. downloadBlobChunk(String session)
ByteBuffer
LocalCluster. downloadChunk(String id)
String
LocalDRPC. execute(String functionName, String funcArgs)
void
LocalDRPC. failRequest(String id)
void
LocalDRPC. failRequestV2(String id, DRPCExecutionException e)
DRPCRequest
LocalDRPC. fetchRequest(String functionName)
void
LocalCluster. finishBlobUpload(String session)
void
LocalCluster. finishFileUpload(String location)
ReadableBlobMeta
LocalCluster. getBlobMeta(String key)
int
LocalCluster. getBlobReplication(String key)
ComponentPageInfo
LocalCluster. getComponentPageInfo(String topologyId, String componentId, String window, boolean isIncludeSys)
NimbusSummary
LocalCluster. getLeader()
String
LocalCluster. getNimbusConf()
List<OwnerResourceSummary>
LocalCluster. getOwnerResourceSummaries(String owner)
SupervisorAssignments
LocalCluster. getSupervisorAssignments(String node)
SupervisorPageInfo
LocalCluster. getSupervisorPageInfo(String id, String host, boolean isIncludeSys)
TopologyHistoryInfo
LocalCluster. getTopologyHistory(String user)
TopologyPageInfo
LocalCluster. getTopologyPageInfo(String id, String window, boolean isIncludeSys)
StormTopology
LocalCluster. getUserTopology(String id)
boolean
LocalCluster. isRemoteBlobExists(String blobKey)
boolean
LocalCluster. isTopologyNameAllowed(String name)
static boolean
StormSubmitter. pushCredentials(String name, Map<String,Object> topoConf, Map<String,String> credentials)
Push a new set of credentials to the running topology.static boolean
StormSubmitter. pushCredentials(String name, Map<String,Object> topoConf, Map<String,String> credentials, String expectedUser)
Push a new set of credentials to the running topology.void
LocalDRPC. result(String id, String result)
void
LocalCluster. sendSupervisorWorkerHeartbeat(SupervisorWorkerHeartbeat heatbeat)
void
LocalCluster. sendSupervisorWorkerHeartbeats(SupervisorWorkerHeartbeats heartbeats)
void
LocalCluster. setBlobMeta(String key, SettableBlobMeta meta)
void
LocalCluster. submitTopology(String name, String uploadedJarLocation, String jsonConf, StormTopology topology)
static void
StormSubmitter. submitTopology(String name, Map<String,Object> topoConf, StormTopology topology)
Submits a topology to run on the cluster.static void
StormSubmitter. submitTopology(String name, Map<String,Object> topoConf, StormTopology topology, SubmitOptions opts)
Submits a topology to run on the cluster.static void
StormSubmitter. submitTopology(String name, Map<String,Object> topoConf, StormTopology topology, SubmitOptions opts, StormSubmitter.ProgressListener progressListener)
Submits a topology to run on the cluster.static void
StormSubmitter. submitTopologyAs(String name, Map<String,Object> topoConf, StormTopology topology, SubmitOptions opts, StormSubmitter.ProgressListener progressListener, String asUser)
Submits a topology to run on the cluster as a particular user.void
LocalCluster. submitTopologyWithOpts(String name, String uploadedJarLocation, String jsonConf, StormTopology topology, SubmitOptions options)
static void
StormSubmitter. submitTopologyWithProgressBar(String name, Map<String,Object> topoConf, StormTopology topology)
Submits a topology to run on the cluster with a progress bar.static void
StormSubmitter. submitTopologyWithProgressBar(String name, Map<String,Object> topoConf, StormTopology topology, SubmitOptions opts)
Submits a topology to run on the cluster with a progress bar.int
LocalCluster. updateBlobReplication(String key, int replication)
void
LocalCluster. uploadBlobChunk(String session, ByteBuffer chunk)
void
LocalCluster. uploadChunk(String location, ByteBuffer chunk)
-
Uses of AuthorizationException in org.apache.storm.blobstore
Methods in org.apache.storm.blobstore that throw AuthorizationException Modifier and Type Method Description protected static void
MigrateBlobs. copyBlobStoreKeys(BlobStore bsFrom, Subject whoFrom, BlobStore bsTo, Subject whoTo)
void
BlobStore. createBlob(String key, byte[] data, SettableBlobMeta meta, Subject who)
Wrapper called to create the blob which contains the byte data.void
BlobStore. createBlob(String key, InputStream in, SettableBlobMeta meta, Subject who)
Wrapper called to create the blob which contains the byte data.abstract AtomicOutputStream
BlobStore. createBlob(String key, SettableBlobMeta meta, Subject who)
Creates the blob.AtomicOutputStream
ClientBlobStore. createBlob(String key, SettableBlobMeta meta)
Client facing API to create a blob.AtomicOutputStream
LocalFsBlobStore. createBlob(String key, SettableBlobMeta meta, Subject who)
protected abstract AtomicOutputStream
ClientBlobStore. createBlobToExtend(String key, SettableBlobMeta meta)
Client facing API to create a blob.protected AtomicOutputStream
LocalModeClientBlobStore. createBlobToExtend(String key, SettableBlobMeta meta)
protected AtomicOutputStream
NimbusBlobStore. createBlobToExtend(String key, SettableBlobMeta meta)
protected static void
MigrateBlobs. deleteAllBlobStoreKeys(BlobStore bs, Subject who)
abstract void
BlobStore. deleteBlob(String key, Subject who)
Deletes the blob data and metadata.abstract void
ClientBlobStore. deleteBlob(String key)
Client facing API to delete a blob.void
LocalFsBlobStore. deleteBlob(String key, Subject who)
void
LocalModeClientBlobStore. deleteBlob(String key)
void
NimbusBlobStore. deleteBlob(String key)
abstract InputStreamWithMeta
BlobStore. getBlob(String key, Subject who)
Gets the InputStream to read the blob details.abstract InputStreamWithMeta
ClientBlobStore. getBlob(String key)
Client facing API to read a blob.InputStreamWithMeta
LocalFsBlobStore. getBlob(String key, Subject who)
InputStreamWithMeta
LocalModeClientBlobStore. getBlob(String key)
InputStreamWithMeta
NimbusBlobStore. getBlob(String key)
abstract ReadableBlobMeta
BlobStore. getBlobMeta(String key, Subject who)
Gets the current version of metadata for a blob to be viewed by the user or downloaded by the supervisor.abstract ReadableBlobMeta
ClientBlobStore. getBlobMeta(String key)
Client facing API to read the metadata information.ReadableBlobMeta
LocalFsBlobStore. getBlobMeta(String key, Subject who)
ReadableBlobMeta
LocalModeClientBlobStore. getBlobMeta(String key)
ReadableBlobMeta
NimbusBlobStore. getBlobMeta(String key)
abstract int
ClientBlobStore. getBlobReplication(String key)
Client facing API to read the replication of a blob.int
LocalModeClientBlobStore. getBlobReplication(String key)
int
NimbusBlobStore. getBlobReplication(String key)
void
BlobStoreAclHandler. hasAnyPermissions(List<AccessControl> acl, int mask, Subject who, String key)
Validates if the user has any of the permissions mentioned in the mask.void
BlobStoreAclHandler. hasPermissions(List<AccessControl> acl, int mask, Subject who, String key)
Validates if the user has at least the set of permissions mentioned in the mask.abstract boolean
ClientBlobStore. isRemoteBlobExists(String blobKey)
Decide if the blob is deleted from cluster.boolean
LocalModeClientBlobStore. isRemoteBlobExists(String blobKey)
boolean
NimbusBlobStore. isRemoteBlobExists(String blobKey)
byte[]
BlobStore. readBlob(String key, Subject who)
Wrapper around readBlobTo which returns a ByteArray output stream.void
BlobStore. readBlobTo(String key, OutputStream out, Subject who)
Reads the blob from the blob store and writes it into the output stream.abstract void
BlobStore. setBlobMeta(String key, SettableBlobMeta meta, Subject who)
Sets the metadata with renewed acls for the blob.void
ClientBlobStore. setBlobMeta(String key, SettableBlobMeta meta)
Client facing API to set the metadata for a blob.void
LocalFsBlobStore. setBlobMeta(String key, SettableBlobMeta meta, Subject who)
protected abstract void
ClientBlobStore. setBlobMetaToExtend(String key, SettableBlobMeta meta)
Client facing API to set the metadata for a blob.protected void
LocalModeClientBlobStore. setBlobMetaToExtend(String key, SettableBlobMeta meta)
protected void
NimbusBlobStore. setBlobMetaToExtend(String key, SettableBlobMeta meta)
void
BlobStore. startSyncBlobs()
Start the syncing blobs between the local running instance of the BlobStore and others.void
LocalFsBlobStore. startSyncBlobs()
void
BlobStore. updateBlob(String key, byte[] data, Subject who)
Wrapper called to create the blob which contains the byte data.abstract AtomicOutputStream
BlobStore. updateBlob(String key, Subject who)
Updates the blob data.abstract AtomicOutputStream
ClientBlobStore. updateBlob(String key)
Client facing API to update a blob.AtomicOutputStream
LocalFsBlobStore. updateBlob(String key, Subject who)
AtomicOutputStream
LocalModeClientBlobStore. updateBlob(String key)
AtomicOutputStream
NimbusBlobStore. updateBlob(String key)
abstract int
BlobStore. updateBlobReplication(String key, int replication, Subject who)
Modifies the replication factor of the blob.abstract int
ClientBlobStore. updateBlobReplication(String key, int replication)
Client facing API to update the replication of a blob.int
LocalFsBlobStore. updateBlobReplication(String key, int replication, Subject who)
int
LocalModeClientBlobStore. updateBlobReplication(String key, int replication)
int
NimbusBlobStore. updateBlobReplication(String key, int replication)
static void
BlobStoreAclHandler. validateSettableACLs(String key, List<AccessControl> acls)
void
BlobStoreAclHandler. validateUserCanReadMeta(List<AccessControl> acl, Subject who, String key)
The user should be able to see the metadata if and only if they have any of READ, WRITE, or ADMIN. -
Uses of AuthorizationException in org.apache.storm.daemon.common
Methods in org.apache.storm.daemon.common with parameters of type AuthorizationException Modifier and Type Method Description jakarta.ws.rs.core.Response
AuthorizationExceptionMapper. toResponse(AuthorizationException ex)
-
Uses of AuthorizationException in org.apache.storm.daemon.drpc
Methods in org.apache.storm.daemon.drpc that throw AuthorizationException Modifier and Type Method Description <T extends OutstandingRequest>
TDRPC. execute(String functionName, String funcArgs, RequestFactory<T> factory)
String
DRPCThrift. execute(String functionName, String funcArgs)
String
DRPC. executeBlocking(String functionName, String funcArgs)
void
DRPC. failRequest(String id, DRPCExecutionException e)
void
DRPCThrift. failRequest(String id)
void
DRPCThrift. failRequestV2(String id, DRPCExecutionException e)
DRPCRequest
DRPC. fetchRequest(String functionName)
DRPCRequest
DRPCThrift. fetchRequest(String functionName)
void
DRPCThrift. result(String id, String result)
void
DRPC. returnResult(String id, String result)
-
Uses of AuthorizationException in org.apache.storm.daemon.nimbus
-
Uses of AuthorizationException in org.apache.storm.daemon.supervisor
Methods in org.apache.storm.daemon.supervisor that throw AuthorizationException Modifier and Type Method Description void
Supervisor. checkAuthorization(String operation)
void
Supervisor. checkAuthorization(String topoName, Map<String,Object> topoConf, String operation)
void
Supervisor. checkAuthorization(String topoName, Map<String,Object> topoConf, String operation, ReqContext context)
-
Uses of AuthorizationException in org.apache.storm.daemon.ui.exceptionmappers
Methods in org.apache.storm.daemon.ui.exceptionmappers with parameters of type AuthorizationException Modifier and Type Method Description static jakarta.ws.rs.core.Response
ExceptionMapperUtils. getResponse(AuthorizationException ex, jakarta.inject.Provider<jakarta.servlet.http.HttpServletRequest> request)
getResponse.jakarta.ws.rs.core.Response
AuthorizationExceptionMapper. toResponse(AuthorizationException e)
-
Uses of AuthorizationException in org.apache.storm.dependency
Methods in org.apache.storm.dependency that throw AuthorizationException Modifier and Type Method Description List<String>
DependencyUploader. uploadFiles(List<File> dependencies, boolean cleanupIfFails)
-
Uses of AuthorizationException in org.apache.storm.drpc
Methods in org.apache.storm.drpc that throw AuthorizationException Modifier and Type Method Description void
DRPCInvocationsClient. failRequest(String id)
void
DRPCInvocationsClient. failRequestV2(String id, DRPCExecutionException ex)
DRPCRequest
DRPCInvocationsClient. fetchRequest(String func)
void
DRPCInvocationsClient. result(String id, String result)
-
Uses of AuthorizationException in org.apache.storm.generated
Methods in org.apache.storm.generated that return AuthorizationException Modifier and Type Method Description AuthorizationException
AuthorizationException. deepCopy()
AuthorizationException
DistributedRPC.execute_result. get_aze()
AuthorizationException
DistributedRPCInvocations.failRequest_result. get_aze()
AuthorizationException
DistributedRPCInvocations.failRequestV2_result. get_aze()
AuthorizationException
DistributedRPCInvocations.fetchRequest_result. get_aze()
AuthorizationException
DistributedRPCInvocations.result_result. get_aze()
AuthorizationException
Nimbus.activate_result. get_aze()
AuthorizationException
Nimbus.beginBlobDownload_result. get_aze()
AuthorizationException
Nimbus.beginCreateBlob_result. get_aze()
AuthorizationException
Nimbus.beginFileUpload_result. get_aze()
AuthorizationException
Nimbus.beginUpdateBlob_result. get_aze()
AuthorizationException
Nimbus.cancelBlobUpload_result. get_aze()
AuthorizationException
Nimbus.deactivate_result. get_aze()
AuthorizationException
Nimbus.debug_result. get_aze()
AuthorizationException
Nimbus.deleteBlob_result. get_aze()
AuthorizationException
Nimbus.downloadBlobChunk_result. get_aze()
AuthorizationException
Nimbus.downloadChunk_result. get_aze()
AuthorizationException
Nimbus.finishBlobUpload_result. get_aze()
AuthorizationException
Nimbus.finishFileUpload_result. get_aze()
AuthorizationException
Nimbus.getBlobMeta_result. get_aze()
AuthorizationException
Nimbus.getBlobReplication_result. get_aze()
AuthorizationException
Nimbus.getClusterInfo_result. get_aze()
AuthorizationException
Nimbus.getComponentPageInfo_result. get_aze()
AuthorizationException
Nimbus.getLeader_result. get_aze()
AuthorizationException
Nimbus.getNimbusConf_result. get_aze()
AuthorizationException
Nimbus.getOwnerResourceSummaries_result. get_aze()
AuthorizationException
Nimbus.getSupervisorAssignments_result. get_aze()
AuthorizationException
Nimbus.getSupervisorPageInfo_result. get_aze()
AuthorizationException
Nimbus.getTopology_result. get_aze()
AuthorizationException
Nimbus.getTopologyConf_result. get_aze()
AuthorizationException
Nimbus.getTopologyHistory_result. get_aze()
AuthorizationException
Nimbus.getTopologyInfo_result. get_aze()
AuthorizationException
Nimbus.getTopologyInfoByName_result. get_aze()
AuthorizationException
Nimbus.getTopologyInfoByNameWithOpts_result. get_aze()
AuthorizationException
Nimbus.getTopologyInfoWithOpts_result. get_aze()
AuthorizationException
Nimbus.getTopologyPageInfo_result. get_aze()
AuthorizationException
Nimbus.getTopologySummaries_result. get_aze()
AuthorizationException
Nimbus.getTopologySummary_result. get_aze()
AuthorizationException
Nimbus.getTopologySummaryByName_result. get_aze()
AuthorizationException
Nimbus.getUserTopology_result. get_aze()
AuthorizationException
Nimbus.isRemoteBlobExists_result. get_aze()
AuthorizationException
Nimbus.isTopologyNameAllowed_result. get_aze()
AuthorizationException
Nimbus.killTopology_result. get_aze()
AuthorizationException
Nimbus.killTopologyWithOpts_result. get_aze()
AuthorizationException
Nimbus.rebalance_result. get_aze()
AuthorizationException
Nimbus.sendSupervisorWorkerHeartbeat_result. get_aze()
AuthorizationException
Nimbus.sendSupervisorWorkerHeartbeats_result. get_aze()
AuthorizationException
Nimbus.setBlobMeta_result. get_aze()
AuthorizationException
Nimbus.submitTopology_result. get_aze()
AuthorizationException
Nimbus.submitTopologyWithOpts_result. get_aze()
AuthorizationException
Nimbus.updateBlobReplication_result. get_aze()
AuthorizationException
Nimbus.uploadBlobChunk_result. get_aze()
AuthorizationException
Nimbus.uploadChunk_result. get_aze()
AuthorizationException
Nimbus.uploadNewCredentials_result. get_aze()
AuthorizationException
Supervisor.getLocalAssignmentForStorm_result. get_aze()
AuthorizationException
Supervisor.sendSupervisorAssignments_result. get_aze()
AuthorizationException
Supervisor.sendSupervisorWorkerHeartbeat_result. get_aze()
Methods in org.apache.storm.generated with parameters of type AuthorizationException Modifier and Type Method Description int
AuthorizationException. compareTo(AuthorizationException other)
boolean
AuthorizationException. equals(AuthorizationException that)
void
DistributedRPC.execute_result. set_aze(AuthorizationException aze)
void
DistributedRPCInvocations.failRequest_result. set_aze(AuthorizationException aze)
void
DistributedRPCInvocations.failRequestV2_result. set_aze(AuthorizationException aze)
void
DistributedRPCInvocations.fetchRequest_result. set_aze(AuthorizationException aze)
void
DistributedRPCInvocations.result_result. set_aze(AuthorizationException aze)
void
Nimbus.activate_result. set_aze(AuthorizationException aze)
void
Nimbus.beginBlobDownload_result. set_aze(AuthorizationException aze)
void
Nimbus.beginCreateBlob_result. set_aze(AuthorizationException aze)
void
Nimbus.beginFileUpload_result. set_aze(AuthorizationException aze)
void
Nimbus.beginUpdateBlob_result. set_aze(AuthorizationException aze)
void
Nimbus.cancelBlobUpload_result. set_aze(AuthorizationException aze)
void
Nimbus.deactivate_result. set_aze(AuthorizationException aze)
void
Nimbus.debug_result. set_aze(AuthorizationException aze)
void
Nimbus.deleteBlob_result. set_aze(AuthorizationException aze)
void
Nimbus.downloadBlobChunk_result. set_aze(AuthorizationException aze)
void
Nimbus.downloadChunk_result. set_aze(AuthorizationException aze)
void
Nimbus.finishBlobUpload_result. set_aze(AuthorizationException aze)
void
Nimbus.finishFileUpload_result. set_aze(AuthorizationException aze)
void
Nimbus.getBlobMeta_result. set_aze(AuthorizationException aze)
void
Nimbus.getBlobReplication_result. set_aze(AuthorizationException aze)
void
Nimbus.getClusterInfo_result. set_aze(AuthorizationException aze)
void
Nimbus.getComponentPageInfo_result. set_aze(AuthorizationException aze)
void
Nimbus.getLeader_result. set_aze(AuthorizationException aze)
void
Nimbus.getNimbusConf_result. set_aze(AuthorizationException aze)
void
Nimbus.getOwnerResourceSummaries_result. set_aze(AuthorizationException aze)
void
Nimbus.getSupervisorAssignments_result. set_aze(AuthorizationException aze)
void
Nimbus.getSupervisorPageInfo_result. set_aze(AuthorizationException aze)
void
Nimbus.getTopology_result. set_aze(AuthorizationException aze)
void
Nimbus.getTopologyConf_result. set_aze(AuthorizationException aze)
void
Nimbus.getTopologyHistory_result. set_aze(AuthorizationException aze)
void
Nimbus.getTopologyInfo_result. set_aze(AuthorizationException aze)
void
Nimbus.getTopologyInfoByName_result. set_aze(AuthorizationException aze)
void
Nimbus.getTopologyInfoByNameWithOpts_result. set_aze(AuthorizationException aze)
void
Nimbus.getTopologyInfoWithOpts_result. set_aze(AuthorizationException aze)
void
Nimbus.getTopologyPageInfo_result. set_aze(AuthorizationException aze)
void
Nimbus.getTopologySummaries_result. set_aze(AuthorizationException aze)
void
Nimbus.getTopologySummary_result. set_aze(AuthorizationException aze)
void
Nimbus.getTopologySummaryByName_result. set_aze(AuthorizationException aze)
void
Nimbus.getUserTopology_result. set_aze(AuthorizationException aze)
void
Nimbus.isRemoteBlobExists_result. set_aze(AuthorizationException aze)
void
Nimbus.isTopologyNameAllowed_result. set_aze(AuthorizationException aze)
void
Nimbus.killTopology_result. set_aze(AuthorizationException aze)
void
Nimbus.killTopologyWithOpts_result. set_aze(AuthorizationException aze)
void
Nimbus.rebalance_result. set_aze(AuthorizationException aze)
void
Nimbus.sendSupervisorWorkerHeartbeat_result. set_aze(AuthorizationException aze)
void
Nimbus.sendSupervisorWorkerHeartbeats_result. set_aze(AuthorizationException aze)
void
Nimbus.setBlobMeta_result. set_aze(AuthorizationException aze)
void
Nimbus.submitTopology_result. set_aze(AuthorizationException aze)
void
Nimbus.submitTopologyWithOpts_result. set_aze(AuthorizationException aze)
void
Nimbus.updateBlobReplication_result. set_aze(AuthorizationException aze)
void
Nimbus.uploadBlobChunk_result. set_aze(AuthorizationException aze)
void
Nimbus.uploadChunk_result. set_aze(AuthorizationException aze)
void
Nimbus.uploadNewCredentials_result. set_aze(AuthorizationException aze)
void
Supervisor.getLocalAssignmentForStorm_result. set_aze(AuthorizationException aze)
void
Supervisor.sendSupervisorAssignments_result. set_aze(AuthorizationException aze)
void
Supervisor.sendSupervisorWorkerHeartbeat_result. set_aze(AuthorizationException aze)
Methods in org.apache.storm.generated that throw AuthorizationException Modifier and Type Method Description void
Nimbus.Client. activate(String name)
void
Nimbus.Iface. activate(String name)
BeginDownloadResult
Nimbus.Client. beginBlobDownload(String key)
BeginDownloadResult
Nimbus.Iface. beginBlobDownload(String key)
String
Nimbus.Client. beginCreateBlob(String key, SettableBlobMeta meta)
String
Nimbus.Iface. beginCreateBlob(String key, SettableBlobMeta meta)
String
Nimbus.Client. beginFileUpload()
String
Nimbus.Iface. beginFileUpload()
String
Nimbus.Client. beginUpdateBlob(String key)
String
Nimbus.Iface. beginUpdateBlob(String key)
void
Nimbus.Client. cancelBlobUpload(String session)
void
Nimbus.Iface. cancelBlobUpload(String session)
void
Nimbus.Client. deactivate(String name)
void
Nimbus.Iface. deactivate(String name)
void
Nimbus.Client. debug(String name, String component, boolean enable, double samplingPercentage)
void
Nimbus.Iface. debug(String name, String component, boolean enable, double samplingPercentage)
Enable/disable logging the tuples generated in topology via an internal EventLogger bolt.void
Nimbus.Client. deleteBlob(String key)
void
Nimbus.Iface. deleteBlob(String key)
ByteBuffer
Nimbus.Client. downloadBlobChunk(String session)
ByteBuffer
Nimbus.Iface. downloadBlobChunk(String session)
ByteBuffer
Nimbus.Client. downloadChunk(String id)
ByteBuffer
Nimbus.Iface. downloadChunk(String id)
String
DistributedRPC.Client. execute(String functionName, String funcArgs)
String
DistributedRPC.Iface. execute(String functionName, String funcArgs)
void
DistributedRPCInvocations.Client. failRequest(String id)
void
DistributedRPCInvocations.Iface. failRequest(String id)
void
DistributedRPCInvocations.Client. failRequestV2(String id, DRPCExecutionException e)
void
DistributedRPCInvocations.Iface. failRequestV2(String id, DRPCExecutionException e)
DRPCRequest
DistributedRPCInvocations.Client. fetchRequest(String functionName)
DRPCRequest
DistributedRPCInvocations.Iface. fetchRequest(String functionName)
void
Nimbus.Client. finishBlobUpload(String session)
void
Nimbus.Iface. finishBlobUpload(String session)
void
Nimbus.Client. finishFileUpload(String location)
void
Nimbus.Iface. finishFileUpload(String location)
ReadableBlobMeta
Nimbus.Client. getBlobMeta(String key)
ReadableBlobMeta
Nimbus.Iface. getBlobMeta(String key)
int
Nimbus.Client. getBlobReplication(String key)
int
Nimbus.Iface. getBlobReplication(String key)
ClusterSummary
Nimbus.Client. getClusterInfo()
ClusterSummary
Nimbus.Iface. getClusterInfo()
ComponentPageInfo
Nimbus.Client. getComponentPageInfo(String topology_id, String component_id, String window, boolean is_include_sys)
ComponentPageInfo
Nimbus.Iface. getComponentPageInfo(String topology_id, String component_id, String window, boolean is_include_sys)
NimbusSummary
Nimbus.Client. getLeader()
NimbusSummary
Nimbus.Iface. getLeader()
Assignment
Supervisor.Client. getLocalAssignmentForStorm(String id)
Assignment
Supervisor.Iface. getLocalAssignmentForStorm(String id)
Get local assignment for a stormString
Nimbus.Client. getNimbusConf()
String
Nimbus.Iface. getNimbusConf()
List<OwnerResourceSummary>
Nimbus.Client. getOwnerResourceSummaries(String owner)
List<OwnerResourceSummary>
Nimbus.Iface. getOwnerResourceSummaries(String owner)
String
DistributedRPC.AsyncClient.execute_call. getResult()
Void
DistributedRPCInvocations.AsyncClient.failRequest_call. getResult()
Void
DistributedRPCInvocations.AsyncClient.failRequestV2_call. getResult()
DRPCRequest
DistributedRPCInvocations.AsyncClient.fetchRequest_call. getResult()
Void
DistributedRPCInvocations.AsyncClient.result_call. getResult()
Void
Nimbus.AsyncClient.activate_call. getResult()
BeginDownloadResult
Nimbus.AsyncClient.beginBlobDownload_call. getResult()
String
Nimbus.AsyncClient.beginCreateBlob_call. getResult()
String
Nimbus.AsyncClient.beginFileUpload_call. getResult()
String
Nimbus.AsyncClient.beginUpdateBlob_call. getResult()
Void
Nimbus.AsyncClient.cancelBlobUpload_call. getResult()
Void
Nimbus.AsyncClient.deactivate_call. getResult()
Void
Nimbus.AsyncClient.debug_call. getResult()
Void
Nimbus.AsyncClient.deleteBlob_call. getResult()
ByteBuffer
Nimbus.AsyncClient.downloadBlobChunk_call. getResult()
ByteBuffer
Nimbus.AsyncClient.downloadChunk_call. getResult()
Void
Nimbus.AsyncClient.finishBlobUpload_call. getResult()
Void
Nimbus.AsyncClient.finishFileUpload_call. getResult()
ReadableBlobMeta
Nimbus.AsyncClient.getBlobMeta_call. getResult()
Integer
Nimbus.AsyncClient.getBlobReplication_call. getResult()
ClusterSummary
Nimbus.AsyncClient.getClusterInfo_call. getResult()
ComponentPageInfo
Nimbus.AsyncClient.getComponentPageInfo_call. getResult()
NimbusSummary
Nimbus.AsyncClient.getLeader_call. getResult()
String
Nimbus.AsyncClient.getNimbusConf_call. getResult()
List<OwnerResourceSummary>
Nimbus.AsyncClient.getOwnerResourceSummaries_call. getResult()
SupervisorAssignments
Nimbus.AsyncClient.getSupervisorAssignments_call. getResult()
SupervisorPageInfo
Nimbus.AsyncClient.getSupervisorPageInfo_call. getResult()
StormTopology
Nimbus.AsyncClient.getTopology_call. getResult()
String
Nimbus.AsyncClient.getTopologyConf_call. getResult()
TopologyHistoryInfo
Nimbus.AsyncClient.getTopologyHistory_call. getResult()
TopologyInfo
Nimbus.AsyncClient.getTopologyInfo_call. getResult()
TopologyInfo
Nimbus.AsyncClient.getTopologyInfoByName_call. getResult()
TopologyInfo
Nimbus.AsyncClient.getTopologyInfoByNameWithOpts_call. getResult()
TopologyInfo
Nimbus.AsyncClient.getTopologyInfoWithOpts_call. getResult()
TopologyPageInfo
Nimbus.AsyncClient.getTopologyPageInfo_call. getResult()
List<TopologySummary>
Nimbus.AsyncClient.getTopologySummaries_call. getResult()
TopologySummary
Nimbus.AsyncClient.getTopologySummary_call. getResult()
TopologySummary
Nimbus.AsyncClient.getTopologySummaryByName_call. getResult()
StormTopology
Nimbus.AsyncClient.getUserTopology_call. getResult()
Boolean
Nimbus.AsyncClient.isRemoteBlobExists_call. getResult()
Boolean
Nimbus.AsyncClient.isTopologyNameAllowed_call. getResult()
Void
Nimbus.AsyncClient.killTopology_call. getResult()
Void
Nimbus.AsyncClient.killTopologyWithOpts_call. getResult()
Void
Nimbus.AsyncClient.rebalance_call. getResult()
Void
Nimbus.AsyncClient.sendSupervisorWorkerHeartbeat_call. getResult()
Void
Nimbus.AsyncClient.sendSupervisorWorkerHeartbeats_call. getResult()
Void
Nimbus.AsyncClient.setBlobMeta_call. getResult()
Void
Nimbus.AsyncClient.submitTopology_call. getResult()
Void
Nimbus.AsyncClient.submitTopologyWithOpts_call. getResult()
Integer
Nimbus.AsyncClient.updateBlobReplication_call. getResult()
Void
Nimbus.AsyncClient.uploadBlobChunk_call. getResult()
Void
Nimbus.AsyncClient.uploadChunk_call. getResult()
Void
Nimbus.AsyncClient.uploadNewCredentials_call. getResult()
Assignment
Supervisor.AsyncClient.getLocalAssignmentForStorm_call. getResult()
Void
Supervisor.AsyncClient.sendSupervisorAssignments_call. getResult()
Void
Supervisor.AsyncClient.sendSupervisorWorkerHeartbeat_call. getResult()
SupervisorAssignments
Nimbus.Client. getSupervisorAssignments(String node)
SupervisorAssignments
Nimbus.Iface. getSupervisorAssignments(String node)
Get assigned assignments for a specific supervisorSupervisorPageInfo
Nimbus.Client. getSupervisorPageInfo(String id, String host, boolean is_include_sys)
SupervisorPageInfo
Nimbus.Iface. getSupervisorPageInfo(String id, String host, boolean is_include_sys)
StormTopology
Nimbus.Client. getTopology(String id)
StormTopology
Nimbus.Iface. getTopology(String id)
Returns the compiled topology that contains ackers and metrics consumsers.String
Nimbus.Client. getTopologyConf(String id)
String
Nimbus.Iface. getTopologyConf(String id)
TopologyHistoryInfo
Nimbus.Client. getTopologyHistory(String user)
TopologyHistoryInfo
Nimbus.Iface. getTopologyHistory(String user)
TopologyInfo
Nimbus.Client. getTopologyInfo(String id)
TopologyInfo
Nimbus.Iface. getTopologyInfo(String id)
TopologyInfo
Nimbus.Client. getTopologyInfoByName(String name)
TopologyInfo
Nimbus.Iface. getTopologyInfoByName(String name)
TopologyInfo
Nimbus.Client. getTopologyInfoByNameWithOpts(String name, GetInfoOptions options)
TopologyInfo
Nimbus.Iface. getTopologyInfoByNameWithOpts(String name, GetInfoOptions options)
TopologyInfo
Nimbus.Client. getTopologyInfoWithOpts(String id, GetInfoOptions options)
TopologyInfo
Nimbus.Iface. getTopologyInfoWithOpts(String id, GetInfoOptions options)
TopologyPageInfo
Nimbus.Client. getTopologyPageInfo(String id, String window, boolean is_include_sys)
TopologyPageInfo
Nimbus.Iface. getTopologyPageInfo(String id, String window, boolean is_include_sys)
List<TopologySummary>
Nimbus.Client. getTopologySummaries()
List<TopologySummary>
Nimbus.Iface. getTopologySummaries()
TopologySummary
Nimbus.Client. getTopologySummary(String id)
TopologySummary
Nimbus.Iface. getTopologySummary(String id)
TopologySummary
Nimbus.Client. getTopologySummaryByName(String name)
TopologySummary
Nimbus.Iface. getTopologySummaryByName(String name)
StormTopology
Nimbus.Client. getUserTopology(String id)
StormTopology
Nimbus.Iface. getUserTopology(String id)
Returns the user specified topology as submitted originally.boolean
Nimbus.Client. isRemoteBlobExists(String blobKey)
boolean
Nimbus.Iface. isRemoteBlobExists(String blobKey)
Decide if the blob is removed from cluster.boolean
Nimbus.Client. isTopologyNameAllowed(String name)
boolean
Nimbus.Iface. isTopologyNameAllowed(String name)
void
Nimbus.Client. killTopology(String name)
void
Nimbus.Iface. killTopology(String name)
void
Nimbus.Client. killTopologyWithOpts(String name, KillOptions options)
void
Nimbus.Iface. killTopologyWithOpts(String name, KillOptions options)
void
Nimbus.Client. rebalance(String name, RebalanceOptions options)
void
Nimbus.Iface. rebalance(String name, RebalanceOptions options)
void
Nimbus.Client. recv_activate()
BeginDownloadResult
Nimbus.Client. recv_beginBlobDownload()
String
Nimbus.Client. recv_beginCreateBlob()
String
Nimbus.Client. recv_beginFileUpload()
String
Nimbus.Client. recv_beginUpdateBlob()
void
Nimbus.Client. recv_cancelBlobUpload()
void
Nimbus.Client. recv_deactivate()
void
Nimbus.Client. recv_debug()
void
Nimbus.Client. recv_deleteBlob()
ByteBuffer
Nimbus.Client. recv_downloadBlobChunk()
ByteBuffer
Nimbus.Client. recv_downloadChunk()
String
DistributedRPC.Client. recv_execute()
void
DistributedRPCInvocations.Client. recv_failRequest()
void
DistributedRPCInvocations.Client. recv_failRequestV2()
DRPCRequest
DistributedRPCInvocations.Client. recv_fetchRequest()
void
Nimbus.Client. recv_finishBlobUpload()
void
Nimbus.Client. recv_finishFileUpload()
ReadableBlobMeta
Nimbus.Client. recv_getBlobMeta()
int
Nimbus.Client. recv_getBlobReplication()
ClusterSummary
Nimbus.Client. recv_getClusterInfo()
ComponentPageInfo
Nimbus.Client. recv_getComponentPageInfo()
NimbusSummary
Nimbus.Client. recv_getLeader()
Assignment
Supervisor.Client. recv_getLocalAssignmentForStorm()
String
Nimbus.Client. recv_getNimbusConf()
List<OwnerResourceSummary>
Nimbus.Client. recv_getOwnerResourceSummaries()
SupervisorAssignments
Nimbus.Client. recv_getSupervisorAssignments()
SupervisorPageInfo
Nimbus.Client. recv_getSupervisorPageInfo()
StormTopology
Nimbus.Client. recv_getTopology()
String
Nimbus.Client. recv_getTopologyConf()
TopologyHistoryInfo
Nimbus.Client. recv_getTopologyHistory()
TopologyInfo
Nimbus.Client. recv_getTopologyInfo()
TopologyInfo
Nimbus.Client. recv_getTopologyInfoByName()
TopologyInfo
Nimbus.Client. recv_getTopologyInfoByNameWithOpts()
TopologyInfo
Nimbus.Client. recv_getTopologyInfoWithOpts()
TopologyPageInfo
Nimbus.Client. recv_getTopologyPageInfo()
List<TopologySummary>
Nimbus.Client. recv_getTopologySummaries()
TopologySummary
Nimbus.Client. recv_getTopologySummary()
TopologySummary
Nimbus.Client. recv_getTopologySummaryByName()
StormTopology
Nimbus.Client. recv_getUserTopology()
boolean
Nimbus.Client. recv_isRemoteBlobExists()
boolean
Nimbus.Client. recv_isTopologyNameAllowed()
void
Nimbus.Client. recv_killTopology()
void
Nimbus.Client. recv_killTopologyWithOpts()
void
Nimbus.Client. recv_rebalance()
void
DistributedRPCInvocations.Client. recv_result()
void
Supervisor.Client. recv_sendSupervisorAssignments()
void
Nimbus.Client. recv_sendSupervisorWorkerHeartbeat()
void
Supervisor.Client. recv_sendSupervisorWorkerHeartbeat()
void
Nimbus.Client. recv_sendSupervisorWorkerHeartbeats()
void
Nimbus.Client. recv_setBlobMeta()
void
Nimbus.Client. recv_submitTopology()
void
Nimbus.Client. recv_submitTopologyWithOpts()
int
Nimbus.Client. recv_updateBlobReplication()
void
Nimbus.Client. recv_uploadBlobChunk()
void
Nimbus.Client. recv_uploadChunk()
void
Nimbus.Client. recv_uploadNewCredentials()
void
DistributedRPCInvocations.Client. result(String id, String result)
void
DistributedRPCInvocations.Iface. result(String id, String result)
void
Supervisor.Client. sendSupervisorAssignments(SupervisorAssignments assignments)
void
Supervisor.Iface. sendSupervisorAssignments(SupervisorAssignments assignments)
Send node specific assignments to supervisorvoid
Nimbus.Client. sendSupervisorWorkerHeartbeat(SupervisorWorkerHeartbeat heatbeat)
void
Nimbus.Iface. sendSupervisorWorkerHeartbeat(SupervisorWorkerHeartbeat heatbeat)
Send supervisor local worker heartbeat when a supervisor is unreachablevoid
Supervisor.Client. sendSupervisorWorkerHeartbeat(SupervisorWorkerHeartbeat heartbeat)
void
Supervisor.Iface. sendSupervisorWorkerHeartbeat(SupervisorWorkerHeartbeat heartbeat)
Send worker heartbeat to local supervisorvoid
Nimbus.Client. sendSupervisorWorkerHeartbeats(SupervisorWorkerHeartbeats heartbeats)
void
Nimbus.Iface. sendSupervisorWorkerHeartbeats(SupervisorWorkerHeartbeats heartbeats)
Send supervisor worker heartbeats for a specific supervisorvoid
Nimbus.Client. setBlobMeta(String key, SettableBlobMeta meta)
void
Nimbus.Iface. setBlobMeta(String key, SettableBlobMeta meta)
void
Nimbus.Client. submitTopology(String name, String uploadedJarLocation, String jsonConf, StormTopology topology)
void
Nimbus.Iface. submitTopology(String name, String uploadedJarLocation, String jsonConf, StormTopology topology)
void
Nimbus.Client. submitTopologyWithOpts(String name, String uploadedJarLocation, String jsonConf, StormTopology topology, SubmitOptions options)
void
Nimbus.Iface. submitTopologyWithOpts(String name, String uploadedJarLocation, String jsonConf, StormTopology topology, SubmitOptions options)
int
Nimbus.Client. updateBlobReplication(String key, int replication)
int
Nimbus.Iface. updateBlobReplication(String key, int replication)
void
Nimbus.Client. uploadBlobChunk(String session, ByteBuffer chunk)
void
Nimbus.Iface. uploadBlobChunk(String session, ByteBuffer chunk)
void
Nimbus.Client. uploadChunk(String location, ByteBuffer chunk)
void
Nimbus.Iface. uploadChunk(String location, ByteBuffer chunk)
void
Nimbus.Client. uploadNewCredentials(String name, Credentials creds)
void
Nimbus.Iface. uploadNewCredentials(String name, Credentials creds)
-
Uses of AuthorizationException in org.apache.storm.hdfs.blobstore
Methods in org.apache.storm.hdfs.blobstore that throw AuthorizationException Modifier and Type Method Description boolean
HdfsBlobStore. blobExists(String key, Subject who)
Checks if a blob exists.AtomicOutputStream
HdfsBlobStore. createBlob(String key, SettableBlobMeta meta, Subject who)
AtomicOutputStream
HdfsClientBlobStore. createBlobToExtend(String key, SettableBlobMeta meta)
void
HdfsBlobStore. deleteBlob(String key, Subject who)
void
HdfsClientBlobStore. deleteBlob(String key)
InputStreamWithMeta
HdfsBlobStore. getBlob(String key, Subject who)
InputStreamWithMeta
HdfsClientBlobStore. getBlob(String key)
ReadableBlobMeta
HdfsBlobStore. getBlobMeta(String key, Subject who)
ReadableBlobMeta
HdfsClientBlobStore. getBlobMeta(String key)
int
HdfsBlobStore. getBlobReplication(String key, Subject who)
int
HdfsClientBlobStore. getBlobReplication(String key)
boolean
HdfsClientBlobStore. isRemoteBlobExists(String blobKey)
void
HdfsBlobStore. setBlobMeta(String key, SettableBlobMeta meta, Subject who)
void
HdfsClientBlobStore. setBlobMetaToExtend(String key, SettableBlobMeta meta)
AtomicOutputStream
HdfsBlobStore. updateBlob(String key, Subject who)
AtomicOutputStream
HdfsClientBlobStore. updateBlob(String key)
int
HdfsBlobStore. updateBlobReplication(String key, int replication, Subject who)
int
HdfsClientBlobStore. updateBlobReplication(String key, int replication)
void
HdfsBlobStore. writeMetadata(String key, SettableBlobMeta meta)
-
Uses of AuthorizationException in org.apache.storm.kafka.trident
Methods in org.apache.storm.kafka.trident that throw AuthorizationException Modifier and Type Method Description protected void
TridentKafkaClientTopologyNamedTopics. run(String[] args)
-
Uses of AuthorizationException in org.apache.storm.localizer
Methods in org.apache.storm.localizer that throw AuthorizationException Modifier and Type Method Description protected org.apache.storm.localizer.LocallyCachedBlob.DownloadMeta
LocallyCachedBlob. fetch(ClientBlobStore store, String key, IOFunction<Long,Path> pathSupplier, IOFunction<File,OutputStream> outStreamSupplier)
Helper function to download blob from blob store.long
LocalizedResource. fetchUnzipToTemp(ClientBlobStore store)
abstract long
LocallyCachedBlob. fetchUnzipToTemp(ClientBlobStore store)
Download the latest version to a temp location.long
LocallyCachedTopologyBlob. fetchUnzipToTemp(ClientBlobStore store)
long
LocalizedResource. getRemoteVersion(ClientBlobStore store)
abstract long
LocallyCachedBlob. getRemoteVersion(ClientBlobStore store)
Get the version of the blob in the blob store.long
LocallyCachedTopologyBlob. getRemoteVersion(ClientBlobStore store)
void
LocallyCachedBlob. update(ClientBlobStore blobStore, long remoteBlobstoreUpdateTime)
Checks and downloads a blob locally as necessary. -
Uses of AuthorizationException in org.apache.storm.utils
Subclasses of AuthorizationException in org.apache.storm.utils Modifier and Type Class Description class
WrappedAuthorizationException
Wraps the generated TException to allow getMessage() to return a valid string.Methods in org.apache.storm.utils that throw AuthorizationException Modifier and Type Method Description String
DRPCClient. execute(String func, String args)
static long
ServerUtils. nimbusVersionOfBlob(String key, ClientBlobStore cb)
static void
Utils. validateTopologyBlobStoreMap(Map<String,Object> topoConf)
Validate topology blobstore map.static void
Utils. validateTopologyBlobStoreMap(Map<String,Object> topoConf, BlobStore blobStore)
Validate topology blobstore map.static void
Utils. validateTopologyBlobStoreMap(Map<String,Object> topoConf, NimbusBlobStore client)
Validate topology blobstore map.
-