risingwave_rpc_client::meta_client

Struct GrpcMetaClient

source
struct GrpcMetaClient {
    member_monitor_event_sender: Sender<Sender<Result<()>>>,
    core: Arc<RwLock<GrpcMetaClientCore>>,
}
Expand description

Client to meta server. Cloning the instance is lightweight.

It is a wrapper of tonic client. See crate::meta_rpc_client_method_impl.

Fields§

§member_monitor_event_sender: Sender<Sender<Result<()>>>§core: Arc<RwLock<GrpcMetaClientCore>>

Implementations§

source§

impl GrpcMetaClient

source

const ENDPOINT_KEEP_ALIVE_INTERVAL_SEC: u64 = 60u64

source

const ENDPOINT_KEEP_ALIVE_TIMEOUT_SEC: u64 = 60u64

source

const INIT_RETRY_BASE_INTERVAL_MS: u64 = 10u64

source

const INIT_RETRY_MAX_INTERVAL_MS: u64 = 2_000u64

source

fn start_meta_member_monitor( &self, init_leader_addr: Uri, members: Either<MetaMemberServiceClient<TracingInjectChannel>, MetaMemberGroup>, force_refresh_receiver: Receiver<Sender<Result<()>>>, meta_config: MetaConfig, ) -> Result<()>

source

async fn force_refresh_leader(&self) -> Result<()>

source

pub async fn new( strategy: &MetaAddressStrategy, config: MetaConfig, ) -> Result<Self>

Connect to the meta server from addrs.

source

fn addr_to_endpoint(addr: Uri) -> Endpoint

source

pub(crate) async fn try_build_rpc_channel( addrs: impl IntoIterator<Item = Uri>, ) -> Result<(TracingInjectChannel, Uri)>

source

async fn connect_to_endpoint(endpoint: Endpoint) -> Result<TracingInjectChannel>

source

pub(crate) fn retry_strategy_to_bound( high_bound: Duration, exceed: bool, ) -> impl Iterator<Item = Duration>

source§

impl GrpcMetaClient

source

async fn refresh_client_if_needed(&self, code: Code)

source§

impl GrpcMetaClient

source

pub async fn add_worker_node( &self, request: AddWorkerNodeRequest, ) -> Result<AddWorkerNodeResponse>

source

pub async fn activate_worker_node( &self, request: ActivateWorkerNodeRequest, ) -> Result<ActivateWorkerNodeResponse>

source

pub async fn delete_worker_node( &self, request: DeleteWorkerNodeRequest, ) -> Result<DeleteWorkerNodeResponse>

source

pub async fn update_worker_node_schedulability( &self, request: UpdateWorkerNodeSchedulabilityRequest, ) -> Result<UpdateWorkerNodeSchedulabilityResponse>

source

pub async fn list_all_nodes( &self, request: ListAllNodesRequest, ) -> Result<ListAllNodesResponse>

source

pub async fn get_cluster_recovery_status( &self, request: GetClusterRecoveryStatusRequest, ) -> Result<GetClusterRecoveryStatusResponse>

source

pub async fn heartbeat( &self, request: HeartbeatRequest, ) -> Result<HeartbeatResponse>

source

pub async fn flush(&self, request: FlushRequest) -> Result<FlushResponse>

source

pub async fn pause(&self, request: PauseRequest) -> Result<PauseResponse>

source

pub async fn resume(&self, request: ResumeRequest) -> Result<ResumeResponse>

source

pub async fn apply_throttle( &self, request: ApplyThrottleRequest, ) -> Result<ApplyThrottleResponse>

source

pub async fn cancel_creating_jobs( &self, request: CancelCreatingJobsRequest, ) -> Result<CancelCreatingJobsResponse>

source

pub async fn list_table_fragments( &self, request: ListTableFragmentsRequest, ) -> Result<ListTableFragmentsResponse>

source

pub async fn list_table_fragment_states( &self, request: ListTableFragmentStatesRequest, ) -> Result<ListTableFragmentStatesResponse>

source

pub async fn list_fragment_distribution( &self, request: ListFragmentDistributionRequest, ) -> Result<ListFragmentDistributionResponse>

source

pub async fn list_actor_states( &self, request: ListActorStatesRequest, ) -> Result<ListActorStatesResponse>

source

pub async fn list_actor_splits( &self, request: ListActorSplitsRequest, ) -> Result<ListActorSplitsResponse>

source

pub async fn list_object_dependencies( &self, request: ListObjectDependenciesRequest, ) -> Result<ListObjectDependenciesResponse>

source

pub async fn recover(&self, request: RecoverRequest) -> Result<RecoverResponse>

source

pub async fn list_rate_limits( &self, request: ListRateLimitsRequest, ) -> Result<ListRateLimitsResponse>

source

pub async fn create_table( &self, request: CreateTableRequest, ) -> Result<CreateTableResponse>

source

pub async fn alter_name( &self, request: AlterNameRequest, ) -> Result<AlterNameResponse>

source

pub async fn alter_owner( &self, request: AlterOwnerRequest, ) -> Result<AlterOwnerResponse>

source

pub async fn alter_set_schema( &self, request: AlterSetSchemaRequest, ) -> Result<AlterSetSchemaResponse>

source

pub async fn alter_parallelism( &self, request: AlterParallelismRequest, ) -> Result<AlterParallelismResponse>

source

pub async fn create_materialized_view( &self, request: CreateMaterializedViewRequest, ) -> Result<CreateMaterializedViewResponse>

source

pub async fn create_view( &self, request: CreateViewRequest, ) -> Result<CreateViewResponse>

source

pub async fn create_source( &self, request: CreateSourceRequest, ) -> Result<CreateSourceResponse>

source

pub async fn create_sink( &self, request: CreateSinkRequest, ) -> Result<CreateSinkResponse>

source

pub async fn create_subscription( &self, request: CreateSubscriptionRequest, ) -> Result<CreateSubscriptionResponse>

source

pub async fn create_schema( &self, request: CreateSchemaRequest, ) -> Result<CreateSchemaResponse>

source

pub async fn create_database( &self, request: CreateDatabaseRequest, ) -> Result<CreateDatabaseResponse>

source

pub async fn create_secret( &self, request: CreateSecretRequest, ) -> Result<CreateSecretResponse>

source

pub async fn create_index( &self, request: CreateIndexRequest, ) -> Result<CreateIndexResponse>

source

pub async fn create_function( &self, request: CreateFunctionRequest, ) -> Result<CreateFunctionResponse>

source

pub async fn drop_table( &self, request: DropTableRequest, ) -> Result<DropTableResponse>

source

pub async fn drop_materialized_view( &self, request: DropMaterializedViewRequest, ) -> Result<DropMaterializedViewResponse>

source

pub async fn drop_view( &self, request: DropViewRequest, ) -> Result<DropViewResponse>

source

pub async fn drop_source( &self, request: DropSourceRequest, ) -> Result<DropSourceResponse>

source

pub async fn drop_secret( &self, request: DropSecretRequest, ) -> Result<DropSecretResponse>

source

pub async fn drop_sink( &self, request: DropSinkRequest, ) -> Result<DropSinkResponse>

source

pub async fn drop_subscription( &self, request: DropSubscriptionRequest, ) -> Result<DropSubscriptionResponse>

source

pub async fn drop_database( &self, request: DropDatabaseRequest, ) -> Result<DropDatabaseResponse>

source

pub async fn drop_schema( &self, request: DropSchemaRequest, ) -> Result<DropSchemaResponse>

source

pub async fn drop_index( &self, request: DropIndexRequest, ) -> Result<DropIndexResponse>

source

pub async fn drop_function( &self, request: DropFunctionRequest, ) -> Result<DropFunctionResponse>

source

pub async fn replace_table_plan( &self, request: ReplaceTablePlanRequest, ) -> Result<ReplaceTablePlanResponse>

source

pub async fn alter_source( &self, request: AlterSourceRequest, ) -> Result<AlterSourceResponse>

source

pub async fn risectl_list_state_tables( &self, request: RisectlListStateTablesRequest, ) -> Result<RisectlListStateTablesResponse>

source

pub async fn get_ddl_progress( &self, request: GetDdlProgressRequest, ) -> Result<GetDdlProgressResponse>

source

pub async fn create_connection( &self, request: CreateConnectionRequest, ) -> Result<CreateConnectionResponse>

source

pub async fn list_connections( &self, request: ListConnectionsRequest, ) -> Result<ListConnectionsResponse>

source

pub async fn drop_connection( &self, request: DropConnectionRequest, ) -> Result<DropConnectionResponse>

source

pub async fn comment_on( &self, request: CommentOnRequest, ) -> Result<CommentOnResponse>

source

pub async fn get_tables( &self, request: GetTablesRequest, ) -> Result<GetTablesResponse>

source

pub async fn wait(&self, request: WaitRequest) -> Result<WaitResponse>

source

pub async fn auto_schema_change( &self, request: AutoSchemaChangeRequest, ) -> Result<AutoSchemaChangeResponse>

source

pub async fn alter_swap_rename( &self, request: AlterSwapRenameRequest, ) -> Result<AlterSwapRenameResponse>

source

pub async fn unpin_version_before( &self, request: UnpinVersionBeforeRequest, ) -> Result<UnpinVersionBeforeResponse>

source

pub async fn get_current_version( &self, request: GetCurrentVersionRequest, ) -> Result<GetCurrentVersionResponse>

source

pub async fn replay_version_delta( &self, request: ReplayVersionDeltaRequest, ) -> Result<ReplayVersionDeltaResponse>

source

pub async fn list_version_deltas( &self, request: ListVersionDeltasRequest, ) -> Result<ListVersionDeltasResponse>

source

pub async fn get_assigned_compact_task_num( &self, request: GetAssignedCompactTaskNumRequest, ) -> Result<GetAssignedCompactTaskNumResponse>

source

pub async fn trigger_compaction_deterministic( &self, request: TriggerCompactionDeterministicRequest, ) -> Result<TriggerCompactionDeterministicResponse>

source

pub async fn disable_commit_epoch( &self, request: DisableCommitEpochRequest, ) -> Result<DisableCommitEpochResponse>

source

pub async fn get_new_sst_ids( &self, request: GetNewSstIdsRequest, ) -> Result<GetNewSstIdsResponse>

source

pub async fn trigger_manual_compaction( &self, request: TriggerManualCompactionRequest, ) -> Result<TriggerManualCompactionResponse>

source

pub async fn trigger_full_gc( &self, request: TriggerFullGcRequest, ) -> Result<TriggerFullGcResponse>

source

pub async fn rise_ctl_get_pinned_versions_summary( &self, request: RiseCtlGetPinnedVersionsSummaryRequest, ) -> Result<RiseCtlGetPinnedVersionsSummaryResponse>

source

pub async fn rise_ctl_list_compaction_group( &self, request: RiseCtlListCompactionGroupRequest, ) -> Result<RiseCtlListCompactionGroupResponse>

source

pub async fn rise_ctl_update_compaction_config( &self, request: RiseCtlUpdateCompactionConfigRequest, ) -> Result<RiseCtlUpdateCompactionConfigResponse>

source

pub async fn rise_ctl_get_checkpoint_version( &self, request: RiseCtlGetCheckpointVersionRequest, ) -> Result<RiseCtlGetCheckpointVersionResponse>

source

pub async fn rise_ctl_pause_version_checkpoint( &self, request: RiseCtlPauseVersionCheckpointRequest, ) -> Result<RiseCtlPauseVersionCheckpointResponse>

source

pub async fn rise_ctl_resume_version_checkpoint( &self, request: RiseCtlResumeVersionCheckpointRequest, ) -> Result<RiseCtlResumeVersionCheckpointResponse>

source

pub async fn init_metadata_for_replay( &self, request: InitMetadataForReplayRequest, ) -> Result<InitMetadataForReplayResponse>

source

pub async fn split_compaction_group( &self, request: SplitCompactionGroupRequest, ) -> Result<SplitCompactionGroupResponse>

source

pub async fn rise_ctl_list_compaction_status( &self, request: RiseCtlListCompactionStatusRequest, ) -> Result<RiseCtlListCompactionStatusResponse>

source

pub async fn get_compaction_score( &self, request: GetCompactionScoreRequest, ) -> Result<GetCompactionScoreResponse>

source

pub async fn rise_ctl_rebuild_table_stats( &self, request: RiseCtlRebuildTableStatsRequest, ) -> Result<RiseCtlRebuildTableStatsResponse>

source

pub async fn subscribe_compaction_event( &self, request: impl IntoStreamingRequest<Message = SubscribeCompactionEventRequest>, ) -> Result<Streaming<SubscribeCompactionEventResponse>>

source

pub async fn list_branched_object( &self, request: ListBranchedObjectRequest, ) -> Result<ListBranchedObjectResponse>

source

pub async fn list_active_write_limit( &self, request: ListActiveWriteLimitRequest, ) -> Result<ListActiveWriteLimitResponse>

source

pub async fn list_hummock_meta_config( &self, request: ListHummockMetaConfigRequest, ) -> Result<ListHummockMetaConfigResponse>

source

pub async fn list_compact_task_assignment( &self, request: ListCompactTaskAssignmentRequest, ) -> Result<ListCompactTaskAssignmentResponse>

source

pub async fn list_compact_task_progress( &self, request: ListCompactTaskProgressRequest, ) -> Result<ListCompactTaskProgressResponse>

source

pub async fn cancel_compact_task( &self, request: CancelCompactTaskRequest, ) -> Result<CancelCompactTaskResponse>

source

pub async fn get_version_by_epoch( &self, request: GetVersionByEpochRequest, ) -> Result<GetVersionByEpochResponse>

source

pub async fn merge_compaction_group( &self, request: MergeCompactionGroupRequest, ) -> Result<MergeCompactionGroupResponse>

source

pub async fn create_user( &self, request: CreateUserRequest, ) -> Result<CreateUserResponse>

source

pub async fn update_user( &self, request: UpdateUserRequest, ) -> Result<UpdateUserResponse>

source

pub async fn drop_user( &self, request: DropUserRequest, ) -> Result<DropUserResponse>

source

pub async fn grant_privilege( &self, request: GrantPrivilegeRequest, ) -> Result<GrantPrivilegeResponse>

source

pub async fn revoke_privilege( &self, request: RevokePrivilegeRequest, ) -> Result<RevokePrivilegeResponse>

source

pub async fn get_cluster_info( &self, request: GetClusterInfoRequest, ) -> Result<GetClusterInfoResponse>

source

pub async fn reschedule( &self, request: RescheduleRequest, ) -> Result<RescheduleResponse>

source

pub async fn subscribe( &self, request: SubscribeRequest, ) -> Result<Streaming<SubscribeResponse>>

source

pub async fn backup_meta( &self, request: BackupMetaRequest, ) -> Result<BackupMetaResponse>

source

pub async fn get_backup_job_status( &self, request: GetBackupJobStatusRequest, ) -> Result<GetBackupJobStatusResponse>

source

pub async fn delete_meta_snapshot( &self, request: DeleteMetaSnapshotRequest, ) -> Result<DeleteMetaSnapshotResponse>

source

pub async fn get_meta_snapshot_manifest( &self, request: GetMetaSnapshotManifestRequest, ) -> Result<GetMetaSnapshotManifestResponse>

source

pub async fn get_telemetry_info( &self, request: GetTelemetryInfoRequest, ) -> Result<TelemetryInfoResponse>

source

pub async fn get_system_params( &self, request: GetSystemParamsRequest, ) -> Result<GetSystemParamsResponse>

source

pub async fn set_system_param( &self, request: SetSystemParamRequest, ) -> Result<SetSystemParamResponse>

source

pub async fn get_session_params( &self, request: GetSessionParamsRequest, ) -> Result<GetSessionParamsResponse>

source

pub async fn set_session_param( &self, request: SetSessionParamRequest, ) -> Result<SetSessionParamResponse>

source

pub async fn get_serving_vnode_mappings( &self, request: GetServingVnodeMappingsRequest, ) -> Result<GetServingVnodeMappingsResponse>

source

pub async fn rw_cloud_validate_source( &self, request: RwCloudValidateSourceRequest, ) -> Result<RwCloudValidateSourceResponse>

source

pub async fn list_event_log( &self, request: ListEventLogRequest, ) -> Result<ListEventLogResponse>

source

pub async fn add_event_log( &self, request: AddEventLogRequest, ) -> Result<AddEventLogResponse>

source

pub async fn get_cluster_limits( &self, request: GetClusterLimitsRequest, ) -> Result<GetClusterLimitsResponse>

Trait Implementations§

source§

impl Clone for GrpcMetaClient

source§

fn clone(&self) -> GrpcMetaClient

Returns a copy of the value. Read more
1.0.0 · source§

fn clone_from(&mut self, source: &Self)

Performs copy-assignment from source. Read more
source§

impl Debug for GrpcMetaClient

source§

fn fmt(&self, f: &mut Formatter<'_>) -> Result

Formats the value using the given formatter. Read more

Auto Trait Implementations§

Blanket Implementations§

source§

impl<T> Any for T
where T: 'static + ?Sized,

source§

fn type_id(&self) -> TypeId

Gets the TypeId of self. Read more
source§

impl<T> Borrow<T> for T
where T: ?Sized,

source§

fn borrow(&self) -> &T

Immutably borrows from an owned value. Read more
source§

impl<T> BorrowMut<T> for T
where T: ?Sized,

source§

fn borrow_mut(&mut self) -> &mut T

Mutably borrows from an owned value. Read more
source§

impl<T> CloneToUninit for T
where T: Clone,

source§

unsafe fn clone_to_uninit(&self, dst: *mut T)

🔬This is a nightly-only experimental API. (clone_to_uninit)
Performs copy-assignment from self to dst. Read more
source§

impl<T> From<T> for T

source§

fn from(t: T) -> T

Returns the argument unchanged.

§

impl<T> FromRef<T> for T
where T: Clone,

§

fn from_ref(input: &T) -> T

Converts to this type from a reference to the input type.
§

impl<T> FutureExt for T

§

fn with_context(self, otel_cx: Context) -> WithContext<Self>

Attaches the provided Context to this type, returning a WithContext wrapper. Read more
§

fn with_current_context(self) -> WithContext<Self>

Attaches the current Context to this type, returning a WithContext wrapper. Read more
§

impl<T> Instrument for T

§

fn instrument(self, span: Span) -> Instrumented<Self>

Instruments this type with the provided [Span], returning an Instrumented wrapper. Read more
§

fn in_current_span(self) -> Instrumented<Self>

Instruments this type with the current Span, returning an Instrumented wrapper. Read more
source§

impl<T> Instrument for T

source§

fn instrument(self, span: Span) -> Instrumented<Self>

Instruments this type with the provided Span, returning an Instrumented wrapper. Read more
source§

fn in_current_span(self) -> Instrumented<Self>

Instruments this type with the current Span, returning an Instrumented wrapper. Read more
source§

impl<T, U> Into<U> for T
where U: From<T>,

source§

fn into(self) -> U

Calls U::from(self).

That is, this conversion is whatever the implementation of From<T> for U chooses to do.

source§

impl<T> IntoEither for T

source§

fn into_either(self, into_left: bool) -> Either<Self, Self>

Converts self into a Left variant of Either<Self, Self> if into_left is true. Converts self into a Right variant of Either<Self, Self> otherwise. Read more
source§

fn into_either_with<F>(self, into_left: F) -> Either<Self, Self>
where F: FnOnce(&Self) -> bool,

Converts self into a Left variant of Either<Self, Self> if into_left(&self) returns true. Converts self into a Right variant of Either<Self, Self> otherwise. Read more
source§

impl<T> IntoRequest<T> for T

source§

fn into_request(self) -> Request<T>

Wrap the input message T in a tonic::Request
§

impl<T> IntoResult<T> for T

§

type Err = Infallible

§

fn into_result(self) -> Result<T, <T as IntoResult<T>>::Err>

source§

impl<M> MetricVecRelabelExt for M

source§

fn relabel( self, metric_level: MetricLevel, relabel_threshold: MetricLevel, ) -> RelabeledMetricVec<M>

source§

fn relabel_n( self, metric_level: MetricLevel, relabel_threshold: MetricLevel, relabel_num: usize, ) -> RelabeledMetricVec<M>

source§

fn relabel_debug_1( self, relabel_threshold: MetricLevel, ) -> RelabeledMetricVec<M>

Equivalent to RelabeledMetricVec::with_metric_level_relabel_n with metric_level set to MetricLevel::Debug and relabel_num set to 1.
§

impl<T> Pointable for T

§

const ALIGN: usize = _

The alignment of pointer.
§

type Init = T

The type for initializers.
§

unsafe fn init(init: <T as Pointable>::Init) -> usize

Initializes a with the given initializer. Read more
§

unsafe fn deref<'a>(ptr: usize) -> &'a T

Dereferences the given pointer. Read more
§

unsafe fn deref_mut<'a>(ptr: usize) -> &'a mut T

Mutably dereferences the given pointer. Read more
§

unsafe fn drop(ptr: usize)

Drops the object pointed to by the given pointer. Read more
source§

impl<T> Same for T

source§

type Output = T

Should always be Self
source§

impl<T> ToOwned for T
where T: Clone,

source§

type Owned = T

The resulting type after obtaining ownership.
source§

fn to_owned(&self) -> T

Creates owned data from borrowed data, usually by cloning. Read more
source§

fn clone_into(&self, target: &mut T)

Uses borrowed data to replace owned data, usually by cloning. Read more
source§

impl<T, U> TryFrom<U> for T
where U: Into<T>,

source§

type Error = Infallible

The type returned in the event of a conversion error.
source§

fn try_from(value: U) -> Result<T, <T as TryFrom<U>>::Error>

Performs the conversion.
source§

impl<T, U> TryInto<U> for T
where U: TryFrom<T>,

source§

type Error = <U as TryFrom<T>>::Error

The type returned in the event of a conversion error.
source§

fn try_into(self) -> Result<U, <U as TryFrom<T>>::Error>

Performs the conversion.
§

impl<V, T> VZip<V> for T
where V: MultiLane<T>,

§

fn vzip(self) -> V

§

impl<T> WithSubscriber for T

§

fn with_subscriber<S>(self, subscriber: S) -> WithDispatch<Self>
where S: Into<Dispatch>,

Attaches the provided Subscriber to this type, returning a [WithDispatch] wrapper. Read more
§

fn with_current_subscriber(self) -> WithDispatch<Self>

Attaches the current default Subscriber to this type, returning a [WithDispatch] wrapper. Read more
source§

impl<T> WithSubscriber for T

source§

fn with_subscriber<S>(self, subscriber: S) -> WithDispatch<Self>
where S: Into<Dispatch>,

Attaches the provided Subscriber to this type, returning a WithDispatch wrapper. Read more
source§

fn with_current_subscriber(self) -> WithDispatch<Self>

Attaches the current default Subscriber to this type, returning a WithDispatch wrapper. Read more
§

impl<T> DevConfig for T
where T: Send + Sync + 'static + Debug,

source§

impl<T> LruValue for T
where T: Send + Sync,

§

impl<T> Value for T
where T: Send + Sync + 'static,