diff --git a/core/trino-main/src/main/java/io/trino/sql/planner/PlanOptimizers.java b/core/trino-main/src/main/java/io/trino/sql/planner/PlanOptimizers.java index 22bc822a1402..21f0ef9484ad 100644 --- a/core/trino-main/src/main/java/io/trino/sql/planner/PlanOptimizers.java +++ b/core/trino-main/src/main/java/io/trino/sql/planner/PlanOptimizers.java @@ -138,6 +138,7 @@ import io.trino.sql.planner.iterative.rule.PruneWindowColumns; import io.trino.sql.planner.iterative.rule.PushAggregationIntoTableScan; import io.trino.sql.planner.iterative.rule.PushAggregationThroughOuterJoin; +import io.trino.sql.planner.iterative.rule.PushPartialAggregationIntoTableScan; import io.trino.sql.planner.iterative.rule.PushCastIntoRow; import io.trino.sql.planner.iterative.rule.PushDistinctLimitIntoTableScan; import io.trino.sql.planner.iterative.rule.PushDownDereferenceThroughFilter; @@ -1003,6 +1004,7 @@ public PlanOptimizers( ImmutableSet.>builder() .addAll(new PushPartialAggregationThroughJoin().rules()) .add(new PushPartialAggregationThroughExchange(plannerContext), + new PushPartialAggregationIntoTableScan(plannerContext), new PruneJoinColumns(), new PruneJoinChildrenColumns(), new RemoveRedundantIdentityProjections()) diff --git a/core/trino-main/src/main/java/io/trino/sql/planner/iterative/rule/PushPartialAggregationIntoTableScan.java b/core/trino-main/src/main/java/io/trino/sql/planner/iterative/rule/PushPartialAggregationIntoTableScan.java new file mode 100644 index 000000000000..6b7348c06ee0 --- /dev/null +++ b/core/trino-main/src/main/java/io/trino/sql/planner/iterative/rule/PushPartialAggregationIntoTableScan.java @@ -0,0 +1,252 @@ +/* + * Licensed under the Apache License, Version 2.0 (the "License"); + * you may not use this file except in compliance with the License. + * You may obtain a copy of the License at + * + * http://www.apache.org/licenses/LICENSE-2.0 + * + * Unless required by applicable law or agreed to in writing, software + * distributed under the License is distributed on an "AS IS" BASIS, + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. + * See the License for the specific language governing permissions and + * limitations under the License. + */ +package io.trino.sql.planner.iterative.rule; + +import com.google.common.collect.ImmutableBiMap; +import com.google.common.collect.ImmutableList; +import com.google.common.collect.ImmutableMap; +import io.trino.Session; +import io.trino.matching.Capture; +import io.trino.matching.Captures; +import io.trino.matching.Pattern; +import io.trino.metadata.TableHandle; +import io.trino.spi.connector.AggregateFunction; +import io.trino.spi.connector.AggregationApplicationResult; +import io.trino.spi.connector.Assignment; +import io.trino.spi.connector.ColumnHandle; +import io.trino.spi.connector.SortItem; +import io.trino.spi.expression.ConnectorExpression; +import io.trino.spi.expression.Variable; +import io.trino.spi.function.BoundSignature; +import io.trino.spi.predicate.TupleDomain; +import io.trino.sql.PlannerContext; +import io.trino.sql.ir.Expression; +import io.trino.sql.ir.Reference; +import io.trino.sql.planner.ConnectorExpressionTranslator; +import io.trino.sql.planner.OrderingScheme; +import io.trino.sql.planner.Symbol; +import io.trino.sql.planner.iterative.Rule; +import io.trino.sql.planner.plan.AggregationNode; +import io.trino.sql.planner.plan.Assignments; +import io.trino.sql.planner.plan.PlanNode; +import io.trino.sql.planner.plan.ProjectNode; +import io.trino.sql.planner.plan.TableScanNode; + +import java.util.HashMap; +import java.util.List; +import java.util.Map; +import java.util.Map.Entry; +import java.util.Optional; +import java.util.stream.IntStream; + +import static com.google.common.base.Verify.verify; +import static com.google.common.collect.ImmutableList.toImmutableList; +import static com.google.common.collect.ImmutableMap.toImmutableMap; +import static io.trino.SystemSessionProperties.isAllowPushdownIntoConnectors; +import static io.trino.matching.Capture.newCapture; +import static io.trino.sql.ir.optimizer.IrExpressionOptimizer.newOptimizer; +import static io.trino.sql.planner.iterative.rule.Rules.deriveTableStatisticsForPushdown; +import static io.trino.sql.planner.plan.Patterns.Aggregation.step; +import static io.trino.sql.planner.plan.Patterns.aggregation; +import static io.trino.sql.planner.plan.Patterns.source; +import static io.trino.sql.planner.plan.Patterns.tableScan; +import static java.util.Objects.requireNonNull; + +public class PushPartialAggregationIntoTableScan + implements Rule +{ + private static final Capture TABLE_SCAN = newCapture(); + + private static final Pattern PATTERN = + aggregation() + .with(step().equalTo(AggregationNode.Step.PARTIAL)) + // skip arguments that are, for instance, lambda expressions + .matching(PushPartialAggregationIntoTableScan::allArgumentsAreSimpleReferences) + .matching(node -> node.getGroupingSets().getGroupingSetCount() <= 1) + .matching(PushPartialAggregationIntoTableScan::hasNoMasks) + .with(source().matching(tableScan().capturedAs(TABLE_SCAN))); + + private final PlannerContext plannerContext; + + public PushPartialAggregationIntoTableScan(PlannerContext plannerContext) + { + this.plannerContext = requireNonNull(plannerContext, "plannerContext is null"); + } + + @Override + public Pattern getPattern() + { + return PATTERN; + } + + @Override + public boolean isEnabled(Session session) + { + return isAllowPushdownIntoConnectors(session); + } + + private static boolean allArgumentsAreSimpleReferences(AggregationNode node) + { + return node.getAggregations() + .values().stream() + .flatMap(aggregation -> aggregation.getArguments().stream()) + .allMatch(Reference.class::isInstance); + } + + private static boolean hasNoMasks(AggregationNode node) + { + return node.getAggregations() + .values().stream() + .allMatch(aggregation -> aggregation.getMask().isEmpty()); + } + + @Override + public Result apply(AggregationNode node, Captures captures, Context context) + { + return PushPartialAggregationIntoTableScan(plannerContext, context, node, captures.get(TABLE_SCAN), node.getAggregations(), node.getGroupingSets().getGroupingKeys()) + .map(Rule.Result::ofPlanNode) + .orElseGet(Rule.Result::empty); + } + + public static Optional PushPartialAggregationIntoTableScan( + PlannerContext plannerContext, + Context context, + PlanNode aggregationNode, + TableScanNode tableScan, + Map aggregations, + List groupingKeys) + { + Session session = context.getSession(); + + if (groupingKeys.isEmpty() && aggregations.isEmpty()) { + // Global aggregation with no aggregate functions. No point to push this down into connector. + return Optional.empty(); + } + + Map assignments = tableScan.getAssignments() + .entrySet().stream() + .collect(toImmutableMap(entry -> entry.getKey().name(), Entry::getValue)); + + List> aggregationsList = ImmutableList.copyOf(aggregations.entrySet()); + + List aggregateFunctions = aggregationsList.stream() + .map(Entry::getValue) + .map(PushPartialAggregationIntoTableScan::toAggregateFunction) + .collect(toImmutableList()); + + List aggregationOutputSymbols = aggregationsList.stream() + .map(Entry::getKey) + .collect(toImmutableList()); + + List groupByColumns = groupingKeys.stream() + .map(groupByColumn -> assignments.get(groupByColumn.name())) + .collect(toImmutableList()); + + Optional> aggregationPushdownResult = plannerContext.getMetadata().applyAggregation( + session, + tableScan.getTable(), + aggregateFunctions, + assignments, + ImmutableList.of(groupByColumns)); + + if (aggregationPushdownResult.isEmpty()) { + return Optional.empty(); + } + + AggregationApplicationResult result = aggregationPushdownResult.get(); + + // The new scan outputs should be the symbols associated with grouping columns plus the symbols associated with aggregations. + ImmutableList.Builder newScanOutputs = ImmutableList.builder(); + newScanOutputs.addAll(tableScan.getOutputSymbols()); + + ImmutableBiMap.Builder newScanAssignments = ImmutableBiMap.builder(); + newScanAssignments.putAll(tableScan.getAssignments()); + + Map variableMappings = new HashMap<>(); + + for (Assignment assignment : result.getAssignments()) { + Symbol symbol = context.getSymbolAllocator().newSymbol(assignment.getVariable(), assignment.getType()); + + newScanOutputs.add(symbol); + newScanAssignments.put(symbol, assignment.getColumn()); + variableMappings.put(assignment.getVariable(), symbol); + } + + List newProjections = result.getProjections().stream() + .map(expression -> { + Expression translated = ConnectorExpressionTranslator.translate(session, expression, plannerContext, variableMappings); + // ConnectorExpressionTranslator may or may not preserve optimized form of expressions during round-trip. Avoid potential optimizer loop + // by ensuring expression is optimized. + return newOptimizer(plannerContext).process(translated, session, ImmutableMap.of()).orElse(translated); + }) + .collect(toImmutableList()); + + verify(aggregationOutputSymbols.size() == newProjections.size()); + + Assignments.Builder assignmentBuilder = Assignments.builder(); + IntStream.range(0, aggregationOutputSymbols.size()) + .forEach(index -> assignmentBuilder.put(aggregationOutputSymbols.get(index), newProjections.get(index))); + + ImmutableBiMap scanAssignments = newScanAssignments.build(); + ImmutableBiMap columnHandleToSymbol = scanAssignments.inverse(); + // projections assignmentBuilder should have both agg and group by so we add all the group bys as symbol references + groupingKeys + .forEach(groupBySymbol -> { + // if the connector returned a new mapping from oldColumnHandle to newColumnHandle, groupBy needs to point to + // new columnHandle's symbol reference, otherwise it will continue pointing at oldColumnHandle. + ColumnHandle originalColumnHandle = assignments.get(groupBySymbol.name()); + ColumnHandle groupByColumnHandle = result.getGroupingColumnMapping().getOrDefault(originalColumnHandle, originalColumnHandle); + assignmentBuilder.put(groupBySymbol, columnHandleToSymbol.get(groupByColumnHandle).toSymbolReference()); + }); + + return Optional.of( + new ProjectNode( + context.getIdAllocator().getNextId(), + new TableScanNode( + context.getIdAllocator().getNextId(), + result.getHandle(), + newScanOutputs.build(), + scanAssignments, + TupleDomain.all(), + deriveTableStatisticsForPushdown(context.getStatsProvider(), session, result.isPrecalculateStatistics(), aggregationNode), + tableScan.isUpdateTarget(), + tableScan.getUseConnectorNodePartitioning()), + assignmentBuilder.build())); + } + + private static AggregateFunction toAggregateFunction(AggregationNode.Aggregation aggregation) + { + BoundSignature signature = aggregation.getResolvedFunction().signature(); + + ImmutableList.Builder arguments = ImmutableList.builder(); + for (int i = 0; i < aggregation.getArguments().size(); i++) { + Reference argument = (Reference) aggregation.getArguments().get(i); + arguments.add(new Variable(argument.name(), signature.getArgumentTypes().get(i))); + } + + Optional orderingScheme = aggregation.getOrderingScheme(); + Optional> sortBy = orderingScheme.map(OrderingScheme::toSortItems); + + Optional filter = aggregation.getFilter() + .map(symbol -> new Variable(symbol.name(), symbol.type())); + + return new AggregateFunction( + signature.getName().getFunctionName(), + signature.getReturnType(), + arguments.build(), + sortBy.orElse(ImmutableList.of()), + aggregation.isDistinct(), + filter); + } +} diff --git a/core/trino-spi/src/main/java/io/trino/spi/grpc/Endpoints.java b/core/trino-spi/src/main/java/io/trino/spi/grpc/Endpoints.java new file mode 100644 index 000000000000..aee7db6c1113 --- /dev/null +++ b/core/trino-spi/src/main/java/io/trino/spi/grpc/Endpoints.java @@ -0,0 +1,35310 @@ +// Generated by the protocol buffer compiler. DO NOT EDIT! +// source: endpoints.proto + +package io.trino.spi.grpc; + +public final class Endpoints { + private Endpoints() {} + public static void registerAllExtensions( + com.google.protobuf.ExtensionRegistryLite registry) { + } + + public static void registerAllExtensions( + com.google.protobuf.ExtensionRegistry registry) { + registerAllExtensions( + (com.google.protobuf.ExtensionRegistryLite) registry); + } + /** + * Protobuf enum {@code grpc.ConnectorStatus} + */ + public enum ConnectorStatus + implements com.google.protobuf.ProtocolMessageEnum { + /** + * REGULAR = 0; + */ + REGULAR(0), + /** + * PREVIEW = 1; + */ + PREVIEW(1), + /** + * COMING_SOON = 2; + */ + COMING_SOON(2), + /** + * HIDDEN = 3; + */ + HIDDEN(3), + UNRECOGNIZED(-1), + ; + + /** + * REGULAR = 0; + */ + public static final int REGULAR_VALUE = 0; + /** + * PREVIEW = 1; + */ + public static final int PREVIEW_VALUE = 1; + /** + * COMING_SOON = 2; + */ + public static final int COMING_SOON_VALUE = 2; + /** + * HIDDEN = 3; + */ + public static final int HIDDEN_VALUE = 3; + + + public final int getNumber() { + if (this == UNRECOGNIZED) { + throw new java.lang.IllegalArgumentException( + "Can't get the number of an unknown enum value."); + } + return value; + } + + /** + * @param value The numeric wire value of the corresponding enum entry. + * @return The enum associated with the given numeric wire value. + * @deprecated Use {@link #forNumber(int)} instead. + */ + @java.lang.Deprecated + public static ConnectorStatus valueOf(int value) { + return forNumber(value); + } + + /** + * @param value The numeric wire value of the corresponding enum entry. + * @return The enum associated with the given numeric wire value. + */ + public static ConnectorStatus forNumber(int value) { + switch (value) { + case 0: return REGULAR; + case 1: return PREVIEW; + case 2: return COMING_SOON; + case 3: return HIDDEN; + default: return null; + } + } + + public static com.google.protobuf.Internal.EnumLiteMap + internalGetValueMap() { + return internalValueMap; + } + private static final com.google.protobuf.Internal.EnumLiteMap< + ConnectorStatus> internalValueMap = + new com.google.protobuf.Internal.EnumLiteMap() { + public ConnectorStatus findValueByNumber(int number) { + return ConnectorStatus.forNumber(number); + } + }; + + public final com.google.protobuf.Descriptors.EnumValueDescriptor + getValueDescriptor() { + if (this == UNRECOGNIZED) { + throw new java.lang.IllegalStateException( + "Can't get the descriptor of an unrecognized enum value."); + } + return getDescriptor().getValues().get(ordinal()); + } + public final com.google.protobuf.Descriptors.EnumDescriptor + getDescriptorForType() { + return getDescriptor(); + } + public static final com.google.protobuf.Descriptors.EnumDescriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.getDescriptor().getEnumTypes().get(0); + } + + private static final ConnectorStatus[] VALUES = values(); + + public static ConnectorStatus valueOf( + com.google.protobuf.Descriptors.EnumValueDescriptor desc) { + if (desc.getType() != getDescriptor()) { + throw new java.lang.IllegalArgumentException( + "EnumValueDescriptor is not for this type."); + } + if (desc.getIndex() == -1) { + return UNRECOGNIZED; + } + return VALUES[desc.getIndex()]; + } + + private final int value; + + private ConnectorStatus(int value) { + this.value = value; + } + + // @@protoc_insertion_point(enum_scope:grpc.ConnectorStatus) + } + + public interface ParameterOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.Parameter) + com.google.protobuf.MessageOrBuilder { + + /** + * string id = 1; + * @return The id. + */ + java.lang.String getId(); + /** + * string id = 1; + * @return The bytes for id. + */ + com.google.protobuf.ByteString + getIdBytes(); + + /** + * string name = 2; + * @return The name. + */ + java.lang.String getName(); + /** + * string name = 2; + * @return The bytes for name. + */ + com.google.protobuf.ByteString + getNameBytes(); + + /** + * string display_name = 3; + * @return The displayName. + */ + java.lang.String getDisplayName(); + /** + * string display_name = 3; + * @return The bytes for displayName. + */ + com.google.protobuf.ByteString + getDisplayNameBytes(); + + /** + * optional string const_value = 4; + * @return Whether the constValue field is set. + */ + boolean hasConstValue(); + /** + * optional string const_value = 4; + * @return The constValue. + */ + java.lang.String getConstValue(); + /** + * optional string const_value = 4; + * @return The bytes for constValue. + */ + com.google.protobuf.ByteString + getConstValueBytes(); + + /** + * int32 type = 5; + * @return The type. + */ + int getType(); + + /** + * bool required = 6; + * @return The required. + */ + boolean getRequired(); + + /** + * optional string default = 7; + * @return Whether the default field is set. + */ + boolean hasDefault(); + /** + * optional string default = 7; + * @return The default. + */ + java.lang.String getDefault(); + /** + * optional string default = 7; + * @return The bytes for default. + */ + com.google.protobuf.ByteString + getDefaultBytes(); + + /** + * optional string example = 8; + * @return Whether the example field is set. + */ + boolean hasExample(); + /** + * optional string example = 8; + * @return The example. + */ + java.lang.String getExample(); + /** + * optional string example = 8; + * @return The bytes for example. + */ + com.google.protobuf.ByteString + getExampleBytes(); + + /** + * bool nullable = 9; + * @return The nullable. + */ + boolean getNullable(); + + /** + * string description = 10; + * @return The description. + */ + java.lang.String getDescription(); + /** + * string description = 10; + * @return The bytes for description. + */ + com.google.protobuf.ByteString + getDescriptionBytes(); + + /** + * optional string trino_name = 11; + * @return Whether the trinoName field is set. + */ + boolean hasTrinoName(); + /** + * optional string trino_name = 11; + * @return The trinoName. + */ + java.lang.String getTrinoName(); + /** + * optional string trino_name = 11; + * @return The bytes for trinoName. + */ + com.google.protobuf.ByteString + getTrinoNameBytes(); + } + /** + * Protobuf type {@code grpc.Parameter} + */ + public static final class Parameter extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.Parameter) + ParameterOrBuilder { + private static final long serialVersionUID = 0L; + // Use Parameter.newBuilder() to construct. + private Parameter(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private Parameter() { + id_ = ""; + name_ = ""; + displayName_ = ""; + constValue_ = ""; + default_ = ""; + example_ = ""; + description_ = ""; + trinoName_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new Parameter(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_Parameter_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_Parameter_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.Parameter.class, io.trino.spi.grpc.Endpoints.Parameter.Builder.class); + } + + private int bitField0_; + public static final int ID_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object id_ = ""; + /** + * string id = 1; + * @return The id. + */ + @java.lang.Override + public java.lang.String getId() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } + } + /** + * string id = 1; + * @return The bytes for id. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int NAME_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object name_ = ""; + /** + * string name = 2; + * @return The name. + */ + @java.lang.Override + public java.lang.String getName() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } + } + /** + * string name = 2; + * @return The bytes for name. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int DISPLAY_NAME_FIELD_NUMBER = 3; + @SuppressWarnings("serial") + private volatile java.lang.Object displayName_ = ""; + /** + * string display_name = 3; + * @return The displayName. + */ + @java.lang.Override + public java.lang.String getDisplayName() { + java.lang.Object ref = displayName_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + displayName_ = s; + return s; + } + } + /** + * string display_name = 3; + * @return The bytes for displayName. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getDisplayNameBytes() { + java.lang.Object ref = displayName_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + displayName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int CONST_VALUE_FIELD_NUMBER = 4; + @SuppressWarnings("serial") + private volatile java.lang.Object constValue_ = ""; + /** + * optional string const_value = 4; + * @return Whether the constValue field is set. + */ + @java.lang.Override + public boolean hasConstValue() { + return ((bitField0_ & 0x00000001) != 0); + } + /** + * optional string const_value = 4; + * @return The constValue. + */ + @java.lang.Override + public java.lang.String getConstValue() { + java.lang.Object ref = constValue_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + constValue_ = s; + return s; + } + } + /** + * optional string const_value = 4; + * @return The bytes for constValue. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getConstValueBytes() { + java.lang.Object ref = constValue_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + constValue_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int TYPE_FIELD_NUMBER = 5; + private int type_ = 0; + /** + * int32 type = 5; + * @return The type. + */ + @java.lang.Override + public int getType() { + return type_; + } + + public static final int REQUIRED_FIELD_NUMBER = 6; + private boolean required_ = false; + /** + * bool required = 6; + * @return The required. + */ + @java.lang.Override + public boolean getRequired() { + return required_; + } + + public static final int DEFAULT_FIELD_NUMBER = 7; + @SuppressWarnings("serial") + private volatile java.lang.Object default_ = ""; + /** + * optional string default = 7; + * @return Whether the default field is set. + */ + @java.lang.Override + public boolean hasDefault() { + return ((bitField0_ & 0x00000002) != 0); + } + /** + * optional string default = 7; + * @return The default. + */ + @java.lang.Override + public java.lang.String getDefault() { + java.lang.Object ref = default_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + default_ = s; + return s; + } + } + /** + * optional string default = 7; + * @return The bytes for default. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getDefaultBytes() { + java.lang.Object ref = default_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + default_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int EXAMPLE_FIELD_NUMBER = 8; + @SuppressWarnings("serial") + private volatile java.lang.Object example_ = ""; + /** + * optional string example = 8; + * @return Whether the example field is set. + */ + @java.lang.Override + public boolean hasExample() { + return ((bitField0_ & 0x00000004) != 0); + } + /** + * optional string example = 8; + * @return The example. + */ + @java.lang.Override + public java.lang.String getExample() { + java.lang.Object ref = example_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + example_ = s; + return s; + } + } + /** + * optional string example = 8; + * @return The bytes for example. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getExampleBytes() { + java.lang.Object ref = example_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + example_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int NULLABLE_FIELD_NUMBER = 9; + private boolean nullable_ = false; + /** + * bool nullable = 9; + * @return The nullable. + */ + @java.lang.Override + public boolean getNullable() { + return nullable_; + } + + public static final int DESCRIPTION_FIELD_NUMBER = 10; + @SuppressWarnings("serial") + private volatile java.lang.Object description_ = ""; + /** + * string description = 10; + * @return The description. + */ + @java.lang.Override + public java.lang.String getDescription() { + java.lang.Object ref = description_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + description_ = s; + return s; + } + } + /** + * string description = 10; + * @return The bytes for description. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getDescriptionBytes() { + java.lang.Object ref = description_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + description_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int TRINO_NAME_FIELD_NUMBER = 11; + @SuppressWarnings("serial") + private volatile java.lang.Object trinoName_ = ""; + /** + * optional string trino_name = 11; + * @return Whether the trinoName field is set. + */ + @java.lang.Override + public boolean hasTrinoName() { + return ((bitField0_ & 0x00000008) != 0); + } + /** + * optional string trino_name = 11; + * @return The trinoName. + */ + @java.lang.Override + public java.lang.String getTrinoName() { + java.lang.Object ref = trinoName_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + trinoName_ = s; + return s; + } + } + /** + * optional string trino_name = 11; + * @return The bytes for trinoName. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTrinoNameBytes() { + java.lang.Object ref = trinoName_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + trinoName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, id_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(name_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, name_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(displayName_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 3, displayName_); + } + if (((bitField0_ & 0x00000001) != 0)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 4, constValue_); + } + if (type_ != 0) { + output.writeInt32(5, type_); + } + if (required_ != false) { + output.writeBool(6, required_); + } + if (((bitField0_ & 0x00000002) != 0)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 7, default_); + } + if (((bitField0_ & 0x00000004) != 0)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 8, example_); + } + if (nullable_ != false) { + output.writeBool(9, nullable_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(description_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 10, description_); + } + if (((bitField0_ & 0x00000008) != 0)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 11, trinoName_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, id_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(name_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, name_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(displayName_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(3, displayName_); + } + if (((bitField0_ & 0x00000001) != 0)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(4, constValue_); + } + if (type_ != 0) { + size += com.google.protobuf.CodedOutputStream + .computeInt32Size(5, type_); + } + if (required_ != false) { + size += com.google.protobuf.CodedOutputStream + .computeBoolSize(6, required_); + } + if (((bitField0_ & 0x00000002) != 0)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(7, default_); + } + if (((bitField0_ & 0x00000004) != 0)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(8, example_); + } + if (nullable_ != false) { + size += com.google.protobuf.CodedOutputStream + .computeBoolSize(9, nullable_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(description_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(10, description_); + } + if (((bitField0_ & 0x00000008) != 0)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(11, trinoName_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.Parameter)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.Parameter other = (io.trino.spi.grpc.Endpoints.Parameter) obj; + + if (!getId() + .equals(other.getId())) return false; + if (!getName() + .equals(other.getName())) return false; + if (!getDisplayName() + .equals(other.getDisplayName())) return false; + if (hasConstValue() != other.hasConstValue()) return false; + if (hasConstValue()) { + if (!getConstValue() + .equals(other.getConstValue())) return false; + } + if (getType() + != other.getType()) return false; + if (getRequired() + != other.getRequired()) return false; + if (hasDefault() != other.hasDefault()) return false; + if (hasDefault()) { + if (!getDefault() + .equals(other.getDefault())) return false; + } + if (hasExample() != other.hasExample()) return false; + if (hasExample()) { + if (!getExample() + .equals(other.getExample())) return false; + } + if (getNullable() + != other.getNullable()) return false; + if (!getDescription() + .equals(other.getDescription())) return false; + if (hasTrinoName() != other.hasTrinoName()) return false; + if (hasTrinoName()) { + if (!getTrinoName() + .equals(other.getTrinoName())) return false; + } + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + ID_FIELD_NUMBER; + hash = (53 * hash) + getId().hashCode(); + hash = (37 * hash) + NAME_FIELD_NUMBER; + hash = (53 * hash) + getName().hashCode(); + hash = (37 * hash) + DISPLAY_NAME_FIELD_NUMBER; + hash = (53 * hash) + getDisplayName().hashCode(); + if (hasConstValue()) { + hash = (37 * hash) + CONST_VALUE_FIELD_NUMBER; + hash = (53 * hash) + getConstValue().hashCode(); + } + hash = (37 * hash) + TYPE_FIELD_NUMBER; + hash = (53 * hash) + getType(); + hash = (37 * hash) + REQUIRED_FIELD_NUMBER; + hash = (53 * hash) + com.google.protobuf.Internal.hashBoolean( + getRequired()); + if (hasDefault()) { + hash = (37 * hash) + DEFAULT_FIELD_NUMBER; + hash = (53 * hash) + getDefault().hashCode(); + } + if (hasExample()) { + hash = (37 * hash) + EXAMPLE_FIELD_NUMBER; + hash = (53 * hash) + getExample().hashCode(); + } + hash = (37 * hash) + NULLABLE_FIELD_NUMBER; + hash = (53 * hash) + com.google.protobuf.Internal.hashBoolean( + getNullable()); + hash = (37 * hash) + DESCRIPTION_FIELD_NUMBER; + hash = (53 * hash) + getDescription().hashCode(); + if (hasTrinoName()) { + hash = (37 * hash) + TRINO_NAME_FIELD_NUMBER; + hash = (53 * hash) + getTrinoName().hashCode(); + } + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.Parameter parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.Parameter parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.Parameter parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.Parameter parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.Parameter parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.Parameter parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.Parameter parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.Parameter parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.Parameter parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.Parameter parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.Parameter parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.Parameter parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.Parameter prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.Parameter} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.Parameter) + io.trino.spi.grpc.Endpoints.ParameterOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_Parameter_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_Parameter_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.Parameter.class, io.trino.spi.grpc.Endpoints.Parameter.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.Parameter.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + id_ = ""; + name_ = ""; + displayName_ = ""; + constValue_ = ""; + type_ = 0; + required_ = false; + default_ = ""; + example_ = ""; + nullable_ = false; + description_ = ""; + trinoName_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_Parameter_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.Parameter getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.Parameter.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.Parameter build() { + io.trino.spi.grpc.Endpoints.Parameter result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.Parameter buildPartial() { + io.trino.spi.grpc.Endpoints.Parameter result = new io.trino.spi.grpc.Endpoints.Parameter(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.Parameter result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.id_ = id_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.name_ = name_; + } + if (((from_bitField0_ & 0x00000004) != 0)) { + result.displayName_ = displayName_; + } + int to_bitField0_ = 0; + if (((from_bitField0_ & 0x00000008) != 0)) { + result.constValue_ = constValue_; + to_bitField0_ |= 0x00000001; + } + if (((from_bitField0_ & 0x00000010) != 0)) { + result.type_ = type_; + } + if (((from_bitField0_ & 0x00000020) != 0)) { + result.required_ = required_; + } + if (((from_bitField0_ & 0x00000040) != 0)) { + result.default_ = default_; + to_bitField0_ |= 0x00000002; + } + if (((from_bitField0_ & 0x00000080) != 0)) { + result.example_ = example_; + to_bitField0_ |= 0x00000004; + } + if (((from_bitField0_ & 0x00000100) != 0)) { + result.nullable_ = nullable_; + } + if (((from_bitField0_ & 0x00000200) != 0)) { + result.description_ = description_; + } + if (((from_bitField0_ & 0x00000400) != 0)) { + result.trinoName_ = trinoName_; + to_bitField0_ |= 0x00000008; + } + result.bitField0_ |= to_bitField0_; + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.Parameter) { + return mergeFrom((io.trino.spi.grpc.Endpoints.Parameter)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.Parameter other) { + if (other == io.trino.spi.grpc.Endpoints.Parameter.getDefaultInstance()) return this; + if (!other.getId().isEmpty()) { + id_ = other.id_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getName().isEmpty()) { + name_ = other.name_; + bitField0_ |= 0x00000002; + onChanged(); + } + if (!other.getDisplayName().isEmpty()) { + displayName_ = other.displayName_; + bitField0_ |= 0x00000004; + onChanged(); + } + if (other.hasConstValue()) { + constValue_ = other.constValue_; + bitField0_ |= 0x00000008; + onChanged(); + } + if (other.getType() != 0) { + setType(other.getType()); + } + if (other.getRequired() != false) { + setRequired(other.getRequired()); + } + if (other.hasDefault()) { + default_ = other.default_; + bitField0_ |= 0x00000040; + onChanged(); + } + if (other.hasExample()) { + example_ = other.example_; + bitField0_ |= 0x00000080; + onChanged(); + } + if (other.getNullable() != false) { + setNullable(other.getNullable()); + } + if (!other.getDescription().isEmpty()) { + description_ = other.description_; + bitField0_ |= 0x00000200; + onChanged(); + } + if (other.hasTrinoName()) { + trinoName_ = other.trinoName_; + bitField0_ |= 0x00000400; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + id_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + name_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + case 26: { + displayName_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000004; + break; + } // case 26 + case 34: { + constValue_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000008; + break; + } // case 34 + case 40: { + type_ = input.readInt32(); + bitField0_ |= 0x00000010; + break; + } // case 40 + case 48: { + required_ = input.readBool(); + bitField0_ |= 0x00000020; + break; + } // case 48 + case 58: { + default_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000040; + break; + } // case 58 + case 66: { + example_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000080; + break; + } // case 66 + case 72: { + nullable_ = input.readBool(); + bitField0_ |= 0x00000100; + break; + } // case 72 + case 82: { + description_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000200; + break; + } // case 82 + case 90: { + trinoName_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000400; + break; + } // case 90 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object id_ = ""; + /** + * string id = 1; + * @return The id. + */ + public java.lang.String getId() { + java.lang.Object ref = id_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string id = 1; + * @return The bytes for id. + */ + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string id = 1; + * @param value The id to set. + * @return This builder for chaining. + */ + public Builder setId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + id_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string id = 1; + * @return This builder for chaining. + */ + public Builder clearId() { + id_ = getDefaultInstance().getId(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string id = 1; + * @param value The bytes for id to set. + * @return This builder for chaining. + */ + public Builder setIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + id_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object name_ = ""; + /** + * string name = 2; + * @return The name. + */ + public java.lang.String getName() { + java.lang.Object ref = name_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string name = 2; + * @return The bytes for name. + */ + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string name = 2; + * @param value The name to set. + * @return This builder for chaining. + */ + public Builder setName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + name_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string name = 2; + * @return This builder for chaining. + */ + public Builder clearName() { + name_ = getDefaultInstance().getName(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string name = 2; + * @param value The bytes for name to set. + * @return This builder for chaining. + */ + public Builder setNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + name_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + + private java.lang.Object displayName_ = ""; + /** + * string display_name = 3; + * @return The displayName. + */ + public java.lang.String getDisplayName() { + java.lang.Object ref = displayName_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + displayName_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string display_name = 3; + * @return The bytes for displayName. + */ + public com.google.protobuf.ByteString + getDisplayNameBytes() { + java.lang.Object ref = displayName_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + displayName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string display_name = 3; + * @param value The displayName to set. + * @return This builder for chaining. + */ + public Builder setDisplayName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + displayName_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + /** + * string display_name = 3; + * @return This builder for chaining. + */ + public Builder clearDisplayName() { + displayName_ = getDefaultInstance().getDisplayName(); + bitField0_ = (bitField0_ & ~0x00000004); + onChanged(); + return this; + } + /** + * string display_name = 3; + * @param value The bytes for displayName to set. + * @return This builder for chaining. + */ + public Builder setDisplayNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + displayName_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + + private java.lang.Object constValue_ = ""; + /** + * optional string const_value = 4; + * @return Whether the constValue field is set. + */ + public boolean hasConstValue() { + return ((bitField0_ & 0x00000008) != 0); + } + /** + * optional string const_value = 4; + * @return The constValue. + */ + public java.lang.String getConstValue() { + java.lang.Object ref = constValue_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + constValue_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * optional string const_value = 4; + * @return The bytes for constValue. + */ + public com.google.protobuf.ByteString + getConstValueBytes() { + java.lang.Object ref = constValue_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + constValue_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * optional string const_value = 4; + * @param value The constValue to set. + * @return This builder for chaining. + */ + public Builder setConstValue( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + constValue_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + /** + * optional string const_value = 4; + * @return This builder for chaining. + */ + public Builder clearConstValue() { + constValue_ = getDefaultInstance().getConstValue(); + bitField0_ = (bitField0_ & ~0x00000008); + onChanged(); + return this; + } + /** + * optional string const_value = 4; + * @param value The bytes for constValue to set. + * @return This builder for chaining. + */ + public Builder setConstValueBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + constValue_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + + private int type_ ; + /** + * int32 type = 5; + * @return The type. + */ + @java.lang.Override + public int getType() { + return type_; + } + /** + * int32 type = 5; + * @param value The type to set. + * @return This builder for chaining. + */ + public Builder setType(int value) { + + type_ = value; + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + /** + * int32 type = 5; + * @return This builder for chaining. + */ + public Builder clearType() { + bitField0_ = (bitField0_ & ~0x00000010); + type_ = 0; + onChanged(); + return this; + } + + private boolean required_ ; + /** + * bool required = 6; + * @return The required. + */ + @java.lang.Override + public boolean getRequired() { + return required_; + } + /** + * bool required = 6; + * @param value The required to set. + * @return This builder for chaining. + */ + public Builder setRequired(boolean value) { + + required_ = value; + bitField0_ |= 0x00000020; + onChanged(); + return this; + } + /** + * bool required = 6; + * @return This builder for chaining. + */ + public Builder clearRequired() { + bitField0_ = (bitField0_ & ~0x00000020); + required_ = false; + onChanged(); + return this; + } + + private java.lang.Object default_ = ""; + /** + * optional string default = 7; + * @return Whether the default field is set. + */ + public boolean hasDefault() { + return ((bitField0_ & 0x00000040) != 0); + } + /** + * optional string default = 7; + * @return The default. + */ + public java.lang.String getDefault() { + java.lang.Object ref = default_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + default_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * optional string default = 7; + * @return The bytes for default. + */ + public com.google.protobuf.ByteString + getDefaultBytes() { + java.lang.Object ref = default_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + default_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * optional string default = 7; + * @param value The default to set. + * @return This builder for chaining. + */ + public Builder setDefault( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + default_ = value; + bitField0_ |= 0x00000040; + onChanged(); + return this; + } + /** + * optional string default = 7; + * @return This builder for chaining. + */ + public Builder clearDefault() { + default_ = getDefaultInstance().getDefault(); + bitField0_ = (bitField0_ & ~0x00000040); + onChanged(); + return this; + } + /** + * optional string default = 7; + * @param value The bytes for default to set. + * @return This builder for chaining. + */ + public Builder setDefaultBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + default_ = value; + bitField0_ |= 0x00000040; + onChanged(); + return this; + } + + private java.lang.Object example_ = ""; + /** + * optional string example = 8; + * @return Whether the example field is set. + */ + public boolean hasExample() { + return ((bitField0_ & 0x00000080) != 0); + } + /** + * optional string example = 8; + * @return The example. + */ + public java.lang.String getExample() { + java.lang.Object ref = example_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + example_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * optional string example = 8; + * @return The bytes for example. + */ + public com.google.protobuf.ByteString + getExampleBytes() { + java.lang.Object ref = example_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + example_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * optional string example = 8; + * @param value The example to set. + * @return This builder for chaining. + */ + public Builder setExample( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + example_ = value; + bitField0_ |= 0x00000080; + onChanged(); + return this; + } + /** + * optional string example = 8; + * @return This builder for chaining. + */ + public Builder clearExample() { + example_ = getDefaultInstance().getExample(); + bitField0_ = (bitField0_ & ~0x00000080); + onChanged(); + return this; + } + /** + * optional string example = 8; + * @param value The bytes for example to set. + * @return This builder for chaining. + */ + public Builder setExampleBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + example_ = value; + bitField0_ |= 0x00000080; + onChanged(); + return this; + } + + private boolean nullable_ ; + /** + * bool nullable = 9; + * @return The nullable. + */ + @java.lang.Override + public boolean getNullable() { + return nullable_; + } + /** + * bool nullable = 9; + * @param value The nullable to set. + * @return This builder for chaining. + */ + public Builder setNullable(boolean value) { + + nullable_ = value; + bitField0_ |= 0x00000100; + onChanged(); + return this; + } + /** + * bool nullable = 9; + * @return This builder for chaining. + */ + public Builder clearNullable() { + bitField0_ = (bitField0_ & ~0x00000100); + nullable_ = false; + onChanged(); + return this; + } + + private java.lang.Object description_ = ""; + /** + * string description = 10; + * @return The description. + */ + public java.lang.String getDescription() { + java.lang.Object ref = description_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + description_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string description = 10; + * @return The bytes for description. + */ + public com.google.protobuf.ByteString + getDescriptionBytes() { + java.lang.Object ref = description_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + description_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string description = 10; + * @param value The description to set. + * @return This builder for chaining. + */ + public Builder setDescription( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + description_ = value; + bitField0_ |= 0x00000200; + onChanged(); + return this; + } + /** + * string description = 10; + * @return This builder for chaining. + */ + public Builder clearDescription() { + description_ = getDefaultInstance().getDescription(); + bitField0_ = (bitField0_ & ~0x00000200); + onChanged(); + return this; + } + /** + * string description = 10; + * @param value The bytes for description to set. + * @return This builder for chaining. + */ + public Builder setDescriptionBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + description_ = value; + bitField0_ |= 0x00000200; + onChanged(); + return this; + } + + private java.lang.Object trinoName_ = ""; + /** + * optional string trino_name = 11; + * @return Whether the trinoName field is set. + */ + public boolean hasTrinoName() { + return ((bitField0_ & 0x00000400) != 0); + } + /** + * optional string trino_name = 11; + * @return The trinoName. + */ + public java.lang.String getTrinoName() { + java.lang.Object ref = trinoName_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + trinoName_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * optional string trino_name = 11; + * @return The bytes for trinoName. + */ + public com.google.protobuf.ByteString + getTrinoNameBytes() { + java.lang.Object ref = trinoName_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + trinoName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * optional string trino_name = 11; + * @param value The trinoName to set. + * @return This builder for chaining. + */ + public Builder setTrinoName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + trinoName_ = value; + bitField0_ |= 0x00000400; + onChanged(); + return this; + } + /** + * optional string trino_name = 11; + * @return This builder for chaining. + */ + public Builder clearTrinoName() { + trinoName_ = getDefaultInstance().getTrinoName(); + bitField0_ = (bitField0_ & ~0x00000400); + onChanged(); + return this; + } + /** + * optional string trino_name = 11; + * @param value The bytes for trinoName to set. + * @return This builder for chaining. + */ + public Builder setTrinoNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + trinoName_ = value; + bitField0_ |= 0x00000400; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.Parameter) + } + + // @@protoc_insertion_point(class_scope:grpc.Parameter) + private static final io.trino.spi.grpc.Endpoints.Parameter DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.Parameter(); + } + + public static io.trino.spi.grpc.Endpoints.Parameter getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public Parameter parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.Parameter getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface ConnectorOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.Connector) + com.google.protobuf.MessageOrBuilder { + + /** + * string id = 1; + * @return The id. + */ + java.lang.String getId(); + /** + * string id = 1; + * @return The bytes for id. + */ + com.google.protobuf.ByteString + getIdBytes(); + + /** + * string name = 2; + * @return The name. + */ + java.lang.String getName(); + /** + * string name = 2; + * @return The bytes for name. + */ + com.google.protobuf.ByteString + getNameBytes(); + + /** + * optional string description = 3; + * @return Whether the description field is set. + */ + boolean hasDescription(); + /** + * optional string description = 3; + * @return The description. + */ + java.lang.String getDescription(); + /** + * optional string description = 3; + * @return The bytes for description. + */ + com.google.protobuf.ByteString + getDescriptionBytes(); + + /** + * string base_url_format = 4; + * @return The baseUrlFormat. + */ + java.lang.String getBaseUrlFormat(); + /** + * string base_url_format = 4; + * @return The bytes for baseUrlFormat. + */ + com.google.protobuf.ByteString + getBaseUrlFormatBytes(); + + /** + * bytes base_url_params = 5; + * @return The baseUrlParams. + */ + com.google.protobuf.ByteString getBaseUrlParams(); + + /** + * string capabilities = 6; + * @return The capabilities. + */ + java.lang.String getCapabilities(); + /** + * string capabilities = 6; + * @return The bytes for capabilities. + */ + com.google.protobuf.ByteString + getCapabilitiesBytes(); + + /** + * optional string category = 7; + * @return Whether the category field is set. + */ + boolean hasCategory(); + /** + * optional string category = 7; + * @return The category. + */ + java.lang.String getCategory(); + /** + * optional string category = 7; + * @return The bytes for category. + */ + com.google.protobuf.ByteString + getCategoryBytes(); + + /** + * .grpc.ConnectorStatus connector_status = 8; + * @return The enum numeric value on the wire for connectorStatus. + */ + int getConnectorStatusValue(); + /** + * .grpc.ConnectorStatus connector_status = 8; + * @return The connectorStatus. + */ + io.trino.spi.grpc.Endpoints.ConnectorStatus getConnectorStatus(); + } + /** + * Protobuf type {@code grpc.Connector} + */ + public static final class Connector extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.Connector) + ConnectorOrBuilder { + private static final long serialVersionUID = 0L; + // Use Connector.newBuilder() to construct. + private Connector(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private Connector() { + id_ = ""; + name_ = ""; + description_ = ""; + baseUrlFormat_ = ""; + baseUrlParams_ = com.google.protobuf.ByteString.EMPTY; + capabilities_ = ""; + category_ = ""; + connectorStatus_ = 0; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new Connector(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_Connector_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_Connector_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.Connector.class, io.trino.spi.grpc.Endpoints.Connector.Builder.class); + } + + private int bitField0_; + public static final int ID_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object id_ = ""; + /** + * string id = 1; + * @return The id. + */ + @java.lang.Override + public java.lang.String getId() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } + } + /** + * string id = 1; + * @return The bytes for id. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int NAME_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object name_ = ""; + /** + * string name = 2; + * @return The name. + */ + @java.lang.Override + public java.lang.String getName() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } + } + /** + * string name = 2; + * @return The bytes for name. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int DESCRIPTION_FIELD_NUMBER = 3; + @SuppressWarnings("serial") + private volatile java.lang.Object description_ = ""; + /** + * optional string description = 3; + * @return Whether the description field is set. + */ + @java.lang.Override + public boolean hasDescription() { + return ((bitField0_ & 0x00000001) != 0); + } + /** + * optional string description = 3; + * @return The description. + */ + @java.lang.Override + public java.lang.String getDescription() { + java.lang.Object ref = description_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + description_ = s; + return s; + } + } + /** + * optional string description = 3; + * @return The bytes for description. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getDescriptionBytes() { + java.lang.Object ref = description_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + description_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int BASE_URL_FORMAT_FIELD_NUMBER = 4; + @SuppressWarnings("serial") + private volatile java.lang.Object baseUrlFormat_ = ""; + /** + * string base_url_format = 4; + * @return The baseUrlFormat. + */ + @java.lang.Override + public java.lang.String getBaseUrlFormat() { + java.lang.Object ref = baseUrlFormat_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + baseUrlFormat_ = s; + return s; + } + } + /** + * string base_url_format = 4; + * @return The bytes for baseUrlFormat. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getBaseUrlFormatBytes() { + java.lang.Object ref = baseUrlFormat_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + baseUrlFormat_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int BASE_URL_PARAMS_FIELD_NUMBER = 5; + private com.google.protobuf.ByteString baseUrlParams_ = com.google.protobuf.ByteString.EMPTY; + /** + * bytes base_url_params = 5; + * @return The baseUrlParams. + */ + @java.lang.Override + public com.google.protobuf.ByteString getBaseUrlParams() { + return baseUrlParams_; + } + + public static final int CAPABILITIES_FIELD_NUMBER = 6; + @SuppressWarnings("serial") + private volatile java.lang.Object capabilities_ = ""; + /** + * string capabilities = 6; + * @return The capabilities. + */ + @java.lang.Override + public java.lang.String getCapabilities() { + java.lang.Object ref = capabilities_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + capabilities_ = s; + return s; + } + } + /** + * string capabilities = 6; + * @return The bytes for capabilities. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getCapabilitiesBytes() { + java.lang.Object ref = capabilities_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + capabilities_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int CATEGORY_FIELD_NUMBER = 7; + @SuppressWarnings("serial") + private volatile java.lang.Object category_ = ""; + /** + * optional string category = 7; + * @return Whether the category field is set. + */ + @java.lang.Override + public boolean hasCategory() { + return ((bitField0_ & 0x00000002) != 0); + } + /** + * optional string category = 7; + * @return The category. + */ + @java.lang.Override + public java.lang.String getCategory() { + java.lang.Object ref = category_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + category_ = s; + return s; + } + } + /** + * optional string category = 7; + * @return The bytes for category. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getCategoryBytes() { + java.lang.Object ref = category_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + category_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int CONNECTOR_STATUS_FIELD_NUMBER = 8; + private int connectorStatus_ = 0; + /** + * .grpc.ConnectorStatus connector_status = 8; + * @return The enum numeric value on the wire for connectorStatus. + */ + @java.lang.Override public int getConnectorStatusValue() { + return connectorStatus_; + } + /** + * .grpc.ConnectorStatus connector_status = 8; + * @return The connectorStatus. + */ + @java.lang.Override public io.trino.spi.grpc.Endpoints.ConnectorStatus getConnectorStatus() { + io.trino.spi.grpc.Endpoints.ConnectorStatus result = io.trino.spi.grpc.Endpoints.ConnectorStatus.forNumber(connectorStatus_); + return result == null ? io.trino.spi.grpc.Endpoints.ConnectorStatus.UNRECOGNIZED : result; + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, id_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(name_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, name_); + } + if (((bitField0_ & 0x00000001) != 0)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 3, description_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(baseUrlFormat_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 4, baseUrlFormat_); + } + if (!baseUrlParams_.isEmpty()) { + output.writeBytes(5, baseUrlParams_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(capabilities_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 6, capabilities_); + } + if (((bitField0_ & 0x00000002) != 0)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 7, category_); + } + if (connectorStatus_ != io.trino.spi.grpc.Endpoints.ConnectorStatus.REGULAR.getNumber()) { + output.writeEnum(8, connectorStatus_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, id_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(name_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, name_); + } + if (((bitField0_ & 0x00000001) != 0)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(3, description_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(baseUrlFormat_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(4, baseUrlFormat_); + } + if (!baseUrlParams_.isEmpty()) { + size += com.google.protobuf.CodedOutputStream + .computeBytesSize(5, baseUrlParams_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(capabilities_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(6, capabilities_); + } + if (((bitField0_ & 0x00000002) != 0)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(7, category_); + } + if (connectorStatus_ != io.trino.spi.grpc.Endpoints.ConnectorStatus.REGULAR.getNumber()) { + size += com.google.protobuf.CodedOutputStream + .computeEnumSize(8, connectorStatus_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.Connector)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.Connector other = (io.trino.spi.grpc.Endpoints.Connector) obj; + + if (!getId() + .equals(other.getId())) return false; + if (!getName() + .equals(other.getName())) return false; + if (hasDescription() != other.hasDescription()) return false; + if (hasDescription()) { + if (!getDescription() + .equals(other.getDescription())) return false; + } + if (!getBaseUrlFormat() + .equals(other.getBaseUrlFormat())) return false; + if (!getBaseUrlParams() + .equals(other.getBaseUrlParams())) return false; + if (!getCapabilities() + .equals(other.getCapabilities())) return false; + if (hasCategory() != other.hasCategory()) return false; + if (hasCategory()) { + if (!getCategory() + .equals(other.getCategory())) return false; + } + if (connectorStatus_ != other.connectorStatus_) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + ID_FIELD_NUMBER; + hash = (53 * hash) + getId().hashCode(); + hash = (37 * hash) + NAME_FIELD_NUMBER; + hash = (53 * hash) + getName().hashCode(); + if (hasDescription()) { + hash = (37 * hash) + DESCRIPTION_FIELD_NUMBER; + hash = (53 * hash) + getDescription().hashCode(); + } + hash = (37 * hash) + BASE_URL_FORMAT_FIELD_NUMBER; + hash = (53 * hash) + getBaseUrlFormat().hashCode(); + hash = (37 * hash) + BASE_URL_PARAMS_FIELD_NUMBER; + hash = (53 * hash) + getBaseUrlParams().hashCode(); + hash = (37 * hash) + CAPABILITIES_FIELD_NUMBER; + hash = (53 * hash) + getCapabilities().hashCode(); + if (hasCategory()) { + hash = (37 * hash) + CATEGORY_FIELD_NUMBER; + hash = (53 * hash) + getCategory().hashCode(); + } + hash = (37 * hash) + CONNECTOR_STATUS_FIELD_NUMBER; + hash = (53 * hash) + connectorStatus_; + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.Connector parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.Connector parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.Connector parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.Connector parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.Connector parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.Connector parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.Connector parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.Connector parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.Connector parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.Connector parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.Connector parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.Connector parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.Connector prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.Connector} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.Connector) + io.trino.spi.grpc.Endpoints.ConnectorOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_Connector_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_Connector_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.Connector.class, io.trino.spi.grpc.Endpoints.Connector.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.Connector.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + id_ = ""; + name_ = ""; + description_ = ""; + baseUrlFormat_ = ""; + baseUrlParams_ = com.google.protobuf.ByteString.EMPTY; + capabilities_ = ""; + category_ = ""; + connectorStatus_ = 0; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_Connector_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.Connector getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.Connector.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.Connector build() { + io.trino.spi.grpc.Endpoints.Connector result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.Connector buildPartial() { + io.trino.spi.grpc.Endpoints.Connector result = new io.trino.spi.grpc.Endpoints.Connector(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.Connector result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.id_ = id_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.name_ = name_; + } + int to_bitField0_ = 0; + if (((from_bitField0_ & 0x00000004) != 0)) { + result.description_ = description_; + to_bitField0_ |= 0x00000001; + } + if (((from_bitField0_ & 0x00000008) != 0)) { + result.baseUrlFormat_ = baseUrlFormat_; + } + if (((from_bitField0_ & 0x00000010) != 0)) { + result.baseUrlParams_ = baseUrlParams_; + } + if (((from_bitField0_ & 0x00000020) != 0)) { + result.capabilities_ = capabilities_; + } + if (((from_bitField0_ & 0x00000040) != 0)) { + result.category_ = category_; + to_bitField0_ |= 0x00000002; + } + if (((from_bitField0_ & 0x00000080) != 0)) { + result.connectorStatus_ = connectorStatus_; + } + result.bitField0_ |= to_bitField0_; + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.Connector) { + return mergeFrom((io.trino.spi.grpc.Endpoints.Connector)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.Connector other) { + if (other == io.trino.spi.grpc.Endpoints.Connector.getDefaultInstance()) return this; + if (!other.getId().isEmpty()) { + id_ = other.id_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getName().isEmpty()) { + name_ = other.name_; + bitField0_ |= 0x00000002; + onChanged(); + } + if (other.hasDescription()) { + description_ = other.description_; + bitField0_ |= 0x00000004; + onChanged(); + } + if (!other.getBaseUrlFormat().isEmpty()) { + baseUrlFormat_ = other.baseUrlFormat_; + bitField0_ |= 0x00000008; + onChanged(); + } + if (other.getBaseUrlParams() != com.google.protobuf.ByteString.EMPTY) { + setBaseUrlParams(other.getBaseUrlParams()); + } + if (!other.getCapabilities().isEmpty()) { + capabilities_ = other.capabilities_; + bitField0_ |= 0x00000020; + onChanged(); + } + if (other.hasCategory()) { + category_ = other.category_; + bitField0_ |= 0x00000040; + onChanged(); + } + if (other.connectorStatus_ != 0) { + setConnectorStatusValue(other.getConnectorStatusValue()); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + id_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + name_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + case 26: { + description_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000004; + break; + } // case 26 + case 34: { + baseUrlFormat_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000008; + break; + } // case 34 + case 42: { + baseUrlParams_ = input.readBytes(); + bitField0_ |= 0x00000010; + break; + } // case 42 + case 50: { + capabilities_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000020; + break; + } // case 50 + case 58: { + category_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000040; + break; + } // case 58 + case 64: { + connectorStatus_ = input.readEnum(); + bitField0_ |= 0x00000080; + break; + } // case 64 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object id_ = ""; + /** + * string id = 1; + * @return The id. + */ + public java.lang.String getId() { + java.lang.Object ref = id_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string id = 1; + * @return The bytes for id. + */ + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string id = 1; + * @param value The id to set. + * @return This builder for chaining. + */ + public Builder setId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + id_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string id = 1; + * @return This builder for chaining. + */ + public Builder clearId() { + id_ = getDefaultInstance().getId(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string id = 1; + * @param value The bytes for id to set. + * @return This builder for chaining. + */ + public Builder setIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + id_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object name_ = ""; + /** + * string name = 2; + * @return The name. + */ + public java.lang.String getName() { + java.lang.Object ref = name_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string name = 2; + * @return The bytes for name. + */ + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string name = 2; + * @param value The name to set. + * @return This builder for chaining. + */ + public Builder setName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + name_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string name = 2; + * @return This builder for chaining. + */ + public Builder clearName() { + name_ = getDefaultInstance().getName(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string name = 2; + * @param value The bytes for name to set. + * @return This builder for chaining. + */ + public Builder setNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + name_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + + private java.lang.Object description_ = ""; + /** + * optional string description = 3; + * @return Whether the description field is set. + */ + public boolean hasDescription() { + return ((bitField0_ & 0x00000004) != 0); + } + /** + * optional string description = 3; + * @return The description. + */ + public java.lang.String getDescription() { + java.lang.Object ref = description_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + description_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * optional string description = 3; + * @return The bytes for description. + */ + public com.google.protobuf.ByteString + getDescriptionBytes() { + java.lang.Object ref = description_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + description_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * optional string description = 3; + * @param value The description to set. + * @return This builder for chaining. + */ + public Builder setDescription( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + description_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + /** + * optional string description = 3; + * @return This builder for chaining. + */ + public Builder clearDescription() { + description_ = getDefaultInstance().getDescription(); + bitField0_ = (bitField0_ & ~0x00000004); + onChanged(); + return this; + } + /** + * optional string description = 3; + * @param value The bytes for description to set. + * @return This builder for chaining. + */ + public Builder setDescriptionBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + description_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + + private java.lang.Object baseUrlFormat_ = ""; + /** + * string base_url_format = 4; + * @return The baseUrlFormat. + */ + public java.lang.String getBaseUrlFormat() { + java.lang.Object ref = baseUrlFormat_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + baseUrlFormat_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string base_url_format = 4; + * @return The bytes for baseUrlFormat. + */ + public com.google.protobuf.ByteString + getBaseUrlFormatBytes() { + java.lang.Object ref = baseUrlFormat_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + baseUrlFormat_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string base_url_format = 4; + * @param value The baseUrlFormat to set. + * @return This builder for chaining. + */ + public Builder setBaseUrlFormat( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + baseUrlFormat_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + /** + * string base_url_format = 4; + * @return This builder for chaining. + */ + public Builder clearBaseUrlFormat() { + baseUrlFormat_ = getDefaultInstance().getBaseUrlFormat(); + bitField0_ = (bitField0_ & ~0x00000008); + onChanged(); + return this; + } + /** + * string base_url_format = 4; + * @param value The bytes for baseUrlFormat to set. + * @return This builder for chaining. + */ + public Builder setBaseUrlFormatBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + baseUrlFormat_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + + private com.google.protobuf.ByteString baseUrlParams_ = com.google.protobuf.ByteString.EMPTY; + /** + * bytes base_url_params = 5; + * @return The baseUrlParams. + */ + @java.lang.Override + public com.google.protobuf.ByteString getBaseUrlParams() { + return baseUrlParams_; + } + /** + * bytes base_url_params = 5; + * @param value The baseUrlParams to set. + * @return This builder for chaining. + */ + public Builder setBaseUrlParams(com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + baseUrlParams_ = value; + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + /** + * bytes base_url_params = 5; + * @return This builder for chaining. + */ + public Builder clearBaseUrlParams() { + bitField0_ = (bitField0_ & ~0x00000010); + baseUrlParams_ = getDefaultInstance().getBaseUrlParams(); + onChanged(); + return this; + } + + private java.lang.Object capabilities_ = ""; + /** + * string capabilities = 6; + * @return The capabilities. + */ + public java.lang.String getCapabilities() { + java.lang.Object ref = capabilities_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + capabilities_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string capabilities = 6; + * @return The bytes for capabilities. + */ + public com.google.protobuf.ByteString + getCapabilitiesBytes() { + java.lang.Object ref = capabilities_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + capabilities_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string capabilities = 6; + * @param value The capabilities to set. + * @return This builder for chaining. + */ + public Builder setCapabilities( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + capabilities_ = value; + bitField0_ |= 0x00000020; + onChanged(); + return this; + } + /** + * string capabilities = 6; + * @return This builder for chaining. + */ + public Builder clearCapabilities() { + capabilities_ = getDefaultInstance().getCapabilities(); + bitField0_ = (bitField0_ & ~0x00000020); + onChanged(); + return this; + } + /** + * string capabilities = 6; + * @param value The bytes for capabilities to set. + * @return This builder for chaining. + */ + public Builder setCapabilitiesBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + capabilities_ = value; + bitField0_ |= 0x00000020; + onChanged(); + return this; + } + + private java.lang.Object category_ = ""; + /** + * optional string category = 7; + * @return Whether the category field is set. + */ + public boolean hasCategory() { + return ((bitField0_ & 0x00000040) != 0); + } + /** + * optional string category = 7; + * @return The category. + */ + public java.lang.String getCategory() { + java.lang.Object ref = category_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + category_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * optional string category = 7; + * @return The bytes for category. + */ + public com.google.protobuf.ByteString + getCategoryBytes() { + java.lang.Object ref = category_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + category_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * optional string category = 7; + * @param value The category to set. + * @return This builder for chaining. + */ + public Builder setCategory( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + category_ = value; + bitField0_ |= 0x00000040; + onChanged(); + return this; + } + /** + * optional string category = 7; + * @return This builder for chaining. + */ + public Builder clearCategory() { + category_ = getDefaultInstance().getCategory(); + bitField0_ = (bitField0_ & ~0x00000040); + onChanged(); + return this; + } + /** + * optional string category = 7; + * @param value The bytes for category to set. + * @return This builder for chaining. + */ + public Builder setCategoryBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + category_ = value; + bitField0_ |= 0x00000040; + onChanged(); + return this; + } + + private int connectorStatus_ = 0; + /** + * .grpc.ConnectorStatus connector_status = 8; + * @return The enum numeric value on the wire for connectorStatus. + */ + @java.lang.Override public int getConnectorStatusValue() { + return connectorStatus_; + } + /** + * .grpc.ConnectorStatus connector_status = 8; + * @param value The enum numeric value on the wire for connectorStatus to set. + * @return This builder for chaining. + */ + public Builder setConnectorStatusValue(int value) { + connectorStatus_ = value; + bitField0_ |= 0x00000080; + onChanged(); + return this; + } + /** + * .grpc.ConnectorStatus connector_status = 8; + * @return The connectorStatus. + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.ConnectorStatus getConnectorStatus() { + io.trino.spi.grpc.Endpoints.ConnectorStatus result = io.trino.spi.grpc.Endpoints.ConnectorStatus.forNumber(connectorStatus_); + return result == null ? io.trino.spi.grpc.Endpoints.ConnectorStatus.UNRECOGNIZED : result; + } + /** + * .grpc.ConnectorStatus connector_status = 8; + * @param value The connectorStatus to set. + * @return This builder for chaining. + */ + public Builder setConnectorStatus(io.trino.spi.grpc.Endpoints.ConnectorStatus value) { + if (value == null) { + throw new NullPointerException(); + } + bitField0_ |= 0x00000080; + connectorStatus_ = value.getNumber(); + onChanged(); + return this; + } + /** + * .grpc.ConnectorStatus connector_status = 8; + * @return This builder for chaining. + */ + public Builder clearConnectorStatus() { + bitField0_ = (bitField0_ & ~0x00000080); + connectorStatus_ = 0; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.Connector) + } + + // @@protoc_insertion_point(class_scope:grpc.Connector) + private static final io.trino.spi.grpc.Endpoints.Connector DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.Connector(); + } + + public static io.trino.spi.grpc.Endpoints.Connector getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public Connector parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.Connector getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface DataSourceOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.DataSource) + com.google.protobuf.MessageOrBuilder { + + /** + * string id = 1; + * @return The id. + */ + java.lang.String getId(); + /** + * string id = 1; + * @return The bytes for id. + */ + com.google.protobuf.ByteString + getIdBytes(); + + /** + * string vendor = 2; + * @return The vendor. + */ + java.lang.String getVendor(); + /** + * string vendor = 2; + * @return The bytes for vendor. + */ + com.google.protobuf.ByteString + getVendorBytes(); + + /** + * optional string product = 3; + * @return Whether the product field is set. + */ + boolean hasProduct(); + /** + * optional string product = 3; + * @return The product. + */ + java.lang.String getProduct(); + /** + * optional string product = 3; + * @return The bytes for product. + */ + com.google.protobuf.ByteString + getProductBytes(); + + /** + * string type = 4; + * @return The type. + */ + java.lang.String getType(); + /** + * string type = 4; + * @return The bytes for type. + */ + com.google.protobuf.ByteString + getTypeBytes(); + + /** + * string name = 5; + * @return The name. + */ + java.lang.String getName(); + /** + * string name = 5; + * @return The bytes for name. + */ + com.google.protobuf.ByteString + getNameBytes(); + + /** + * string display_name = 6; + * @return The displayName. + */ + java.lang.String getDisplayName(); + /** + * string display_name = 6; + * @return The bytes for displayName. + */ + com.google.protobuf.ByteString + getDisplayNameBytes(); + } + /** + * Protobuf type {@code grpc.DataSource} + */ + public static final class DataSource extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.DataSource) + DataSourceOrBuilder { + private static final long serialVersionUID = 0L; + // Use DataSource.newBuilder() to construct. + private DataSource(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private DataSource() { + id_ = ""; + vendor_ = ""; + product_ = ""; + type_ = ""; + name_ = ""; + displayName_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new DataSource(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSource_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSource_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.DataSource.class, io.trino.spi.grpc.Endpoints.DataSource.Builder.class); + } + + private int bitField0_; + public static final int ID_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object id_ = ""; + /** + * string id = 1; + * @return The id. + */ + @java.lang.Override + public java.lang.String getId() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } + } + /** + * string id = 1; + * @return The bytes for id. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int VENDOR_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object vendor_ = ""; + /** + * string vendor = 2; + * @return The vendor. + */ + @java.lang.Override + public java.lang.String getVendor() { + java.lang.Object ref = vendor_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + vendor_ = s; + return s; + } + } + /** + * string vendor = 2; + * @return The bytes for vendor. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getVendorBytes() { + java.lang.Object ref = vendor_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + vendor_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int PRODUCT_FIELD_NUMBER = 3; + @SuppressWarnings("serial") + private volatile java.lang.Object product_ = ""; + /** + * optional string product = 3; + * @return Whether the product field is set. + */ + @java.lang.Override + public boolean hasProduct() { + return ((bitField0_ & 0x00000001) != 0); + } + /** + * optional string product = 3; + * @return The product. + */ + @java.lang.Override + public java.lang.String getProduct() { + java.lang.Object ref = product_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + product_ = s; + return s; + } + } + /** + * optional string product = 3; + * @return The bytes for product. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getProductBytes() { + java.lang.Object ref = product_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + product_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int TYPE_FIELD_NUMBER = 4; + @SuppressWarnings("serial") + private volatile java.lang.Object type_ = ""; + /** + * string type = 4; + * @return The type. + */ + @java.lang.Override + public java.lang.String getType() { + java.lang.Object ref = type_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + type_ = s; + return s; + } + } + /** + * string type = 4; + * @return The bytes for type. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTypeBytes() { + java.lang.Object ref = type_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + type_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int NAME_FIELD_NUMBER = 5; + @SuppressWarnings("serial") + private volatile java.lang.Object name_ = ""; + /** + * string name = 5; + * @return The name. + */ + @java.lang.Override + public java.lang.String getName() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } + } + /** + * string name = 5; + * @return The bytes for name. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int DISPLAY_NAME_FIELD_NUMBER = 6; + @SuppressWarnings("serial") + private volatile java.lang.Object displayName_ = ""; + /** + * string display_name = 6; + * @return The displayName. + */ + @java.lang.Override + public java.lang.String getDisplayName() { + java.lang.Object ref = displayName_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + displayName_ = s; + return s; + } + } + /** + * string display_name = 6; + * @return The bytes for displayName. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getDisplayNameBytes() { + java.lang.Object ref = displayName_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + displayName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, id_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(vendor_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, vendor_); + } + if (((bitField0_ & 0x00000001) != 0)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 3, product_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(type_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 4, type_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(name_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 5, name_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(displayName_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 6, displayName_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, id_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(vendor_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, vendor_); + } + if (((bitField0_ & 0x00000001) != 0)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(3, product_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(type_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(4, type_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(name_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(5, name_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(displayName_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(6, displayName_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.DataSource)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.DataSource other = (io.trino.spi.grpc.Endpoints.DataSource) obj; + + if (!getId() + .equals(other.getId())) return false; + if (!getVendor() + .equals(other.getVendor())) return false; + if (hasProduct() != other.hasProduct()) return false; + if (hasProduct()) { + if (!getProduct() + .equals(other.getProduct())) return false; + } + if (!getType() + .equals(other.getType())) return false; + if (!getName() + .equals(other.getName())) return false; + if (!getDisplayName() + .equals(other.getDisplayName())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + ID_FIELD_NUMBER; + hash = (53 * hash) + getId().hashCode(); + hash = (37 * hash) + VENDOR_FIELD_NUMBER; + hash = (53 * hash) + getVendor().hashCode(); + if (hasProduct()) { + hash = (37 * hash) + PRODUCT_FIELD_NUMBER; + hash = (53 * hash) + getProduct().hashCode(); + } + hash = (37 * hash) + TYPE_FIELD_NUMBER; + hash = (53 * hash) + getType().hashCode(); + hash = (37 * hash) + NAME_FIELD_NUMBER; + hash = (53 * hash) + getName().hashCode(); + hash = (37 * hash) + DISPLAY_NAME_FIELD_NUMBER; + hash = (53 * hash) + getDisplayName().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.DataSource parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.DataSource parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.DataSource parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.DataSource parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.DataSource parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.DataSource parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.DataSource parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.DataSource parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.DataSource parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.DataSource parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.DataSource parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.DataSource parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.DataSource prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.DataSource} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.DataSource) + io.trino.spi.grpc.Endpoints.DataSourceOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSource_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSource_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.DataSource.class, io.trino.spi.grpc.Endpoints.DataSource.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.DataSource.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + id_ = ""; + vendor_ = ""; + product_ = ""; + type_ = ""; + name_ = ""; + displayName_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSource_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSource getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.DataSource.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSource build() { + io.trino.spi.grpc.Endpoints.DataSource result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSource buildPartial() { + io.trino.spi.grpc.Endpoints.DataSource result = new io.trino.spi.grpc.Endpoints.DataSource(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.DataSource result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.id_ = id_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.vendor_ = vendor_; + } + int to_bitField0_ = 0; + if (((from_bitField0_ & 0x00000004) != 0)) { + result.product_ = product_; + to_bitField0_ |= 0x00000001; + } + if (((from_bitField0_ & 0x00000008) != 0)) { + result.type_ = type_; + } + if (((from_bitField0_ & 0x00000010) != 0)) { + result.name_ = name_; + } + if (((from_bitField0_ & 0x00000020) != 0)) { + result.displayName_ = displayName_; + } + result.bitField0_ |= to_bitField0_; + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.DataSource) { + return mergeFrom((io.trino.spi.grpc.Endpoints.DataSource)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.DataSource other) { + if (other == io.trino.spi.grpc.Endpoints.DataSource.getDefaultInstance()) return this; + if (!other.getId().isEmpty()) { + id_ = other.id_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getVendor().isEmpty()) { + vendor_ = other.vendor_; + bitField0_ |= 0x00000002; + onChanged(); + } + if (other.hasProduct()) { + product_ = other.product_; + bitField0_ |= 0x00000004; + onChanged(); + } + if (!other.getType().isEmpty()) { + type_ = other.type_; + bitField0_ |= 0x00000008; + onChanged(); + } + if (!other.getName().isEmpty()) { + name_ = other.name_; + bitField0_ |= 0x00000010; + onChanged(); + } + if (!other.getDisplayName().isEmpty()) { + displayName_ = other.displayName_; + bitField0_ |= 0x00000020; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + id_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + vendor_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + case 26: { + product_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000004; + break; + } // case 26 + case 34: { + type_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000008; + break; + } // case 34 + case 42: { + name_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000010; + break; + } // case 42 + case 50: { + displayName_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000020; + break; + } // case 50 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object id_ = ""; + /** + * string id = 1; + * @return The id. + */ + public java.lang.String getId() { + java.lang.Object ref = id_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string id = 1; + * @return The bytes for id. + */ + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string id = 1; + * @param value The id to set. + * @return This builder for chaining. + */ + public Builder setId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + id_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string id = 1; + * @return This builder for chaining. + */ + public Builder clearId() { + id_ = getDefaultInstance().getId(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string id = 1; + * @param value The bytes for id to set. + * @return This builder for chaining. + */ + public Builder setIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + id_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object vendor_ = ""; + /** + * string vendor = 2; + * @return The vendor. + */ + public java.lang.String getVendor() { + java.lang.Object ref = vendor_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + vendor_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string vendor = 2; + * @return The bytes for vendor. + */ + public com.google.protobuf.ByteString + getVendorBytes() { + java.lang.Object ref = vendor_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + vendor_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string vendor = 2; + * @param value The vendor to set. + * @return This builder for chaining. + */ + public Builder setVendor( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + vendor_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string vendor = 2; + * @return This builder for chaining. + */ + public Builder clearVendor() { + vendor_ = getDefaultInstance().getVendor(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string vendor = 2; + * @param value The bytes for vendor to set. + * @return This builder for chaining. + */ + public Builder setVendorBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + vendor_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + + private java.lang.Object product_ = ""; + /** + * optional string product = 3; + * @return Whether the product field is set. + */ + public boolean hasProduct() { + return ((bitField0_ & 0x00000004) != 0); + } + /** + * optional string product = 3; + * @return The product. + */ + public java.lang.String getProduct() { + java.lang.Object ref = product_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + product_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * optional string product = 3; + * @return The bytes for product. + */ + public com.google.protobuf.ByteString + getProductBytes() { + java.lang.Object ref = product_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + product_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * optional string product = 3; + * @param value The product to set. + * @return This builder for chaining. + */ + public Builder setProduct( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + product_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + /** + * optional string product = 3; + * @return This builder for chaining. + */ + public Builder clearProduct() { + product_ = getDefaultInstance().getProduct(); + bitField0_ = (bitField0_ & ~0x00000004); + onChanged(); + return this; + } + /** + * optional string product = 3; + * @param value The bytes for product to set. + * @return This builder for chaining. + */ + public Builder setProductBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + product_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + + private java.lang.Object type_ = ""; + /** + * string type = 4; + * @return The type. + */ + public java.lang.String getType() { + java.lang.Object ref = type_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + type_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string type = 4; + * @return The bytes for type. + */ + public com.google.protobuf.ByteString + getTypeBytes() { + java.lang.Object ref = type_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + type_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string type = 4; + * @param value The type to set. + * @return This builder for chaining. + */ + public Builder setType( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + type_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + /** + * string type = 4; + * @return This builder for chaining. + */ + public Builder clearType() { + type_ = getDefaultInstance().getType(); + bitField0_ = (bitField0_ & ~0x00000008); + onChanged(); + return this; + } + /** + * string type = 4; + * @param value The bytes for type to set. + * @return This builder for chaining. + */ + public Builder setTypeBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + type_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + + private java.lang.Object name_ = ""; + /** + * string name = 5; + * @return The name. + */ + public java.lang.String getName() { + java.lang.Object ref = name_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string name = 5; + * @return The bytes for name. + */ + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string name = 5; + * @param value The name to set. + * @return This builder for chaining. + */ + public Builder setName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + name_ = value; + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + /** + * string name = 5; + * @return This builder for chaining. + */ + public Builder clearName() { + name_ = getDefaultInstance().getName(); + bitField0_ = (bitField0_ & ~0x00000010); + onChanged(); + return this; + } + /** + * string name = 5; + * @param value The bytes for name to set. + * @return This builder for chaining. + */ + public Builder setNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + name_ = value; + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + + private java.lang.Object displayName_ = ""; + /** + * string display_name = 6; + * @return The displayName. + */ + public java.lang.String getDisplayName() { + java.lang.Object ref = displayName_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + displayName_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string display_name = 6; + * @return The bytes for displayName. + */ + public com.google.protobuf.ByteString + getDisplayNameBytes() { + java.lang.Object ref = displayName_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + displayName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string display_name = 6; + * @param value The displayName to set. + * @return This builder for chaining. + */ + public Builder setDisplayName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + displayName_ = value; + bitField0_ |= 0x00000020; + onChanged(); + return this; + } + /** + * string display_name = 6; + * @return This builder for chaining. + */ + public Builder clearDisplayName() { + displayName_ = getDefaultInstance().getDisplayName(); + bitField0_ = (bitField0_ & ~0x00000020); + onChanged(); + return this; + } + /** + * string display_name = 6; + * @param value The bytes for displayName to set. + * @return This builder for chaining. + */ + public Builder setDisplayNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + displayName_ = value; + bitField0_ |= 0x00000020; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.DataSource) + } + + // @@protoc_insertion_point(class_scope:grpc.DataSource) + private static final io.trino.spi.grpc.Endpoints.DataSource DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.DataSource(); + } + + public static io.trino.spi.grpc.Endpoints.DataSource getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public DataSource parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSource getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface DataSourceInstanceInputOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.DataSourceInstanceInput) + com.google.protobuf.MessageOrBuilder { + + /** + * string data_source_id = 1; + * @return The dataSourceId. + */ + java.lang.String getDataSourceId(); + /** + * string data_source_id = 1; + * @return The bytes for dataSourceId. + */ + com.google.protobuf.ByteString + getDataSourceIdBytes(); + + /** + * string scheme = 2; + * @return The scheme. + */ + java.lang.String getScheme(); + /** + * string scheme = 2; + * @return The bytes for scheme. + */ + com.google.protobuf.ByteString + getSchemeBytes(); + + /** + * string table = 3; + * @return The table. + */ + java.lang.String getTable(); + /** + * string table = 3; + * @return The bytes for table. + */ + com.google.protobuf.ByteString + getTableBytes(); + + /** + * optional string filter = 4; + * @return Whether the filter field is set. + */ + boolean hasFilter(); + /** + * optional string filter = 4; + * @return The filter. + */ + java.lang.String getFilter(); + /** + * optional string filter = 4; + * @return The bytes for filter. + */ + com.google.protobuf.ByteString + getFilterBytes(); + } + /** + * Protobuf type {@code grpc.DataSourceInstanceInput} + */ + public static final class DataSourceInstanceInput extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.DataSourceInstanceInput) + DataSourceInstanceInputOrBuilder { + private static final long serialVersionUID = 0L; + // Use DataSourceInstanceInput.newBuilder() to construct. + private DataSourceInstanceInput(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private DataSourceInstanceInput() { + dataSourceId_ = ""; + scheme_ = ""; + table_ = ""; + filter_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new DataSourceInstanceInput(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSourceInstanceInput_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSourceInstanceInput_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.DataSourceInstanceInput.class, io.trino.spi.grpc.Endpoints.DataSourceInstanceInput.Builder.class); + } + + private int bitField0_; + public static final int DATA_SOURCE_ID_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object dataSourceId_ = ""; + /** + * string data_source_id = 1; + * @return The dataSourceId. + */ + @java.lang.Override + public java.lang.String getDataSourceId() { + java.lang.Object ref = dataSourceId_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + dataSourceId_ = s; + return s; + } + } + /** + * string data_source_id = 1; + * @return The bytes for dataSourceId. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getDataSourceIdBytes() { + java.lang.Object ref = dataSourceId_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + dataSourceId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int SCHEME_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object scheme_ = ""; + /** + * string scheme = 2; + * @return The scheme. + */ + @java.lang.Override + public java.lang.String getScheme() { + java.lang.Object ref = scheme_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + scheme_ = s; + return s; + } + } + /** + * string scheme = 2; + * @return The bytes for scheme. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getSchemeBytes() { + java.lang.Object ref = scheme_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + scheme_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int TABLE_FIELD_NUMBER = 3; + @SuppressWarnings("serial") + private volatile java.lang.Object table_ = ""; + /** + * string table = 3; + * @return The table. + */ + @java.lang.Override + public java.lang.String getTable() { + java.lang.Object ref = table_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + table_ = s; + return s; + } + } + /** + * string table = 3; + * @return The bytes for table. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTableBytes() { + java.lang.Object ref = table_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + table_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int FILTER_FIELD_NUMBER = 4; + @SuppressWarnings("serial") + private volatile java.lang.Object filter_ = ""; + /** + * optional string filter = 4; + * @return Whether the filter field is set. + */ + @java.lang.Override + public boolean hasFilter() { + return ((bitField0_ & 0x00000001) != 0); + } + /** + * optional string filter = 4; + * @return The filter. + */ + @java.lang.Override + public java.lang.String getFilter() { + java.lang.Object ref = filter_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + filter_ = s; + return s; + } + } + /** + * optional string filter = 4; + * @return The bytes for filter. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getFilterBytes() { + java.lang.Object ref = filter_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + filter_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(dataSourceId_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, dataSourceId_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(scheme_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, scheme_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(table_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 3, table_); + } + if (((bitField0_ & 0x00000001) != 0)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 4, filter_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(dataSourceId_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, dataSourceId_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(scheme_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, scheme_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(table_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(3, table_); + } + if (((bitField0_ & 0x00000001) != 0)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(4, filter_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.DataSourceInstanceInput)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.DataSourceInstanceInput other = (io.trino.spi.grpc.Endpoints.DataSourceInstanceInput) obj; + + if (!getDataSourceId() + .equals(other.getDataSourceId())) return false; + if (!getScheme() + .equals(other.getScheme())) return false; + if (!getTable() + .equals(other.getTable())) return false; + if (hasFilter() != other.hasFilter()) return false; + if (hasFilter()) { + if (!getFilter() + .equals(other.getFilter())) return false; + } + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + DATA_SOURCE_ID_FIELD_NUMBER; + hash = (53 * hash) + getDataSourceId().hashCode(); + hash = (37 * hash) + SCHEME_FIELD_NUMBER; + hash = (53 * hash) + getScheme().hashCode(); + hash = (37 * hash) + TABLE_FIELD_NUMBER; + hash = (53 * hash) + getTable().hashCode(); + if (hasFilter()) { + hash = (37 * hash) + FILTER_FIELD_NUMBER; + hash = (53 * hash) + getFilter().hashCode(); + } + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.DataSourceInstanceInput parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.DataSourceInstanceInput parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.DataSourceInstanceInput parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.DataSourceInstanceInput parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.DataSourceInstanceInput parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.DataSourceInstanceInput parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.DataSourceInstanceInput parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.DataSourceInstanceInput parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.DataSourceInstanceInput parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.DataSourceInstanceInput parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.DataSourceInstanceInput parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.DataSourceInstanceInput parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.DataSourceInstanceInput prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.DataSourceInstanceInput} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.DataSourceInstanceInput) + io.trino.spi.grpc.Endpoints.DataSourceInstanceInputOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSourceInstanceInput_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSourceInstanceInput_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.DataSourceInstanceInput.class, io.trino.spi.grpc.Endpoints.DataSourceInstanceInput.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.DataSourceInstanceInput.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + dataSourceId_ = ""; + scheme_ = ""; + table_ = ""; + filter_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSourceInstanceInput_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceInstanceInput getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.DataSourceInstanceInput.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceInstanceInput build() { + io.trino.spi.grpc.Endpoints.DataSourceInstanceInput result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceInstanceInput buildPartial() { + io.trino.spi.grpc.Endpoints.DataSourceInstanceInput result = new io.trino.spi.grpc.Endpoints.DataSourceInstanceInput(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.DataSourceInstanceInput result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.dataSourceId_ = dataSourceId_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.scheme_ = scheme_; + } + if (((from_bitField0_ & 0x00000004) != 0)) { + result.table_ = table_; + } + int to_bitField0_ = 0; + if (((from_bitField0_ & 0x00000008) != 0)) { + result.filter_ = filter_; + to_bitField0_ |= 0x00000001; + } + result.bitField0_ |= to_bitField0_; + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.DataSourceInstanceInput) { + return mergeFrom((io.trino.spi.grpc.Endpoints.DataSourceInstanceInput)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.DataSourceInstanceInput other) { + if (other == io.trino.spi.grpc.Endpoints.DataSourceInstanceInput.getDefaultInstance()) return this; + if (!other.getDataSourceId().isEmpty()) { + dataSourceId_ = other.dataSourceId_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getScheme().isEmpty()) { + scheme_ = other.scheme_; + bitField0_ |= 0x00000002; + onChanged(); + } + if (!other.getTable().isEmpty()) { + table_ = other.table_; + bitField0_ |= 0x00000004; + onChanged(); + } + if (other.hasFilter()) { + filter_ = other.filter_; + bitField0_ |= 0x00000008; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + dataSourceId_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + scheme_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + case 26: { + table_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000004; + break; + } // case 26 + case 34: { + filter_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000008; + break; + } // case 34 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object dataSourceId_ = ""; + /** + * string data_source_id = 1; + * @return The dataSourceId. + */ + public java.lang.String getDataSourceId() { + java.lang.Object ref = dataSourceId_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + dataSourceId_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string data_source_id = 1; + * @return The bytes for dataSourceId. + */ + public com.google.protobuf.ByteString + getDataSourceIdBytes() { + java.lang.Object ref = dataSourceId_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + dataSourceId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string data_source_id = 1; + * @param value The dataSourceId to set. + * @return This builder for chaining. + */ + public Builder setDataSourceId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + dataSourceId_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string data_source_id = 1; + * @return This builder for chaining. + */ + public Builder clearDataSourceId() { + dataSourceId_ = getDefaultInstance().getDataSourceId(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string data_source_id = 1; + * @param value The bytes for dataSourceId to set. + * @return This builder for chaining. + */ + public Builder setDataSourceIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + dataSourceId_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object scheme_ = ""; + /** + * string scheme = 2; + * @return The scheme. + */ + public java.lang.String getScheme() { + java.lang.Object ref = scheme_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + scheme_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string scheme = 2; + * @return The bytes for scheme. + */ + public com.google.protobuf.ByteString + getSchemeBytes() { + java.lang.Object ref = scheme_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + scheme_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string scheme = 2; + * @param value The scheme to set. + * @return This builder for chaining. + */ + public Builder setScheme( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + scheme_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string scheme = 2; + * @return This builder for chaining. + */ + public Builder clearScheme() { + scheme_ = getDefaultInstance().getScheme(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string scheme = 2; + * @param value The bytes for scheme to set. + * @return This builder for chaining. + */ + public Builder setSchemeBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + scheme_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + + private java.lang.Object table_ = ""; + /** + * string table = 3; + * @return The table. + */ + public java.lang.String getTable() { + java.lang.Object ref = table_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + table_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string table = 3; + * @return The bytes for table. + */ + public com.google.protobuf.ByteString + getTableBytes() { + java.lang.Object ref = table_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + table_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string table = 3; + * @param value The table to set. + * @return This builder for chaining. + */ + public Builder setTable( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + table_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + /** + * string table = 3; + * @return This builder for chaining. + */ + public Builder clearTable() { + table_ = getDefaultInstance().getTable(); + bitField0_ = (bitField0_ & ~0x00000004); + onChanged(); + return this; + } + /** + * string table = 3; + * @param value The bytes for table to set. + * @return This builder for chaining. + */ + public Builder setTableBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + table_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + + private java.lang.Object filter_ = ""; + /** + * optional string filter = 4; + * @return Whether the filter field is set. + */ + public boolean hasFilter() { + return ((bitField0_ & 0x00000008) != 0); + } + /** + * optional string filter = 4; + * @return The filter. + */ + public java.lang.String getFilter() { + java.lang.Object ref = filter_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + filter_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * optional string filter = 4; + * @return The bytes for filter. + */ + public com.google.protobuf.ByteString + getFilterBytes() { + java.lang.Object ref = filter_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + filter_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * optional string filter = 4; + * @param value The filter to set. + * @return This builder for chaining. + */ + public Builder setFilter( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + filter_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + /** + * optional string filter = 4; + * @return This builder for chaining. + */ + public Builder clearFilter() { + filter_ = getDefaultInstance().getFilter(); + bitField0_ = (bitField0_ & ~0x00000008); + onChanged(); + return this; + } + /** + * optional string filter = 4; + * @param value The bytes for filter to set. + * @return This builder for chaining. + */ + public Builder setFilterBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + filter_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.DataSourceInstanceInput) + } + + // @@protoc_insertion_point(class_scope:grpc.DataSourceInstanceInput) + private static final io.trino.spi.grpc.Endpoints.DataSourceInstanceInput DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.DataSourceInstanceInput(); + } + + public static io.trino.spi.grpc.Endpoints.DataSourceInstanceInput getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public DataSourceInstanceInput parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceInstanceInput getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface DataSourceInstanceOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.DataSourceInstance) + com.google.protobuf.MessageOrBuilder { + + /** + * string id = 1; + * @return The id. + */ + java.lang.String getId(); + /** + * string id = 1; + * @return The bytes for id. + */ + com.google.protobuf.ByteString + getIdBytes(); + + /** + * string connector_instance_id = 2; + * @return The connectorInstanceId. + */ + java.lang.String getConnectorInstanceId(); + /** + * string connector_instance_id = 2; + * @return The bytes for connectorInstanceId. + */ + com.google.protobuf.ByteString + getConnectorInstanceIdBytes(); + + /** + * string data_source_id = 3; + * @return The dataSourceId. + */ + java.lang.String getDataSourceId(); + /** + * string data_source_id = 3; + * @return The bytes for dataSourceId. + */ + com.google.protobuf.ByteString + getDataSourceIdBytes(); + + /** + * .grpc.DataSource data_source = 4; + * @return Whether the dataSource field is set. + */ + boolean hasDataSource(); + /** + * .grpc.DataSource data_source = 4; + * @return The dataSource. + */ + io.trino.spi.grpc.Endpoints.DataSource getDataSource(); + /** + * .grpc.DataSource data_source = 4; + */ + io.trino.spi.grpc.Endpoints.DataSourceOrBuilder getDataSourceOrBuilder(); + + /** + * string scheme = 5; + * @return The scheme. + */ + java.lang.String getScheme(); + /** + * string scheme = 5; + * @return The bytes for scheme. + */ + com.google.protobuf.ByteString + getSchemeBytes(); + + /** + * string table = 6; + * @return The table. + */ + java.lang.String getTable(); + /** + * string table = 6; + * @return The bytes for table. + */ + com.google.protobuf.ByteString + getTableBytes(); + + /** + * optional string filter = 7; + * @return Whether the filter field is set. + */ + boolean hasFilter(); + /** + * optional string filter = 7; + * @return The filter. + */ + java.lang.String getFilter(); + /** + * optional string filter = 7; + * @return The bytes for filter. + */ + com.google.protobuf.ByteString + getFilterBytes(); + } + /** + * Protobuf type {@code grpc.DataSourceInstance} + */ + public static final class DataSourceInstance extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.DataSourceInstance) + DataSourceInstanceOrBuilder { + private static final long serialVersionUID = 0L; + // Use DataSourceInstance.newBuilder() to construct. + private DataSourceInstance(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private DataSourceInstance() { + id_ = ""; + connectorInstanceId_ = ""; + dataSourceId_ = ""; + scheme_ = ""; + table_ = ""; + filter_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new DataSourceInstance(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSourceInstance_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSourceInstance_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.DataSourceInstance.class, io.trino.spi.grpc.Endpoints.DataSourceInstance.Builder.class); + } + + private int bitField0_; + public static final int ID_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object id_ = ""; + /** + * string id = 1; + * @return The id. + */ + @java.lang.Override + public java.lang.String getId() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } + } + /** + * string id = 1; + * @return The bytes for id. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int CONNECTOR_INSTANCE_ID_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object connectorInstanceId_ = ""; + /** + * string connector_instance_id = 2; + * @return The connectorInstanceId. + */ + @java.lang.Override + public java.lang.String getConnectorInstanceId() { + java.lang.Object ref = connectorInstanceId_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + connectorInstanceId_ = s; + return s; + } + } + /** + * string connector_instance_id = 2; + * @return The bytes for connectorInstanceId. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getConnectorInstanceIdBytes() { + java.lang.Object ref = connectorInstanceId_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + connectorInstanceId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int DATA_SOURCE_ID_FIELD_NUMBER = 3; + @SuppressWarnings("serial") + private volatile java.lang.Object dataSourceId_ = ""; + /** + * string data_source_id = 3; + * @return The dataSourceId. + */ + @java.lang.Override + public java.lang.String getDataSourceId() { + java.lang.Object ref = dataSourceId_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + dataSourceId_ = s; + return s; + } + } + /** + * string data_source_id = 3; + * @return The bytes for dataSourceId. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getDataSourceIdBytes() { + java.lang.Object ref = dataSourceId_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + dataSourceId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int DATA_SOURCE_FIELD_NUMBER = 4; + private io.trino.spi.grpc.Endpoints.DataSource dataSource_; + /** + * .grpc.DataSource data_source = 4; + * @return Whether the dataSource field is set. + */ + @java.lang.Override + public boolean hasDataSource() { + return dataSource_ != null; + } + /** + * .grpc.DataSource data_source = 4; + * @return The dataSource. + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSource getDataSource() { + return dataSource_ == null ? io.trino.spi.grpc.Endpoints.DataSource.getDefaultInstance() : dataSource_; + } + /** + * .grpc.DataSource data_source = 4; + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceOrBuilder getDataSourceOrBuilder() { + return dataSource_ == null ? io.trino.spi.grpc.Endpoints.DataSource.getDefaultInstance() : dataSource_; + } + + public static final int SCHEME_FIELD_NUMBER = 5; + @SuppressWarnings("serial") + private volatile java.lang.Object scheme_ = ""; + /** + * string scheme = 5; + * @return The scheme. + */ + @java.lang.Override + public java.lang.String getScheme() { + java.lang.Object ref = scheme_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + scheme_ = s; + return s; + } + } + /** + * string scheme = 5; + * @return The bytes for scheme. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getSchemeBytes() { + java.lang.Object ref = scheme_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + scheme_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int TABLE_FIELD_NUMBER = 6; + @SuppressWarnings("serial") + private volatile java.lang.Object table_ = ""; + /** + * string table = 6; + * @return The table. + */ + @java.lang.Override + public java.lang.String getTable() { + java.lang.Object ref = table_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + table_ = s; + return s; + } + } + /** + * string table = 6; + * @return The bytes for table. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTableBytes() { + java.lang.Object ref = table_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + table_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int FILTER_FIELD_NUMBER = 7; + @SuppressWarnings("serial") + private volatile java.lang.Object filter_ = ""; + /** + * optional string filter = 7; + * @return Whether the filter field is set. + */ + @java.lang.Override + public boolean hasFilter() { + return ((bitField0_ & 0x00000001) != 0); + } + /** + * optional string filter = 7; + * @return The filter. + */ + @java.lang.Override + public java.lang.String getFilter() { + java.lang.Object ref = filter_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + filter_ = s; + return s; + } + } + /** + * optional string filter = 7; + * @return The bytes for filter. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getFilterBytes() { + java.lang.Object ref = filter_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + filter_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, id_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(connectorInstanceId_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, connectorInstanceId_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(dataSourceId_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 3, dataSourceId_); + } + if (dataSource_ != null) { + output.writeMessage(4, getDataSource()); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(scheme_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 5, scheme_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(table_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 6, table_); + } + if (((bitField0_ & 0x00000001) != 0)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 7, filter_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, id_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(connectorInstanceId_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, connectorInstanceId_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(dataSourceId_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(3, dataSourceId_); + } + if (dataSource_ != null) { + size += com.google.protobuf.CodedOutputStream + .computeMessageSize(4, getDataSource()); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(scheme_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(5, scheme_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(table_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(6, table_); + } + if (((bitField0_ & 0x00000001) != 0)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(7, filter_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.DataSourceInstance)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.DataSourceInstance other = (io.trino.spi.grpc.Endpoints.DataSourceInstance) obj; + + if (!getId() + .equals(other.getId())) return false; + if (!getConnectorInstanceId() + .equals(other.getConnectorInstanceId())) return false; + if (!getDataSourceId() + .equals(other.getDataSourceId())) return false; + if (hasDataSource() != other.hasDataSource()) return false; + if (hasDataSource()) { + if (!getDataSource() + .equals(other.getDataSource())) return false; + } + if (!getScheme() + .equals(other.getScheme())) return false; + if (!getTable() + .equals(other.getTable())) return false; + if (hasFilter() != other.hasFilter()) return false; + if (hasFilter()) { + if (!getFilter() + .equals(other.getFilter())) return false; + } + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + ID_FIELD_NUMBER; + hash = (53 * hash) + getId().hashCode(); + hash = (37 * hash) + CONNECTOR_INSTANCE_ID_FIELD_NUMBER; + hash = (53 * hash) + getConnectorInstanceId().hashCode(); + hash = (37 * hash) + DATA_SOURCE_ID_FIELD_NUMBER; + hash = (53 * hash) + getDataSourceId().hashCode(); + if (hasDataSource()) { + hash = (37 * hash) + DATA_SOURCE_FIELD_NUMBER; + hash = (53 * hash) + getDataSource().hashCode(); + } + hash = (37 * hash) + SCHEME_FIELD_NUMBER; + hash = (53 * hash) + getScheme().hashCode(); + hash = (37 * hash) + TABLE_FIELD_NUMBER; + hash = (53 * hash) + getTable().hashCode(); + if (hasFilter()) { + hash = (37 * hash) + FILTER_FIELD_NUMBER; + hash = (53 * hash) + getFilter().hashCode(); + } + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.DataSourceInstance parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.DataSourceInstance parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.DataSourceInstance parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.DataSourceInstance parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.DataSourceInstance parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.DataSourceInstance parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.DataSourceInstance parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.DataSourceInstance parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.DataSourceInstance parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.DataSourceInstance parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.DataSourceInstance parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.DataSourceInstance parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.DataSourceInstance prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.DataSourceInstance} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.DataSourceInstance) + io.trino.spi.grpc.Endpoints.DataSourceInstanceOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSourceInstance_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSourceInstance_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.DataSourceInstance.class, io.trino.spi.grpc.Endpoints.DataSourceInstance.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.DataSourceInstance.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + id_ = ""; + connectorInstanceId_ = ""; + dataSourceId_ = ""; + dataSource_ = null; + if (dataSourceBuilder_ != null) { + dataSourceBuilder_.dispose(); + dataSourceBuilder_ = null; + } + scheme_ = ""; + table_ = ""; + filter_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSourceInstance_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceInstance getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.DataSourceInstance.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceInstance build() { + io.trino.spi.grpc.Endpoints.DataSourceInstance result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceInstance buildPartial() { + io.trino.spi.grpc.Endpoints.DataSourceInstance result = new io.trino.spi.grpc.Endpoints.DataSourceInstance(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.DataSourceInstance result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.id_ = id_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.connectorInstanceId_ = connectorInstanceId_; + } + if (((from_bitField0_ & 0x00000004) != 0)) { + result.dataSourceId_ = dataSourceId_; + } + if (((from_bitField0_ & 0x00000008) != 0)) { + result.dataSource_ = dataSourceBuilder_ == null + ? dataSource_ + : dataSourceBuilder_.build(); + } + if (((from_bitField0_ & 0x00000010) != 0)) { + result.scheme_ = scheme_; + } + if (((from_bitField0_ & 0x00000020) != 0)) { + result.table_ = table_; + } + int to_bitField0_ = 0; + if (((from_bitField0_ & 0x00000040) != 0)) { + result.filter_ = filter_; + to_bitField0_ |= 0x00000001; + } + result.bitField0_ |= to_bitField0_; + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.DataSourceInstance) { + return mergeFrom((io.trino.spi.grpc.Endpoints.DataSourceInstance)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.DataSourceInstance other) { + if (other == io.trino.spi.grpc.Endpoints.DataSourceInstance.getDefaultInstance()) return this; + if (!other.getId().isEmpty()) { + id_ = other.id_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getConnectorInstanceId().isEmpty()) { + connectorInstanceId_ = other.connectorInstanceId_; + bitField0_ |= 0x00000002; + onChanged(); + } + if (!other.getDataSourceId().isEmpty()) { + dataSourceId_ = other.dataSourceId_; + bitField0_ |= 0x00000004; + onChanged(); + } + if (other.hasDataSource()) { + mergeDataSource(other.getDataSource()); + } + if (!other.getScheme().isEmpty()) { + scheme_ = other.scheme_; + bitField0_ |= 0x00000010; + onChanged(); + } + if (!other.getTable().isEmpty()) { + table_ = other.table_; + bitField0_ |= 0x00000020; + onChanged(); + } + if (other.hasFilter()) { + filter_ = other.filter_; + bitField0_ |= 0x00000040; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + id_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + connectorInstanceId_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + case 26: { + dataSourceId_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000004; + break; + } // case 26 + case 34: { + input.readMessage( + getDataSourceFieldBuilder().getBuilder(), + extensionRegistry); + bitField0_ |= 0x00000008; + break; + } // case 34 + case 42: { + scheme_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000010; + break; + } // case 42 + case 50: { + table_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000020; + break; + } // case 50 + case 58: { + filter_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000040; + break; + } // case 58 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object id_ = ""; + /** + * string id = 1; + * @return The id. + */ + public java.lang.String getId() { + java.lang.Object ref = id_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string id = 1; + * @return The bytes for id. + */ + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string id = 1; + * @param value The id to set. + * @return This builder for chaining. + */ + public Builder setId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + id_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string id = 1; + * @return This builder for chaining. + */ + public Builder clearId() { + id_ = getDefaultInstance().getId(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string id = 1; + * @param value The bytes for id to set. + * @return This builder for chaining. + */ + public Builder setIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + id_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object connectorInstanceId_ = ""; + /** + * string connector_instance_id = 2; + * @return The connectorInstanceId. + */ + public java.lang.String getConnectorInstanceId() { + java.lang.Object ref = connectorInstanceId_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + connectorInstanceId_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string connector_instance_id = 2; + * @return The bytes for connectorInstanceId. + */ + public com.google.protobuf.ByteString + getConnectorInstanceIdBytes() { + java.lang.Object ref = connectorInstanceId_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + connectorInstanceId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string connector_instance_id = 2; + * @param value The connectorInstanceId to set. + * @return This builder for chaining. + */ + public Builder setConnectorInstanceId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + connectorInstanceId_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string connector_instance_id = 2; + * @return This builder for chaining. + */ + public Builder clearConnectorInstanceId() { + connectorInstanceId_ = getDefaultInstance().getConnectorInstanceId(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string connector_instance_id = 2; + * @param value The bytes for connectorInstanceId to set. + * @return This builder for chaining. + */ + public Builder setConnectorInstanceIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + connectorInstanceId_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + + private java.lang.Object dataSourceId_ = ""; + /** + * string data_source_id = 3; + * @return The dataSourceId. + */ + public java.lang.String getDataSourceId() { + java.lang.Object ref = dataSourceId_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + dataSourceId_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string data_source_id = 3; + * @return The bytes for dataSourceId. + */ + public com.google.protobuf.ByteString + getDataSourceIdBytes() { + java.lang.Object ref = dataSourceId_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + dataSourceId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string data_source_id = 3; + * @param value The dataSourceId to set. + * @return This builder for chaining. + */ + public Builder setDataSourceId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + dataSourceId_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + /** + * string data_source_id = 3; + * @return This builder for chaining. + */ + public Builder clearDataSourceId() { + dataSourceId_ = getDefaultInstance().getDataSourceId(); + bitField0_ = (bitField0_ & ~0x00000004); + onChanged(); + return this; + } + /** + * string data_source_id = 3; + * @param value The bytes for dataSourceId to set. + * @return This builder for chaining. + */ + public Builder setDataSourceIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + dataSourceId_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + + private io.trino.spi.grpc.Endpoints.DataSource dataSource_; + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.DataSource, io.trino.spi.grpc.Endpoints.DataSource.Builder, io.trino.spi.grpc.Endpoints.DataSourceOrBuilder> dataSourceBuilder_; + /** + * .grpc.DataSource data_source = 4; + * @return Whether the dataSource field is set. + */ + public boolean hasDataSource() { + return ((bitField0_ & 0x00000008) != 0); + } + /** + * .grpc.DataSource data_source = 4; + * @return The dataSource. + */ + public io.trino.spi.grpc.Endpoints.DataSource getDataSource() { + if (dataSourceBuilder_ == null) { + return dataSource_ == null ? io.trino.spi.grpc.Endpoints.DataSource.getDefaultInstance() : dataSource_; + } else { + return dataSourceBuilder_.getMessage(); + } + } + /** + * .grpc.DataSource data_source = 4; + */ + public Builder setDataSource(io.trino.spi.grpc.Endpoints.DataSource value) { + if (dataSourceBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + dataSource_ = value; + } else { + dataSourceBuilder_.setMessage(value); + } + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + /** + * .grpc.DataSource data_source = 4; + */ + public Builder setDataSource( + io.trino.spi.grpc.Endpoints.DataSource.Builder builderForValue) { + if (dataSourceBuilder_ == null) { + dataSource_ = builderForValue.build(); + } else { + dataSourceBuilder_.setMessage(builderForValue.build()); + } + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + /** + * .grpc.DataSource data_source = 4; + */ + public Builder mergeDataSource(io.trino.spi.grpc.Endpoints.DataSource value) { + if (dataSourceBuilder_ == null) { + if (((bitField0_ & 0x00000008) != 0) && + dataSource_ != null && + dataSource_ != io.trino.spi.grpc.Endpoints.DataSource.getDefaultInstance()) { + getDataSourceBuilder().mergeFrom(value); + } else { + dataSource_ = value; + } + } else { + dataSourceBuilder_.mergeFrom(value); + } + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + /** + * .grpc.DataSource data_source = 4; + */ + public Builder clearDataSource() { + bitField0_ = (bitField0_ & ~0x00000008); + dataSource_ = null; + if (dataSourceBuilder_ != null) { + dataSourceBuilder_.dispose(); + dataSourceBuilder_ = null; + } + onChanged(); + return this; + } + /** + * .grpc.DataSource data_source = 4; + */ + public io.trino.spi.grpc.Endpoints.DataSource.Builder getDataSourceBuilder() { + bitField0_ |= 0x00000008; + onChanged(); + return getDataSourceFieldBuilder().getBuilder(); + } + /** + * .grpc.DataSource data_source = 4; + */ + public io.trino.spi.grpc.Endpoints.DataSourceOrBuilder getDataSourceOrBuilder() { + if (dataSourceBuilder_ != null) { + return dataSourceBuilder_.getMessageOrBuilder(); + } else { + return dataSource_ == null ? + io.trino.spi.grpc.Endpoints.DataSource.getDefaultInstance() : dataSource_; + } + } + /** + * .grpc.DataSource data_source = 4; + */ + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.DataSource, io.trino.spi.grpc.Endpoints.DataSource.Builder, io.trino.spi.grpc.Endpoints.DataSourceOrBuilder> + getDataSourceFieldBuilder() { + if (dataSourceBuilder_ == null) { + dataSourceBuilder_ = new com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.DataSource, io.trino.spi.grpc.Endpoints.DataSource.Builder, io.trino.spi.grpc.Endpoints.DataSourceOrBuilder>( + getDataSource(), + getParentForChildren(), + isClean()); + dataSource_ = null; + } + return dataSourceBuilder_; + } + + private java.lang.Object scheme_ = ""; + /** + * string scheme = 5; + * @return The scheme. + */ + public java.lang.String getScheme() { + java.lang.Object ref = scheme_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + scheme_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string scheme = 5; + * @return The bytes for scheme. + */ + public com.google.protobuf.ByteString + getSchemeBytes() { + java.lang.Object ref = scheme_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + scheme_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string scheme = 5; + * @param value The scheme to set. + * @return This builder for chaining. + */ + public Builder setScheme( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + scheme_ = value; + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + /** + * string scheme = 5; + * @return This builder for chaining. + */ + public Builder clearScheme() { + scheme_ = getDefaultInstance().getScheme(); + bitField0_ = (bitField0_ & ~0x00000010); + onChanged(); + return this; + } + /** + * string scheme = 5; + * @param value The bytes for scheme to set. + * @return This builder for chaining. + */ + public Builder setSchemeBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + scheme_ = value; + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + + private java.lang.Object table_ = ""; + /** + * string table = 6; + * @return The table. + */ + public java.lang.String getTable() { + java.lang.Object ref = table_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + table_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string table = 6; + * @return The bytes for table. + */ + public com.google.protobuf.ByteString + getTableBytes() { + java.lang.Object ref = table_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + table_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string table = 6; + * @param value The table to set. + * @return This builder for chaining. + */ + public Builder setTable( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + table_ = value; + bitField0_ |= 0x00000020; + onChanged(); + return this; + } + /** + * string table = 6; + * @return This builder for chaining. + */ + public Builder clearTable() { + table_ = getDefaultInstance().getTable(); + bitField0_ = (bitField0_ & ~0x00000020); + onChanged(); + return this; + } + /** + * string table = 6; + * @param value The bytes for table to set. + * @return This builder for chaining. + */ + public Builder setTableBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + table_ = value; + bitField0_ |= 0x00000020; + onChanged(); + return this; + } + + private java.lang.Object filter_ = ""; + /** + * optional string filter = 7; + * @return Whether the filter field is set. + */ + public boolean hasFilter() { + return ((bitField0_ & 0x00000040) != 0); + } + /** + * optional string filter = 7; + * @return The filter. + */ + public java.lang.String getFilter() { + java.lang.Object ref = filter_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + filter_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * optional string filter = 7; + * @return The bytes for filter. + */ + public com.google.protobuf.ByteString + getFilterBytes() { + java.lang.Object ref = filter_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + filter_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * optional string filter = 7; + * @param value The filter to set. + * @return This builder for chaining. + */ + public Builder setFilter( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + filter_ = value; + bitField0_ |= 0x00000040; + onChanged(); + return this; + } + /** + * optional string filter = 7; + * @return This builder for chaining. + */ + public Builder clearFilter() { + filter_ = getDefaultInstance().getFilter(); + bitField0_ = (bitField0_ & ~0x00000040); + onChanged(); + return this; + } + /** + * optional string filter = 7; + * @param value The bytes for filter to set. + * @return This builder for chaining. + */ + public Builder setFilterBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + filter_ = value; + bitField0_ |= 0x00000040; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.DataSourceInstance) + } + + // @@protoc_insertion_point(class_scope:grpc.DataSourceInstance) + private static final io.trino.spi.grpc.Endpoints.DataSourceInstance DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.DataSourceInstance(); + } + + public static io.trino.spi.grpc.Endpoints.DataSourceInstance getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public DataSourceInstance parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceInstance getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface DataSourceInstanceConnectorDetailsOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.DataSourceInstanceConnectorDetails) + com.google.protobuf.MessageOrBuilder { + + /** + * .grpc.DataSourceInstance dataSourceInstance = 1; + * @return Whether the dataSourceInstance field is set. + */ + boolean hasDataSourceInstance(); + /** + * .grpc.DataSourceInstance dataSourceInstance = 1; + * @return The dataSourceInstance. + */ + io.trino.spi.grpc.Endpoints.DataSourceInstance getDataSourceInstance(); + /** + * .grpc.DataSourceInstance dataSourceInstance = 1; + */ + io.trino.spi.grpc.Endpoints.DataSourceInstanceOrBuilder getDataSourceInstanceOrBuilder(); + + /** + * string connector_name = 2; + * @return The connectorName. + */ + java.lang.String getConnectorName(); + /** + * string connector_name = 2; + * @return The bytes for connectorName. + */ + com.google.protobuf.ByteString + getConnectorNameBytes(); + + /** + * string catalog_name = 3; + * @return The catalogName. + */ + java.lang.String getCatalogName(); + /** + * string catalog_name = 3; + * @return The bytes for catalogName. + */ + com.google.protobuf.ByteString + getCatalogNameBytes(); + } + /** + * Protobuf type {@code grpc.DataSourceInstanceConnectorDetails} + */ + public static final class DataSourceInstanceConnectorDetails extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.DataSourceInstanceConnectorDetails) + DataSourceInstanceConnectorDetailsOrBuilder { + private static final long serialVersionUID = 0L; + // Use DataSourceInstanceConnectorDetails.newBuilder() to construct. + private DataSourceInstanceConnectorDetails(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private DataSourceInstanceConnectorDetails() { + connectorName_ = ""; + catalogName_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new DataSourceInstanceConnectorDetails(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSourceInstanceConnectorDetails_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSourceInstanceConnectorDetails_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails.class, io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails.Builder.class); + } + + public static final int DATASOURCEINSTANCE_FIELD_NUMBER = 1; + private io.trino.spi.grpc.Endpoints.DataSourceInstance dataSourceInstance_; + /** + * .grpc.DataSourceInstance dataSourceInstance = 1; + * @return Whether the dataSourceInstance field is set. + */ + @java.lang.Override + public boolean hasDataSourceInstance() { + return dataSourceInstance_ != null; + } + /** + * .grpc.DataSourceInstance dataSourceInstance = 1; + * @return The dataSourceInstance. + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceInstance getDataSourceInstance() { + return dataSourceInstance_ == null ? io.trino.spi.grpc.Endpoints.DataSourceInstance.getDefaultInstance() : dataSourceInstance_; + } + /** + * .grpc.DataSourceInstance dataSourceInstance = 1; + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceInstanceOrBuilder getDataSourceInstanceOrBuilder() { + return dataSourceInstance_ == null ? io.trino.spi.grpc.Endpoints.DataSourceInstance.getDefaultInstance() : dataSourceInstance_; + } + + public static final int CONNECTOR_NAME_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object connectorName_ = ""; + /** + * string connector_name = 2; + * @return The connectorName. + */ + @java.lang.Override + public java.lang.String getConnectorName() { + java.lang.Object ref = connectorName_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + connectorName_ = s; + return s; + } + } + /** + * string connector_name = 2; + * @return The bytes for connectorName. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getConnectorNameBytes() { + java.lang.Object ref = connectorName_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + connectorName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int CATALOG_NAME_FIELD_NUMBER = 3; + @SuppressWarnings("serial") + private volatile java.lang.Object catalogName_ = ""; + /** + * string catalog_name = 3; + * @return The catalogName. + */ + @java.lang.Override + public java.lang.String getCatalogName() { + java.lang.Object ref = catalogName_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + catalogName_ = s; + return s; + } + } + /** + * string catalog_name = 3; + * @return The bytes for catalogName. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getCatalogNameBytes() { + java.lang.Object ref = catalogName_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + catalogName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (dataSourceInstance_ != null) { + output.writeMessage(1, getDataSourceInstance()); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(connectorName_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, connectorName_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(catalogName_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 3, catalogName_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (dataSourceInstance_ != null) { + size += com.google.protobuf.CodedOutputStream + .computeMessageSize(1, getDataSourceInstance()); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(connectorName_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, connectorName_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(catalogName_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(3, catalogName_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails other = (io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails) obj; + + if (hasDataSourceInstance() != other.hasDataSourceInstance()) return false; + if (hasDataSourceInstance()) { + if (!getDataSourceInstance() + .equals(other.getDataSourceInstance())) return false; + } + if (!getConnectorName() + .equals(other.getConnectorName())) return false; + if (!getCatalogName() + .equals(other.getCatalogName())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + if (hasDataSourceInstance()) { + hash = (37 * hash) + DATASOURCEINSTANCE_FIELD_NUMBER; + hash = (53 * hash) + getDataSourceInstance().hashCode(); + } + hash = (37 * hash) + CONNECTOR_NAME_FIELD_NUMBER; + hash = (53 * hash) + getConnectorName().hashCode(); + hash = (37 * hash) + CATALOG_NAME_FIELD_NUMBER; + hash = (53 * hash) + getCatalogName().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.DataSourceInstanceConnectorDetails} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.DataSourceInstanceConnectorDetails) + io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetailsOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSourceInstanceConnectorDetails_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSourceInstanceConnectorDetails_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails.class, io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + dataSourceInstance_ = null; + if (dataSourceInstanceBuilder_ != null) { + dataSourceInstanceBuilder_.dispose(); + dataSourceInstanceBuilder_ = null; + } + connectorName_ = ""; + catalogName_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSourceInstanceConnectorDetails_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails build() { + io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails buildPartial() { + io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails result = new io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.dataSourceInstance_ = dataSourceInstanceBuilder_ == null + ? dataSourceInstance_ + : dataSourceInstanceBuilder_.build(); + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.connectorName_ = connectorName_; + } + if (((from_bitField0_ & 0x00000004) != 0)) { + result.catalogName_ = catalogName_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails) { + return mergeFrom((io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails other) { + if (other == io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails.getDefaultInstance()) return this; + if (other.hasDataSourceInstance()) { + mergeDataSourceInstance(other.getDataSourceInstance()); + } + if (!other.getConnectorName().isEmpty()) { + connectorName_ = other.connectorName_; + bitField0_ |= 0x00000002; + onChanged(); + } + if (!other.getCatalogName().isEmpty()) { + catalogName_ = other.catalogName_; + bitField0_ |= 0x00000004; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + input.readMessage( + getDataSourceInstanceFieldBuilder().getBuilder(), + extensionRegistry); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + connectorName_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + case 26: { + catalogName_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000004; + break; + } // case 26 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private io.trino.spi.grpc.Endpoints.DataSourceInstance dataSourceInstance_; + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.DataSourceInstance, io.trino.spi.grpc.Endpoints.DataSourceInstance.Builder, io.trino.spi.grpc.Endpoints.DataSourceInstanceOrBuilder> dataSourceInstanceBuilder_; + /** + * .grpc.DataSourceInstance dataSourceInstance = 1; + * @return Whether the dataSourceInstance field is set. + */ + public boolean hasDataSourceInstance() { + return ((bitField0_ & 0x00000001) != 0); + } + /** + * .grpc.DataSourceInstance dataSourceInstance = 1; + * @return The dataSourceInstance. + */ + public io.trino.spi.grpc.Endpoints.DataSourceInstance getDataSourceInstance() { + if (dataSourceInstanceBuilder_ == null) { + return dataSourceInstance_ == null ? io.trino.spi.grpc.Endpoints.DataSourceInstance.getDefaultInstance() : dataSourceInstance_; + } else { + return dataSourceInstanceBuilder_.getMessage(); + } + } + /** + * .grpc.DataSourceInstance dataSourceInstance = 1; + */ + public Builder setDataSourceInstance(io.trino.spi.grpc.Endpoints.DataSourceInstance value) { + if (dataSourceInstanceBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + dataSourceInstance_ = value; + } else { + dataSourceInstanceBuilder_.setMessage(value); + } + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * .grpc.DataSourceInstance dataSourceInstance = 1; + */ + public Builder setDataSourceInstance( + io.trino.spi.grpc.Endpoints.DataSourceInstance.Builder builderForValue) { + if (dataSourceInstanceBuilder_ == null) { + dataSourceInstance_ = builderForValue.build(); + } else { + dataSourceInstanceBuilder_.setMessage(builderForValue.build()); + } + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * .grpc.DataSourceInstance dataSourceInstance = 1; + */ + public Builder mergeDataSourceInstance(io.trino.spi.grpc.Endpoints.DataSourceInstance value) { + if (dataSourceInstanceBuilder_ == null) { + if (((bitField0_ & 0x00000001) != 0) && + dataSourceInstance_ != null && + dataSourceInstance_ != io.trino.spi.grpc.Endpoints.DataSourceInstance.getDefaultInstance()) { + getDataSourceInstanceBuilder().mergeFrom(value); + } else { + dataSourceInstance_ = value; + } + } else { + dataSourceInstanceBuilder_.mergeFrom(value); + } + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * .grpc.DataSourceInstance dataSourceInstance = 1; + */ + public Builder clearDataSourceInstance() { + bitField0_ = (bitField0_ & ~0x00000001); + dataSourceInstance_ = null; + if (dataSourceInstanceBuilder_ != null) { + dataSourceInstanceBuilder_.dispose(); + dataSourceInstanceBuilder_ = null; + } + onChanged(); + return this; + } + /** + * .grpc.DataSourceInstance dataSourceInstance = 1; + */ + public io.trino.spi.grpc.Endpoints.DataSourceInstance.Builder getDataSourceInstanceBuilder() { + bitField0_ |= 0x00000001; + onChanged(); + return getDataSourceInstanceFieldBuilder().getBuilder(); + } + /** + * .grpc.DataSourceInstance dataSourceInstance = 1; + */ + public io.trino.spi.grpc.Endpoints.DataSourceInstanceOrBuilder getDataSourceInstanceOrBuilder() { + if (dataSourceInstanceBuilder_ != null) { + return dataSourceInstanceBuilder_.getMessageOrBuilder(); + } else { + return dataSourceInstance_ == null ? + io.trino.spi.grpc.Endpoints.DataSourceInstance.getDefaultInstance() : dataSourceInstance_; + } + } + /** + * .grpc.DataSourceInstance dataSourceInstance = 1; + */ + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.DataSourceInstance, io.trino.spi.grpc.Endpoints.DataSourceInstance.Builder, io.trino.spi.grpc.Endpoints.DataSourceInstanceOrBuilder> + getDataSourceInstanceFieldBuilder() { + if (dataSourceInstanceBuilder_ == null) { + dataSourceInstanceBuilder_ = new com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.DataSourceInstance, io.trino.spi.grpc.Endpoints.DataSourceInstance.Builder, io.trino.spi.grpc.Endpoints.DataSourceInstanceOrBuilder>( + getDataSourceInstance(), + getParentForChildren(), + isClean()); + dataSourceInstance_ = null; + } + return dataSourceInstanceBuilder_; + } + + private java.lang.Object connectorName_ = ""; + /** + * string connector_name = 2; + * @return The connectorName. + */ + public java.lang.String getConnectorName() { + java.lang.Object ref = connectorName_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + connectorName_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string connector_name = 2; + * @return The bytes for connectorName. + */ + public com.google.protobuf.ByteString + getConnectorNameBytes() { + java.lang.Object ref = connectorName_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + connectorName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string connector_name = 2; + * @param value The connectorName to set. + * @return This builder for chaining. + */ + public Builder setConnectorName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + connectorName_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string connector_name = 2; + * @return This builder for chaining. + */ + public Builder clearConnectorName() { + connectorName_ = getDefaultInstance().getConnectorName(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string connector_name = 2; + * @param value The bytes for connectorName to set. + * @return This builder for chaining. + */ + public Builder setConnectorNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + connectorName_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + + private java.lang.Object catalogName_ = ""; + /** + * string catalog_name = 3; + * @return The catalogName. + */ + public java.lang.String getCatalogName() { + java.lang.Object ref = catalogName_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + catalogName_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string catalog_name = 3; + * @return The bytes for catalogName. + */ + public com.google.protobuf.ByteString + getCatalogNameBytes() { + java.lang.Object ref = catalogName_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + catalogName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string catalog_name = 3; + * @param value The catalogName to set. + * @return This builder for chaining. + */ + public Builder setCatalogName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + catalogName_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + /** + * string catalog_name = 3; + * @return This builder for chaining. + */ + public Builder clearCatalogName() { + catalogName_ = getDefaultInstance().getCatalogName(); + bitField0_ = (bitField0_ & ~0x00000004); + onChanged(); + return this; + } + /** + * string catalog_name = 3; + * @param value The bytes for catalogName to set. + * @return This builder for chaining. + */ + public Builder setCatalogNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + catalogName_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.DataSourceInstanceConnectorDetails) + } + + // @@protoc_insertion_point(class_scope:grpc.DataSourceInstanceConnectorDetails) + private static final io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails(); + } + + public static io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public DataSourceInstanceConnectorDetails parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface ConnectorInstanceOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.ConnectorInstance) + com.google.protobuf.MessageOrBuilder { + + /** + * string id = 1; + * @return The id. + */ + java.lang.String getId(); + /** + * string id = 1; + * @return The bytes for id. + */ + com.google.protobuf.ByteString + getIdBytes(); + + /** + * string name = 2; + * @return The name. + */ + java.lang.String getName(); + /** + * string name = 2; + * @return The bytes for name. + */ + com.google.protobuf.ByteString + getNameBytes(); + + /** + * bool is_custom = 3; + * @return The isCustom. + */ + boolean getIsCustom(); + + /** + * string connector_id = 4; + * @return The connectorId. + */ + java.lang.String getConnectorId(); + /** + * string connector_id = 4; + * @return The bytes for connectorId. + */ + com.google.protobuf.ByteString + getConnectorIdBytes(); + + /** + * optional int64 last_activity_time = 5; + * @return Whether the lastActivityTime field is set. + */ + boolean hasLastActivityTime(); + /** + * optional int64 last_activity_time = 5; + * @return The lastActivityTime. + */ + long getLastActivityTime(); + + /** + * .grpc.Connector connector = 6; + * @return Whether the connector field is set. + */ + boolean hasConnector(); + /** + * .grpc.Connector connector = 6; + * @return The connector. + */ + io.trino.spi.grpc.Endpoints.Connector getConnector(); + /** + * .grpc.Connector connector = 6; + */ + io.trino.spi.grpc.Endpoints.ConnectorOrBuilder getConnectorOrBuilder(); + + /** + * repeated .grpc.DataSourceInstance data_sources = 7; + */ + java.util.List + getDataSourcesList(); + /** + * repeated .grpc.DataSourceInstance data_sources = 7; + */ + io.trino.spi.grpc.Endpoints.DataSourceInstance getDataSources(int index); + /** + * repeated .grpc.DataSourceInstance data_sources = 7; + */ + int getDataSourcesCount(); + /** + * repeated .grpc.DataSourceInstance data_sources = 7; + */ + java.util.List + getDataSourcesOrBuilderList(); + /** + * repeated .grpc.DataSourceInstance data_sources = 7; + */ + io.trino.spi.grpc.Endpoints.DataSourceInstanceOrBuilder getDataSourcesOrBuilder( + int index); + + /** + * .grpc.Broker broker = 8; + * @return Whether the broker field is set. + */ + boolean hasBroker(); + /** + * .grpc.Broker broker = 8; + * @return The broker. + */ + io.trino.spi.grpc.Endpoints.Broker getBroker(); + /** + * .grpc.Broker broker = 8; + */ + io.trino.spi.grpc.Endpoints.BrokerOrBuilder getBrokerOrBuilder(); + + /** + * string tenant_name = 9; + * @return The tenantName. + */ + java.lang.String getTenantName(); + /** + * string tenant_name = 9; + * @return The bytes for tenantName. + */ + com.google.protobuf.ByteString + getTenantNameBytes(); + + /** + * int64 created_at = 10; + * @return The createdAt. + */ + long getCreatedAt(); + } + /** + * Protobuf type {@code grpc.ConnectorInstance} + */ + public static final class ConnectorInstance extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.ConnectorInstance) + ConnectorInstanceOrBuilder { + private static final long serialVersionUID = 0L; + // Use ConnectorInstance.newBuilder() to construct. + private ConnectorInstance(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private ConnectorInstance() { + id_ = ""; + name_ = ""; + connectorId_ = ""; + dataSources_ = java.util.Collections.emptyList(); + tenantName_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new ConnectorInstance(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_ConnectorInstance_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_ConnectorInstance_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.ConnectorInstance.class, io.trino.spi.grpc.Endpoints.ConnectorInstance.Builder.class); + } + + private int bitField0_; + public static final int ID_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object id_ = ""; + /** + * string id = 1; + * @return The id. + */ + @java.lang.Override + public java.lang.String getId() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } + } + /** + * string id = 1; + * @return The bytes for id. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int NAME_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object name_ = ""; + /** + * string name = 2; + * @return The name. + */ + @java.lang.Override + public java.lang.String getName() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } + } + /** + * string name = 2; + * @return The bytes for name. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int IS_CUSTOM_FIELD_NUMBER = 3; + private boolean isCustom_ = false; + /** + * bool is_custom = 3; + * @return The isCustom. + */ + @java.lang.Override + public boolean getIsCustom() { + return isCustom_; + } + + public static final int CONNECTOR_ID_FIELD_NUMBER = 4; + @SuppressWarnings("serial") + private volatile java.lang.Object connectorId_ = ""; + /** + * string connector_id = 4; + * @return The connectorId. + */ + @java.lang.Override + public java.lang.String getConnectorId() { + java.lang.Object ref = connectorId_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + connectorId_ = s; + return s; + } + } + /** + * string connector_id = 4; + * @return The bytes for connectorId. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getConnectorIdBytes() { + java.lang.Object ref = connectorId_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + connectorId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int LAST_ACTIVITY_TIME_FIELD_NUMBER = 5; + private long lastActivityTime_ = 0L; + /** + * optional int64 last_activity_time = 5; + * @return Whether the lastActivityTime field is set. + */ + @java.lang.Override + public boolean hasLastActivityTime() { + return ((bitField0_ & 0x00000001) != 0); + } + /** + * optional int64 last_activity_time = 5; + * @return The lastActivityTime. + */ + @java.lang.Override + public long getLastActivityTime() { + return lastActivityTime_; + } + + public static final int CONNECTOR_FIELD_NUMBER = 6; + private io.trino.spi.grpc.Endpoints.Connector connector_; + /** + * .grpc.Connector connector = 6; + * @return Whether the connector field is set. + */ + @java.lang.Override + public boolean hasConnector() { + return connector_ != null; + } + /** + * .grpc.Connector connector = 6; + * @return The connector. + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.Connector getConnector() { + return connector_ == null ? io.trino.spi.grpc.Endpoints.Connector.getDefaultInstance() : connector_; + } + /** + * .grpc.Connector connector = 6; + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.ConnectorOrBuilder getConnectorOrBuilder() { + return connector_ == null ? io.trino.spi.grpc.Endpoints.Connector.getDefaultInstance() : connector_; + } + + public static final int DATA_SOURCES_FIELD_NUMBER = 7; + @SuppressWarnings("serial") + private java.util.List dataSources_; + /** + * repeated .grpc.DataSourceInstance data_sources = 7; + */ + @java.lang.Override + public java.util.List getDataSourcesList() { + return dataSources_; + } + /** + * repeated .grpc.DataSourceInstance data_sources = 7; + */ + @java.lang.Override + public java.util.List + getDataSourcesOrBuilderList() { + return dataSources_; + } + /** + * repeated .grpc.DataSourceInstance data_sources = 7; + */ + @java.lang.Override + public int getDataSourcesCount() { + return dataSources_.size(); + } + /** + * repeated .grpc.DataSourceInstance data_sources = 7; + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceInstance getDataSources(int index) { + return dataSources_.get(index); + } + /** + * repeated .grpc.DataSourceInstance data_sources = 7; + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceInstanceOrBuilder getDataSourcesOrBuilder( + int index) { + return dataSources_.get(index); + } + + public static final int BROKER_FIELD_NUMBER = 8; + private io.trino.spi.grpc.Endpoints.Broker broker_; + /** + * .grpc.Broker broker = 8; + * @return Whether the broker field is set. + */ + @java.lang.Override + public boolean hasBroker() { + return broker_ != null; + } + /** + * .grpc.Broker broker = 8; + * @return The broker. + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.Broker getBroker() { + return broker_ == null ? io.trino.spi.grpc.Endpoints.Broker.getDefaultInstance() : broker_; + } + /** + * .grpc.Broker broker = 8; + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BrokerOrBuilder getBrokerOrBuilder() { + return broker_ == null ? io.trino.spi.grpc.Endpoints.Broker.getDefaultInstance() : broker_; + } + + public static final int TENANT_NAME_FIELD_NUMBER = 9; + @SuppressWarnings("serial") + private volatile java.lang.Object tenantName_ = ""; + /** + * string tenant_name = 9; + * @return The tenantName. + */ + @java.lang.Override + public java.lang.String getTenantName() { + java.lang.Object ref = tenantName_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenantName_ = s; + return s; + } + } + /** + * string tenant_name = 9; + * @return The bytes for tenantName. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantNameBytes() { + java.lang.Object ref = tenantName_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenantName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int CREATED_AT_FIELD_NUMBER = 10; + private long createdAt_ = 0L; + /** + * int64 created_at = 10; + * @return The createdAt. + */ + @java.lang.Override + public long getCreatedAt() { + return createdAt_; + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, id_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(name_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, name_); + } + if (isCustom_ != false) { + output.writeBool(3, isCustom_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(connectorId_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 4, connectorId_); + } + if (((bitField0_ & 0x00000001) != 0)) { + output.writeInt64(5, lastActivityTime_); + } + if (connector_ != null) { + output.writeMessage(6, getConnector()); + } + for (int i = 0; i < dataSources_.size(); i++) { + output.writeMessage(7, dataSources_.get(i)); + } + if (broker_ != null) { + output.writeMessage(8, getBroker()); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenantName_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 9, tenantName_); + } + if (createdAt_ != 0L) { + output.writeInt64(10, createdAt_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, id_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(name_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, name_); + } + if (isCustom_ != false) { + size += com.google.protobuf.CodedOutputStream + .computeBoolSize(3, isCustom_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(connectorId_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(4, connectorId_); + } + if (((bitField0_ & 0x00000001) != 0)) { + size += com.google.protobuf.CodedOutputStream + .computeInt64Size(5, lastActivityTime_); + } + if (connector_ != null) { + size += com.google.protobuf.CodedOutputStream + .computeMessageSize(6, getConnector()); + } + for (int i = 0; i < dataSources_.size(); i++) { + size += com.google.protobuf.CodedOutputStream + .computeMessageSize(7, dataSources_.get(i)); + } + if (broker_ != null) { + size += com.google.protobuf.CodedOutputStream + .computeMessageSize(8, getBroker()); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenantName_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(9, tenantName_); + } + if (createdAt_ != 0L) { + size += com.google.protobuf.CodedOutputStream + .computeInt64Size(10, createdAt_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.ConnectorInstance)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.ConnectorInstance other = (io.trino.spi.grpc.Endpoints.ConnectorInstance) obj; + + if (!getId() + .equals(other.getId())) return false; + if (!getName() + .equals(other.getName())) return false; + if (getIsCustom() + != other.getIsCustom()) return false; + if (!getConnectorId() + .equals(other.getConnectorId())) return false; + if (hasLastActivityTime() != other.hasLastActivityTime()) return false; + if (hasLastActivityTime()) { + if (getLastActivityTime() + != other.getLastActivityTime()) return false; + } + if (hasConnector() != other.hasConnector()) return false; + if (hasConnector()) { + if (!getConnector() + .equals(other.getConnector())) return false; + } + if (!getDataSourcesList() + .equals(other.getDataSourcesList())) return false; + if (hasBroker() != other.hasBroker()) return false; + if (hasBroker()) { + if (!getBroker() + .equals(other.getBroker())) return false; + } + if (!getTenantName() + .equals(other.getTenantName())) return false; + if (getCreatedAt() + != other.getCreatedAt()) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + ID_FIELD_NUMBER; + hash = (53 * hash) + getId().hashCode(); + hash = (37 * hash) + NAME_FIELD_NUMBER; + hash = (53 * hash) + getName().hashCode(); + hash = (37 * hash) + IS_CUSTOM_FIELD_NUMBER; + hash = (53 * hash) + com.google.protobuf.Internal.hashBoolean( + getIsCustom()); + hash = (37 * hash) + CONNECTOR_ID_FIELD_NUMBER; + hash = (53 * hash) + getConnectorId().hashCode(); + if (hasLastActivityTime()) { + hash = (37 * hash) + LAST_ACTIVITY_TIME_FIELD_NUMBER; + hash = (53 * hash) + com.google.protobuf.Internal.hashLong( + getLastActivityTime()); + } + if (hasConnector()) { + hash = (37 * hash) + CONNECTOR_FIELD_NUMBER; + hash = (53 * hash) + getConnector().hashCode(); + } + if (getDataSourcesCount() > 0) { + hash = (37 * hash) + DATA_SOURCES_FIELD_NUMBER; + hash = (53 * hash) + getDataSourcesList().hashCode(); + } + if (hasBroker()) { + hash = (37 * hash) + BROKER_FIELD_NUMBER; + hash = (53 * hash) + getBroker().hashCode(); + } + hash = (37 * hash) + TENANT_NAME_FIELD_NUMBER; + hash = (53 * hash) + getTenantName().hashCode(); + hash = (37 * hash) + CREATED_AT_FIELD_NUMBER; + hash = (53 * hash) + com.google.protobuf.Internal.hashLong( + getCreatedAt()); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.ConnectorInstance parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstance parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstance parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstance parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstance parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstance parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstance parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstance parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.ConnectorInstance parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.ConnectorInstance parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstance parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstance parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.ConnectorInstance prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.ConnectorInstance} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.ConnectorInstance) + io.trino.spi.grpc.Endpoints.ConnectorInstanceOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_ConnectorInstance_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_ConnectorInstance_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.ConnectorInstance.class, io.trino.spi.grpc.Endpoints.ConnectorInstance.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.ConnectorInstance.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + id_ = ""; + name_ = ""; + isCustom_ = false; + connectorId_ = ""; + lastActivityTime_ = 0L; + connector_ = null; + if (connectorBuilder_ != null) { + connectorBuilder_.dispose(); + connectorBuilder_ = null; + } + if (dataSourcesBuilder_ == null) { + dataSources_ = java.util.Collections.emptyList(); + } else { + dataSources_ = null; + dataSourcesBuilder_.clear(); + } + bitField0_ = (bitField0_ & ~0x00000040); + broker_ = null; + if (brokerBuilder_ != null) { + brokerBuilder_.dispose(); + brokerBuilder_ = null; + } + tenantName_ = ""; + createdAt_ = 0L; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_ConnectorInstance_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.ConnectorInstance getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.ConnectorInstance.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.ConnectorInstance build() { + io.trino.spi.grpc.Endpoints.ConnectorInstance result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.ConnectorInstance buildPartial() { + io.trino.spi.grpc.Endpoints.ConnectorInstance result = new io.trino.spi.grpc.Endpoints.ConnectorInstance(this); + buildPartialRepeatedFields(result); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartialRepeatedFields(io.trino.spi.grpc.Endpoints.ConnectorInstance result) { + if (dataSourcesBuilder_ == null) { + if (((bitField0_ & 0x00000040) != 0)) { + dataSources_ = java.util.Collections.unmodifiableList(dataSources_); + bitField0_ = (bitField0_ & ~0x00000040); + } + result.dataSources_ = dataSources_; + } else { + result.dataSources_ = dataSourcesBuilder_.build(); + } + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.ConnectorInstance result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.id_ = id_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.name_ = name_; + } + if (((from_bitField0_ & 0x00000004) != 0)) { + result.isCustom_ = isCustom_; + } + if (((from_bitField0_ & 0x00000008) != 0)) { + result.connectorId_ = connectorId_; + } + int to_bitField0_ = 0; + if (((from_bitField0_ & 0x00000010) != 0)) { + result.lastActivityTime_ = lastActivityTime_; + to_bitField0_ |= 0x00000001; + } + if (((from_bitField0_ & 0x00000020) != 0)) { + result.connector_ = connectorBuilder_ == null + ? connector_ + : connectorBuilder_.build(); + } + if (((from_bitField0_ & 0x00000080) != 0)) { + result.broker_ = brokerBuilder_ == null + ? broker_ + : brokerBuilder_.build(); + } + if (((from_bitField0_ & 0x00000100) != 0)) { + result.tenantName_ = tenantName_; + } + if (((from_bitField0_ & 0x00000200) != 0)) { + result.createdAt_ = createdAt_; + } + result.bitField0_ |= to_bitField0_; + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.ConnectorInstance) { + return mergeFrom((io.trino.spi.grpc.Endpoints.ConnectorInstance)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.ConnectorInstance other) { + if (other == io.trino.spi.grpc.Endpoints.ConnectorInstance.getDefaultInstance()) return this; + if (!other.getId().isEmpty()) { + id_ = other.id_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getName().isEmpty()) { + name_ = other.name_; + bitField0_ |= 0x00000002; + onChanged(); + } + if (other.getIsCustom() != false) { + setIsCustom(other.getIsCustom()); + } + if (!other.getConnectorId().isEmpty()) { + connectorId_ = other.connectorId_; + bitField0_ |= 0x00000008; + onChanged(); + } + if (other.hasLastActivityTime()) { + setLastActivityTime(other.getLastActivityTime()); + } + if (other.hasConnector()) { + mergeConnector(other.getConnector()); + } + if (dataSourcesBuilder_ == null) { + if (!other.dataSources_.isEmpty()) { + if (dataSources_.isEmpty()) { + dataSources_ = other.dataSources_; + bitField0_ = (bitField0_ & ~0x00000040); + } else { + ensureDataSourcesIsMutable(); + dataSources_.addAll(other.dataSources_); + } + onChanged(); + } + } else { + if (!other.dataSources_.isEmpty()) { + if (dataSourcesBuilder_.isEmpty()) { + dataSourcesBuilder_.dispose(); + dataSourcesBuilder_ = null; + dataSources_ = other.dataSources_; + bitField0_ = (bitField0_ & ~0x00000040); + dataSourcesBuilder_ = + com.google.protobuf.GeneratedMessageV3.alwaysUseFieldBuilders ? + getDataSourcesFieldBuilder() : null; + } else { + dataSourcesBuilder_.addAllMessages(other.dataSources_); + } + } + } + if (other.hasBroker()) { + mergeBroker(other.getBroker()); + } + if (!other.getTenantName().isEmpty()) { + tenantName_ = other.tenantName_; + bitField0_ |= 0x00000100; + onChanged(); + } + if (other.getCreatedAt() != 0L) { + setCreatedAt(other.getCreatedAt()); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + id_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + name_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + case 24: { + isCustom_ = input.readBool(); + bitField0_ |= 0x00000004; + break; + } // case 24 + case 34: { + connectorId_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000008; + break; + } // case 34 + case 40: { + lastActivityTime_ = input.readInt64(); + bitField0_ |= 0x00000010; + break; + } // case 40 + case 50: { + input.readMessage( + getConnectorFieldBuilder().getBuilder(), + extensionRegistry); + bitField0_ |= 0x00000020; + break; + } // case 50 + case 58: { + io.trino.spi.grpc.Endpoints.DataSourceInstance m = + input.readMessage( + io.trino.spi.grpc.Endpoints.DataSourceInstance.parser(), + extensionRegistry); + if (dataSourcesBuilder_ == null) { + ensureDataSourcesIsMutable(); + dataSources_.add(m); + } else { + dataSourcesBuilder_.addMessage(m); + } + break; + } // case 58 + case 66: { + input.readMessage( + getBrokerFieldBuilder().getBuilder(), + extensionRegistry); + bitField0_ |= 0x00000080; + break; + } // case 66 + case 74: { + tenantName_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000100; + break; + } // case 74 + case 80: { + createdAt_ = input.readInt64(); + bitField0_ |= 0x00000200; + break; + } // case 80 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object id_ = ""; + /** + * string id = 1; + * @return The id. + */ + public java.lang.String getId() { + java.lang.Object ref = id_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string id = 1; + * @return The bytes for id. + */ + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string id = 1; + * @param value The id to set. + * @return This builder for chaining. + */ + public Builder setId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + id_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string id = 1; + * @return This builder for chaining. + */ + public Builder clearId() { + id_ = getDefaultInstance().getId(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string id = 1; + * @param value The bytes for id to set. + * @return This builder for chaining. + */ + public Builder setIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + id_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object name_ = ""; + /** + * string name = 2; + * @return The name. + */ + public java.lang.String getName() { + java.lang.Object ref = name_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string name = 2; + * @return The bytes for name. + */ + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string name = 2; + * @param value The name to set. + * @return This builder for chaining. + */ + public Builder setName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + name_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string name = 2; + * @return This builder for chaining. + */ + public Builder clearName() { + name_ = getDefaultInstance().getName(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string name = 2; + * @param value The bytes for name to set. + * @return This builder for chaining. + */ + public Builder setNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + name_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + + private boolean isCustom_ ; + /** + * bool is_custom = 3; + * @return The isCustom. + */ + @java.lang.Override + public boolean getIsCustom() { + return isCustom_; + } + /** + * bool is_custom = 3; + * @param value The isCustom to set. + * @return This builder for chaining. + */ + public Builder setIsCustom(boolean value) { + + isCustom_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + /** + * bool is_custom = 3; + * @return This builder for chaining. + */ + public Builder clearIsCustom() { + bitField0_ = (bitField0_ & ~0x00000004); + isCustom_ = false; + onChanged(); + return this; + } + + private java.lang.Object connectorId_ = ""; + /** + * string connector_id = 4; + * @return The connectorId. + */ + public java.lang.String getConnectorId() { + java.lang.Object ref = connectorId_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + connectorId_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string connector_id = 4; + * @return The bytes for connectorId. + */ + public com.google.protobuf.ByteString + getConnectorIdBytes() { + java.lang.Object ref = connectorId_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + connectorId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string connector_id = 4; + * @param value The connectorId to set. + * @return This builder for chaining. + */ + public Builder setConnectorId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + connectorId_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + /** + * string connector_id = 4; + * @return This builder for chaining. + */ + public Builder clearConnectorId() { + connectorId_ = getDefaultInstance().getConnectorId(); + bitField0_ = (bitField0_ & ~0x00000008); + onChanged(); + return this; + } + /** + * string connector_id = 4; + * @param value The bytes for connectorId to set. + * @return This builder for chaining. + */ + public Builder setConnectorIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + connectorId_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + + private long lastActivityTime_ ; + /** + * optional int64 last_activity_time = 5; + * @return Whether the lastActivityTime field is set. + */ + @java.lang.Override + public boolean hasLastActivityTime() { + return ((bitField0_ & 0x00000010) != 0); + } + /** + * optional int64 last_activity_time = 5; + * @return The lastActivityTime. + */ + @java.lang.Override + public long getLastActivityTime() { + return lastActivityTime_; + } + /** + * optional int64 last_activity_time = 5; + * @param value The lastActivityTime to set. + * @return This builder for chaining. + */ + public Builder setLastActivityTime(long value) { + + lastActivityTime_ = value; + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + /** + * optional int64 last_activity_time = 5; + * @return This builder for chaining. + */ + public Builder clearLastActivityTime() { + bitField0_ = (bitField0_ & ~0x00000010); + lastActivityTime_ = 0L; + onChanged(); + return this; + } + + private io.trino.spi.grpc.Endpoints.Connector connector_; + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.Connector, io.trino.spi.grpc.Endpoints.Connector.Builder, io.trino.spi.grpc.Endpoints.ConnectorOrBuilder> connectorBuilder_; + /** + * .grpc.Connector connector = 6; + * @return Whether the connector field is set. + */ + public boolean hasConnector() { + return ((bitField0_ & 0x00000020) != 0); + } + /** + * .grpc.Connector connector = 6; + * @return The connector. + */ + public io.trino.spi.grpc.Endpoints.Connector getConnector() { + if (connectorBuilder_ == null) { + return connector_ == null ? io.trino.spi.grpc.Endpoints.Connector.getDefaultInstance() : connector_; + } else { + return connectorBuilder_.getMessage(); + } + } + /** + * .grpc.Connector connector = 6; + */ + public Builder setConnector(io.trino.spi.grpc.Endpoints.Connector value) { + if (connectorBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + connector_ = value; + } else { + connectorBuilder_.setMessage(value); + } + bitField0_ |= 0x00000020; + onChanged(); + return this; + } + /** + * .grpc.Connector connector = 6; + */ + public Builder setConnector( + io.trino.spi.grpc.Endpoints.Connector.Builder builderForValue) { + if (connectorBuilder_ == null) { + connector_ = builderForValue.build(); + } else { + connectorBuilder_.setMessage(builderForValue.build()); + } + bitField0_ |= 0x00000020; + onChanged(); + return this; + } + /** + * .grpc.Connector connector = 6; + */ + public Builder mergeConnector(io.trino.spi.grpc.Endpoints.Connector value) { + if (connectorBuilder_ == null) { + if (((bitField0_ & 0x00000020) != 0) && + connector_ != null && + connector_ != io.trino.spi.grpc.Endpoints.Connector.getDefaultInstance()) { + getConnectorBuilder().mergeFrom(value); + } else { + connector_ = value; + } + } else { + connectorBuilder_.mergeFrom(value); + } + bitField0_ |= 0x00000020; + onChanged(); + return this; + } + /** + * .grpc.Connector connector = 6; + */ + public Builder clearConnector() { + bitField0_ = (bitField0_ & ~0x00000020); + connector_ = null; + if (connectorBuilder_ != null) { + connectorBuilder_.dispose(); + connectorBuilder_ = null; + } + onChanged(); + return this; + } + /** + * .grpc.Connector connector = 6; + */ + public io.trino.spi.grpc.Endpoints.Connector.Builder getConnectorBuilder() { + bitField0_ |= 0x00000020; + onChanged(); + return getConnectorFieldBuilder().getBuilder(); + } + /** + * .grpc.Connector connector = 6; + */ + public io.trino.spi.grpc.Endpoints.ConnectorOrBuilder getConnectorOrBuilder() { + if (connectorBuilder_ != null) { + return connectorBuilder_.getMessageOrBuilder(); + } else { + return connector_ == null ? + io.trino.spi.grpc.Endpoints.Connector.getDefaultInstance() : connector_; + } + } + /** + * .grpc.Connector connector = 6; + */ + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.Connector, io.trino.spi.grpc.Endpoints.Connector.Builder, io.trino.spi.grpc.Endpoints.ConnectorOrBuilder> + getConnectorFieldBuilder() { + if (connectorBuilder_ == null) { + connectorBuilder_ = new com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.Connector, io.trino.spi.grpc.Endpoints.Connector.Builder, io.trino.spi.grpc.Endpoints.ConnectorOrBuilder>( + getConnector(), + getParentForChildren(), + isClean()); + connector_ = null; + } + return connectorBuilder_; + } + + private java.util.List dataSources_ = + java.util.Collections.emptyList(); + private void ensureDataSourcesIsMutable() { + if (!((bitField0_ & 0x00000040) != 0)) { + dataSources_ = new java.util.ArrayList(dataSources_); + bitField0_ |= 0x00000040; + } + } + + private com.google.protobuf.RepeatedFieldBuilderV3< + io.trino.spi.grpc.Endpoints.DataSourceInstance, io.trino.spi.grpc.Endpoints.DataSourceInstance.Builder, io.trino.spi.grpc.Endpoints.DataSourceInstanceOrBuilder> dataSourcesBuilder_; + + /** + * repeated .grpc.DataSourceInstance data_sources = 7; + */ + public java.util.List getDataSourcesList() { + if (dataSourcesBuilder_ == null) { + return java.util.Collections.unmodifiableList(dataSources_); + } else { + return dataSourcesBuilder_.getMessageList(); + } + } + /** + * repeated .grpc.DataSourceInstance data_sources = 7; + */ + public int getDataSourcesCount() { + if (dataSourcesBuilder_ == null) { + return dataSources_.size(); + } else { + return dataSourcesBuilder_.getCount(); + } + } + /** + * repeated .grpc.DataSourceInstance data_sources = 7; + */ + public io.trino.spi.grpc.Endpoints.DataSourceInstance getDataSources(int index) { + if (dataSourcesBuilder_ == null) { + return dataSources_.get(index); + } else { + return dataSourcesBuilder_.getMessage(index); + } + } + /** + * repeated .grpc.DataSourceInstance data_sources = 7; + */ + public Builder setDataSources( + int index, io.trino.spi.grpc.Endpoints.DataSourceInstance value) { + if (dataSourcesBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + ensureDataSourcesIsMutable(); + dataSources_.set(index, value); + onChanged(); + } else { + dataSourcesBuilder_.setMessage(index, value); + } + return this; + } + /** + * repeated .grpc.DataSourceInstance data_sources = 7; + */ + public Builder setDataSources( + int index, io.trino.spi.grpc.Endpoints.DataSourceInstance.Builder builderForValue) { + if (dataSourcesBuilder_ == null) { + ensureDataSourcesIsMutable(); + dataSources_.set(index, builderForValue.build()); + onChanged(); + } else { + dataSourcesBuilder_.setMessage(index, builderForValue.build()); + } + return this; + } + /** + * repeated .grpc.DataSourceInstance data_sources = 7; + */ + public Builder addDataSources(io.trino.spi.grpc.Endpoints.DataSourceInstance value) { + if (dataSourcesBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + ensureDataSourcesIsMutable(); + dataSources_.add(value); + onChanged(); + } else { + dataSourcesBuilder_.addMessage(value); + } + return this; + } + /** + * repeated .grpc.DataSourceInstance data_sources = 7; + */ + public Builder addDataSources( + int index, io.trino.spi.grpc.Endpoints.DataSourceInstance value) { + if (dataSourcesBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + ensureDataSourcesIsMutable(); + dataSources_.add(index, value); + onChanged(); + } else { + dataSourcesBuilder_.addMessage(index, value); + } + return this; + } + /** + * repeated .grpc.DataSourceInstance data_sources = 7; + */ + public Builder addDataSources( + io.trino.spi.grpc.Endpoints.DataSourceInstance.Builder builderForValue) { + if (dataSourcesBuilder_ == null) { + ensureDataSourcesIsMutable(); + dataSources_.add(builderForValue.build()); + onChanged(); + } else { + dataSourcesBuilder_.addMessage(builderForValue.build()); + } + return this; + } + /** + * repeated .grpc.DataSourceInstance data_sources = 7; + */ + public Builder addDataSources( + int index, io.trino.spi.grpc.Endpoints.DataSourceInstance.Builder builderForValue) { + if (dataSourcesBuilder_ == null) { + ensureDataSourcesIsMutable(); + dataSources_.add(index, builderForValue.build()); + onChanged(); + } else { + dataSourcesBuilder_.addMessage(index, builderForValue.build()); + } + return this; + } + /** + * repeated .grpc.DataSourceInstance data_sources = 7; + */ + public Builder addAllDataSources( + java.lang.Iterable values) { + if (dataSourcesBuilder_ == null) { + ensureDataSourcesIsMutable(); + com.google.protobuf.AbstractMessageLite.Builder.addAll( + values, dataSources_); + onChanged(); + } else { + dataSourcesBuilder_.addAllMessages(values); + } + return this; + } + /** + * repeated .grpc.DataSourceInstance data_sources = 7; + */ + public Builder clearDataSources() { + if (dataSourcesBuilder_ == null) { + dataSources_ = java.util.Collections.emptyList(); + bitField0_ = (bitField0_ & ~0x00000040); + onChanged(); + } else { + dataSourcesBuilder_.clear(); + } + return this; + } + /** + * repeated .grpc.DataSourceInstance data_sources = 7; + */ + public Builder removeDataSources(int index) { + if (dataSourcesBuilder_ == null) { + ensureDataSourcesIsMutable(); + dataSources_.remove(index); + onChanged(); + } else { + dataSourcesBuilder_.remove(index); + } + return this; + } + /** + * repeated .grpc.DataSourceInstance data_sources = 7; + */ + public io.trino.spi.grpc.Endpoints.DataSourceInstance.Builder getDataSourcesBuilder( + int index) { + return getDataSourcesFieldBuilder().getBuilder(index); + } + /** + * repeated .grpc.DataSourceInstance data_sources = 7; + */ + public io.trino.spi.grpc.Endpoints.DataSourceInstanceOrBuilder getDataSourcesOrBuilder( + int index) { + if (dataSourcesBuilder_ == null) { + return dataSources_.get(index); } else { + return dataSourcesBuilder_.getMessageOrBuilder(index); + } + } + /** + * repeated .grpc.DataSourceInstance data_sources = 7; + */ + public java.util.List + getDataSourcesOrBuilderList() { + if (dataSourcesBuilder_ != null) { + return dataSourcesBuilder_.getMessageOrBuilderList(); + } else { + return java.util.Collections.unmodifiableList(dataSources_); + } + } + /** + * repeated .grpc.DataSourceInstance data_sources = 7; + */ + public io.trino.spi.grpc.Endpoints.DataSourceInstance.Builder addDataSourcesBuilder() { + return getDataSourcesFieldBuilder().addBuilder( + io.trino.spi.grpc.Endpoints.DataSourceInstance.getDefaultInstance()); + } + /** + * repeated .grpc.DataSourceInstance data_sources = 7; + */ + public io.trino.spi.grpc.Endpoints.DataSourceInstance.Builder addDataSourcesBuilder( + int index) { + return getDataSourcesFieldBuilder().addBuilder( + index, io.trino.spi.grpc.Endpoints.DataSourceInstance.getDefaultInstance()); + } + /** + * repeated .grpc.DataSourceInstance data_sources = 7; + */ + public java.util.List + getDataSourcesBuilderList() { + return getDataSourcesFieldBuilder().getBuilderList(); + } + private com.google.protobuf.RepeatedFieldBuilderV3< + io.trino.spi.grpc.Endpoints.DataSourceInstance, io.trino.spi.grpc.Endpoints.DataSourceInstance.Builder, io.trino.spi.grpc.Endpoints.DataSourceInstanceOrBuilder> + getDataSourcesFieldBuilder() { + if (dataSourcesBuilder_ == null) { + dataSourcesBuilder_ = new com.google.protobuf.RepeatedFieldBuilderV3< + io.trino.spi.grpc.Endpoints.DataSourceInstance, io.trino.spi.grpc.Endpoints.DataSourceInstance.Builder, io.trino.spi.grpc.Endpoints.DataSourceInstanceOrBuilder>( + dataSources_, + ((bitField0_ & 0x00000040) != 0), + getParentForChildren(), + isClean()); + dataSources_ = null; + } + return dataSourcesBuilder_; + } + + private io.trino.spi.grpc.Endpoints.Broker broker_; + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.Broker, io.trino.spi.grpc.Endpoints.Broker.Builder, io.trino.spi.grpc.Endpoints.BrokerOrBuilder> brokerBuilder_; + /** + * .grpc.Broker broker = 8; + * @return Whether the broker field is set. + */ + public boolean hasBroker() { + return ((bitField0_ & 0x00000080) != 0); + } + /** + * .grpc.Broker broker = 8; + * @return The broker. + */ + public io.trino.spi.grpc.Endpoints.Broker getBroker() { + if (brokerBuilder_ == null) { + return broker_ == null ? io.trino.spi.grpc.Endpoints.Broker.getDefaultInstance() : broker_; + } else { + return brokerBuilder_.getMessage(); + } + } + /** + * .grpc.Broker broker = 8; + */ + public Builder setBroker(io.trino.spi.grpc.Endpoints.Broker value) { + if (brokerBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + broker_ = value; + } else { + brokerBuilder_.setMessage(value); + } + bitField0_ |= 0x00000080; + onChanged(); + return this; + } + /** + * .grpc.Broker broker = 8; + */ + public Builder setBroker( + io.trino.spi.grpc.Endpoints.Broker.Builder builderForValue) { + if (brokerBuilder_ == null) { + broker_ = builderForValue.build(); + } else { + brokerBuilder_.setMessage(builderForValue.build()); + } + bitField0_ |= 0x00000080; + onChanged(); + return this; + } + /** + * .grpc.Broker broker = 8; + */ + public Builder mergeBroker(io.trino.spi.grpc.Endpoints.Broker value) { + if (brokerBuilder_ == null) { + if (((bitField0_ & 0x00000080) != 0) && + broker_ != null && + broker_ != io.trino.spi.grpc.Endpoints.Broker.getDefaultInstance()) { + getBrokerBuilder().mergeFrom(value); + } else { + broker_ = value; + } + } else { + brokerBuilder_.mergeFrom(value); + } + bitField0_ |= 0x00000080; + onChanged(); + return this; + } + /** + * .grpc.Broker broker = 8; + */ + public Builder clearBroker() { + bitField0_ = (bitField0_ & ~0x00000080); + broker_ = null; + if (brokerBuilder_ != null) { + brokerBuilder_.dispose(); + brokerBuilder_ = null; + } + onChanged(); + return this; + } + /** + * .grpc.Broker broker = 8; + */ + public io.trino.spi.grpc.Endpoints.Broker.Builder getBrokerBuilder() { + bitField0_ |= 0x00000080; + onChanged(); + return getBrokerFieldBuilder().getBuilder(); + } + /** + * .grpc.Broker broker = 8; + */ + public io.trino.spi.grpc.Endpoints.BrokerOrBuilder getBrokerOrBuilder() { + if (brokerBuilder_ != null) { + return brokerBuilder_.getMessageOrBuilder(); + } else { + return broker_ == null ? + io.trino.spi.grpc.Endpoints.Broker.getDefaultInstance() : broker_; + } + } + /** + * .grpc.Broker broker = 8; + */ + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.Broker, io.trino.spi.grpc.Endpoints.Broker.Builder, io.trino.spi.grpc.Endpoints.BrokerOrBuilder> + getBrokerFieldBuilder() { + if (brokerBuilder_ == null) { + brokerBuilder_ = new com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.Broker, io.trino.spi.grpc.Endpoints.Broker.Builder, io.trino.spi.grpc.Endpoints.BrokerOrBuilder>( + getBroker(), + getParentForChildren(), + isClean()); + broker_ = null; + } + return brokerBuilder_; + } + + private java.lang.Object tenantName_ = ""; + /** + * string tenant_name = 9; + * @return The tenantName. + */ + public java.lang.String getTenantName() { + java.lang.Object ref = tenantName_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenantName_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant_name = 9; + * @return The bytes for tenantName. + */ + public com.google.protobuf.ByteString + getTenantNameBytes() { + java.lang.Object ref = tenantName_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenantName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant_name = 9; + * @param value The tenantName to set. + * @return This builder for chaining. + */ + public Builder setTenantName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenantName_ = value; + bitField0_ |= 0x00000100; + onChanged(); + return this; + } + /** + * string tenant_name = 9; + * @return This builder for chaining. + */ + public Builder clearTenantName() { + tenantName_ = getDefaultInstance().getTenantName(); + bitField0_ = (bitField0_ & ~0x00000100); + onChanged(); + return this; + } + /** + * string tenant_name = 9; + * @param value The bytes for tenantName to set. + * @return This builder for chaining. + */ + public Builder setTenantNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenantName_ = value; + bitField0_ |= 0x00000100; + onChanged(); + return this; + } + + private long createdAt_ ; + /** + * int64 created_at = 10; + * @return The createdAt. + */ + @java.lang.Override + public long getCreatedAt() { + return createdAt_; + } + /** + * int64 created_at = 10; + * @param value The createdAt to set. + * @return This builder for chaining. + */ + public Builder setCreatedAt(long value) { + + createdAt_ = value; + bitField0_ |= 0x00000200; + onChanged(); + return this; + } + /** + * int64 created_at = 10; + * @return This builder for chaining. + */ + public Builder clearCreatedAt() { + bitField0_ = (bitField0_ & ~0x00000200); + createdAt_ = 0L; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.ConnectorInstance) + } + + // @@protoc_insertion_point(class_scope:grpc.ConnectorInstance) + private static final io.trino.spi.grpc.Endpoints.ConnectorInstance DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.ConnectorInstance(); + } + + public static io.trino.spi.grpc.Endpoints.ConnectorInstance getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public ConnectorInstance parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.ConnectorInstance getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface HttpEndpointOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.HttpEndpoint) + com.google.protobuf.MessageOrBuilder { + + /** + * string id = 1; + * @return The id. + */ + java.lang.String getId(); + /** + * string id = 1; + * @return The bytes for id. + */ + com.google.protobuf.ByteString + getIdBytes(); + + /** + * string connector_id = 2; + * @return The connectorId. + */ + java.lang.String getConnectorId(); + /** + * string connector_id = 2; + * @return The bytes for connectorId. + */ + com.google.protobuf.ByteString + getConnectorIdBytes(); + + /** + * string name = 3; + * @return The name. + */ + java.lang.String getName(); + /** + * string name = 3; + * @return The bytes for name. + */ + com.google.protobuf.ByteString + getNameBytes(); + + /** + * optional string description = 4; + * @return Whether the description field is set. + */ + boolean hasDescription(); + /** + * optional string description = 4; + * @return The description. + */ + java.lang.String getDescription(); + /** + * optional string description = 4; + * @return The bytes for description. + */ + com.google.protobuf.ByteString + getDescriptionBytes(); + + /** + * int32 method_type = 5; + * @return The methodType. + */ + int getMethodType(); + + /** + * string url_format = 6; + * @return The urlFormat. + */ + java.lang.String getUrlFormat(); + /** + * string url_format = 6; + * @return The bytes for urlFormat. + */ + com.google.protobuf.ByteString + getUrlFormatBytes(); + + /** + * repeated .grpc.Parameter request_parameters = 7; + */ + java.util.List + getRequestParametersList(); + /** + * repeated .grpc.Parameter request_parameters = 7; + */ + io.trino.spi.grpc.Endpoints.Parameter getRequestParameters(int index); + /** + * repeated .grpc.Parameter request_parameters = 7; + */ + int getRequestParametersCount(); + /** + * repeated .grpc.Parameter request_parameters = 7; + */ + java.util.List + getRequestParametersOrBuilderList(); + /** + * repeated .grpc.Parameter request_parameters = 7; + */ + io.trino.spi.grpc.Endpoints.ParameterOrBuilder getRequestParametersOrBuilder( + int index); + + /** + * string connector_instance_name = 8; + * @return The connectorInstanceName. + */ + java.lang.String getConnectorInstanceName(); + /** + * string connector_instance_name = 8; + * @return The bytes for connectorInstanceName. + */ + com.google.protobuf.ByteString + getConnectorInstanceNameBytes(); + + /** + * string connector_instance_id = 9; + * @return The connectorInstanceId. + */ + java.lang.String getConnectorInstanceId(); + /** + * string connector_instance_id = 9; + * @return The bytes for connectorInstanceId. + */ + com.google.protobuf.ByteString + getConnectorInstanceIdBytes(); + } + /** + * Protobuf type {@code grpc.HttpEndpoint} + */ + public static final class HttpEndpoint extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.HttpEndpoint) + HttpEndpointOrBuilder { + private static final long serialVersionUID = 0L; + // Use HttpEndpoint.newBuilder() to construct. + private HttpEndpoint(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private HttpEndpoint() { + id_ = ""; + connectorId_ = ""; + name_ = ""; + description_ = ""; + urlFormat_ = ""; + requestParameters_ = java.util.Collections.emptyList(); + connectorInstanceName_ = ""; + connectorInstanceId_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new HttpEndpoint(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_HttpEndpoint_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_HttpEndpoint_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.HttpEndpoint.class, io.trino.spi.grpc.Endpoints.HttpEndpoint.Builder.class); + } + + private int bitField0_; + public static final int ID_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object id_ = ""; + /** + * string id = 1; + * @return The id. + */ + @java.lang.Override + public java.lang.String getId() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } + } + /** + * string id = 1; + * @return The bytes for id. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int CONNECTOR_ID_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object connectorId_ = ""; + /** + * string connector_id = 2; + * @return The connectorId. + */ + @java.lang.Override + public java.lang.String getConnectorId() { + java.lang.Object ref = connectorId_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + connectorId_ = s; + return s; + } + } + /** + * string connector_id = 2; + * @return The bytes for connectorId. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getConnectorIdBytes() { + java.lang.Object ref = connectorId_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + connectorId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int NAME_FIELD_NUMBER = 3; + @SuppressWarnings("serial") + private volatile java.lang.Object name_ = ""; + /** + * string name = 3; + * @return The name. + */ + @java.lang.Override + public java.lang.String getName() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } + } + /** + * string name = 3; + * @return The bytes for name. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int DESCRIPTION_FIELD_NUMBER = 4; + @SuppressWarnings("serial") + private volatile java.lang.Object description_ = ""; + /** + * optional string description = 4; + * @return Whether the description field is set. + */ + @java.lang.Override + public boolean hasDescription() { + return ((bitField0_ & 0x00000001) != 0); + } + /** + * optional string description = 4; + * @return The description. + */ + @java.lang.Override + public java.lang.String getDescription() { + java.lang.Object ref = description_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + description_ = s; + return s; + } + } + /** + * optional string description = 4; + * @return The bytes for description. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getDescriptionBytes() { + java.lang.Object ref = description_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + description_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int METHOD_TYPE_FIELD_NUMBER = 5; + private int methodType_ = 0; + /** + * int32 method_type = 5; + * @return The methodType. + */ + @java.lang.Override + public int getMethodType() { + return methodType_; + } + + public static final int URL_FORMAT_FIELD_NUMBER = 6; + @SuppressWarnings("serial") + private volatile java.lang.Object urlFormat_ = ""; + /** + * string url_format = 6; + * @return The urlFormat. + */ + @java.lang.Override + public java.lang.String getUrlFormat() { + java.lang.Object ref = urlFormat_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + urlFormat_ = s; + return s; + } + } + /** + * string url_format = 6; + * @return The bytes for urlFormat. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getUrlFormatBytes() { + java.lang.Object ref = urlFormat_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + urlFormat_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int REQUEST_PARAMETERS_FIELD_NUMBER = 7; + @SuppressWarnings("serial") + private java.util.List requestParameters_; + /** + * repeated .grpc.Parameter request_parameters = 7; + */ + @java.lang.Override + public java.util.List getRequestParametersList() { + return requestParameters_; + } + /** + * repeated .grpc.Parameter request_parameters = 7; + */ + @java.lang.Override + public java.util.List + getRequestParametersOrBuilderList() { + return requestParameters_; + } + /** + * repeated .grpc.Parameter request_parameters = 7; + */ + @java.lang.Override + public int getRequestParametersCount() { + return requestParameters_.size(); + } + /** + * repeated .grpc.Parameter request_parameters = 7; + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.Parameter getRequestParameters(int index) { + return requestParameters_.get(index); + } + /** + * repeated .grpc.Parameter request_parameters = 7; + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.ParameterOrBuilder getRequestParametersOrBuilder( + int index) { + return requestParameters_.get(index); + } + + public static final int CONNECTOR_INSTANCE_NAME_FIELD_NUMBER = 8; + @SuppressWarnings("serial") + private volatile java.lang.Object connectorInstanceName_ = ""; + /** + * string connector_instance_name = 8; + * @return The connectorInstanceName. + */ + @java.lang.Override + public java.lang.String getConnectorInstanceName() { + java.lang.Object ref = connectorInstanceName_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + connectorInstanceName_ = s; + return s; + } + } + /** + * string connector_instance_name = 8; + * @return The bytes for connectorInstanceName. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getConnectorInstanceNameBytes() { + java.lang.Object ref = connectorInstanceName_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + connectorInstanceName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int CONNECTOR_INSTANCE_ID_FIELD_NUMBER = 9; + @SuppressWarnings("serial") + private volatile java.lang.Object connectorInstanceId_ = ""; + /** + * string connector_instance_id = 9; + * @return The connectorInstanceId. + */ + @java.lang.Override + public java.lang.String getConnectorInstanceId() { + java.lang.Object ref = connectorInstanceId_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + connectorInstanceId_ = s; + return s; + } + } + /** + * string connector_instance_id = 9; + * @return The bytes for connectorInstanceId. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getConnectorInstanceIdBytes() { + java.lang.Object ref = connectorInstanceId_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + connectorInstanceId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, id_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(connectorId_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, connectorId_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(name_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 3, name_); + } + if (((bitField0_ & 0x00000001) != 0)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 4, description_); + } + if (methodType_ != 0) { + output.writeInt32(5, methodType_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(urlFormat_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 6, urlFormat_); + } + for (int i = 0; i < requestParameters_.size(); i++) { + output.writeMessage(7, requestParameters_.get(i)); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(connectorInstanceName_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 8, connectorInstanceName_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(connectorInstanceId_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 9, connectorInstanceId_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, id_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(connectorId_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, connectorId_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(name_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(3, name_); + } + if (((bitField0_ & 0x00000001) != 0)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(4, description_); + } + if (methodType_ != 0) { + size += com.google.protobuf.CodedOutputStream + .computeInt32Size(5, methodType_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(urlFormat_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(6, urlFormat_); + } + for (int i = 0; i < requestParameters_.size(); i++) { + size += com.google.protobuf.CodedOutputStream + .computeMessageSize(7, requestParameters_.get(i)); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(connectorInstanceName_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(8, connectorInstanceName_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(connectorInstanceId_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(9, connectorInstanceId_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.HttpEndpoint)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.HttpEndpoint other = (io.trino.spi.grpc.Endpoints.HttpEndpoint) obj; + + if (!getId() + .equals(other.getId())) return false; + if (!getConnectorId() + .equals(other.getConnectorId())) return false; + if (!getName() + .equals(other.getName())) return false; + if (hasDescription() != other.hasDescription()) return false; + if (hasDescription()) { + if (!getDescription() + .equals(other.getDescription())) return false; + } + if (getMethodType() + != other.getMethodType()) return false; + if (!getUrlFormat() + .equals(other.getUrlFormat())) return false; + if (!getRequestParametersList() + .equals(other.getRequestParametersList())) return false; + if (!getConnectorInstanceName() + .equals(other.getConnectorInstanceName())) return false; + if (!getConnectorInstanceId() + .equals(other.getConnectorInstanceId())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + ID_FIELD_NUMBER; + hash = (53 * hash) + getId().hashCode(); + hash = (37 * hash) + CONNECTOR_ID_FIELD_NUMBER; + hash = (53 * hash) + getConnectorId().hashCode(); + hash = (37 * hash) + NAME_FIELD_NUMBER; + hash = (53 * hash) + getName().hashCode(); + if (hasDescription()) { + hash = (37 * hash) + DESCRIPTION_FIELD_NUMBER; + hash = (53 * hash) + getDescription().hashCode(); + } + hash = (37 * hash) + METHOD_TYPE_FIELD_NUMBER; + hash = (53 * hash) + getMethodType(); + hash = (37 * hash) + URL_FORMAT_FIELD_NUMBER; + hash = (53 * hash) + getUrlFormat().hashCode(); + if (getRequestParametersCount() > 0) { + hash = (37 * hash) + REQUEST_PARAMETERS_FIELD_NUMBER; + hash = (53 * hash) + getRequestParametersList().hashCode(); + } + hash = (37 * hash) + CONNECTOR_INSTANCE_NAME_FIELD_NUMBER; + hash = (53 * hash) + getConnectorInstanceName().hashCode(); + hash = (37 * hash) + CONNECTOR_INSTANCE_ID_FIELD_NUMBER; + hash = (53 * hash) + getConnectorInstanceId().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.HttpEndpoint parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.HttpEndpoint parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.HttpEndpoint parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.HttpEndpoint parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.HttpEndpoint parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.HttpEndpoint parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.HttpEndpoint parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.HttpEndpoint parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.HttpEndpoint parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.HttpEndpoint parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.HttpEndpoint parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.HttpEndpoint parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.HttpEndpoint prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.HttpEndpoint} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.HttpEndpoint) + io.trino.spi.grpc.Endpoints.HttpEndpointOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_HttpEndpoint_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_HttpEndpoint_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.HttpEndpoint.class, io.trino.spi.grpc.Endpoints.HttpEndpoint.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.HttpEndpoint.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + id_ = ""; + connectorId_ = ""; + name_ = ""; + description_ = ""; + methodType_ = 0; + urlFormat_ = ""; + if (requestParametersBuilder_ == null) { + requestParameters_ = java.util.Collections.emptyList(); + } else { + requestParameters_ = null; + requestParametersBuilder_.clear(); + } + bitField0_ = (bitField0_ & ~0x00000040); + connectorInstanceName_ = ""; + connectorInstanceId_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_HttpEndpoint_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.HttpEndpoint getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.HttpEndpoint.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.HttpEndpoint build() { + io.trino.spi.grpc.Endpoints.HttpEndpoint result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.HttpEndpoint buildPartial() { + io.trino.spi.grpc.Endpoints.HttpEndpoint result = new io.trino.spi.grpc.Endpoints.HttpEndpoint(this); + buildPartialRepeatedFields(result); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartialRepeatedFields(io.trino.spi.grpc.Endpoints.HttpEndpoint result) { + if (requestParametersBuilder_ == null) { + if (((bitField0_ & 0x00000040) != 0)) { + requestParameters_ = java.util.Collections.unmodifiableList(requestParameters_); + bitField0_ = (bitField0_ & ~0x00000040); + } + result.requestParameters_ = requestParameters_; + } else { + result.requestParameters_ = requestParametersBuilder_.build(); + } + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.HttpEndpoint result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.id_ = id_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.connectorId_ = connectorId_; + } + if (((from_bitField0_ & 0x00000004) != 0)) { + result.name_ = name_; + } + int to_bitField0_ = 0; + if (((from_bitField0_ & 0x00000008) != 0)) { + result.description_ = description_; + to_bitField0_ |= 0x00000001; + } + if (((from_bitField0_ & 0x00000010) != 0)) { + result.methodType_ = methodType_; + } + if (((from_bitField0_ & 0x00000020) != 0)) { + result.urlFormat_ = urlFormat_; + } + if (((from_bitField0_ & 0x00000080) != 0)) { + result.connectorInstanceName_ = connectorInstanceName_; + } + if (((from_bitField0_ & 0x00000100) != 0)) { + result.connectorInstanceId_ = connectorInstanceId_; + } + result.bitField0_ |= to_bitField0_; + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.HttpEndpoint) { + return mergeFrom((io.trino.spi.grpc.Endpoints.HttpEndpoint)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.HttpEndpoint other) { + if (other == io.trino.spi.grpc.Endpoints.HttpEndpoint.getDefaultInstance()) return this; + if (!other.getId().isEmpty()) { + id_ = other.id_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getConnectorId().isEmpty()) { + connectorId_ = other.connectorId_; + bitField0_ |= 0x00000002; + onChanged(); + } + if (!other.getName().isEmpty()) { + name_ = other.name_; + bitField0_ |= 0x00000004; + onChanged(); + } + if (other.hasDescription()) { + description_ = other.description_; + bitField0_ |= 0x00000008; + onChanged(); + } + if (other.getMethodType() != 0) { + setMethodType(other.getMethodType()); + } + if (!other.getUrlFormat().isEmpty()) { + urlFormat_ = other.urlFormat_; + bitField0_ |= 0x00000020; + onChanged(); + } + if (requestParametersBuilder_ == null) { + if (!other.requestParameters_.isEmpty()) { + if (requestParameters_.isEmpty()) { + requestParameters_ = other.requestParameters_; + bitField0_ = (bitField0_ & ~0x00000040); + } else { + ensureRequestParametersIsMutable(); + requestParameters_.addAll(other.requestParameters_); + } + onChanged(); + } + } else { + if (!other.requestParameters_.isEmpty()) { + if (requestParametersBuilder_.isEmpty()) { + requestParametersBuilder_.dispose(); + requestParametersBuilder_ = null; + requestParameters_ = other.requestParameters_; + bitField0_ = (bitField0_ & ~0x00000040); + requestParametersBuilder_ = + com.google.protobuf.GeneratedMessageV3.alwaysUseFieldBuilders ? + getRequestParametersFieldBuilder() : null; + } else { + requestParametersBuilder_.addAllMessages(other.requestParameters_); + } + } + } + if (!other.getConnectorInstanceName().isEmpty()) { + connectorInstanceName_ = other.connectorInstanceName_; + bitField0_ |= 0x00000080; + onChanged(); + } + if (!other.getConnectorInstanceId().isEmpty()) { + connectorInstanceId_ = other.connectorInstanceId_; + bitField0_ |= 0x00000100; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + id_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + connectorId_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + case 26: { + name_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000004; + break; + } // case 26 + case 34: { + description_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000008; + break; + } // case 34 + case 40: { + methodType_ = input.readInt32(); + bitField0_ |= 0x00000010; + break; + } // case 40 + case 50: { + urlFormat_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000020; + break; + } // case 50 + case 58: { + io.trino.spi.grpc.Endpoints.Parameter m = + input.readMessage( + io.trino.spi.grpc.Endpoints.Parameter.parser(), + extensionRegistry); + if (requestParametersBuilder_ == null) { + ensureRequestParametersIsMutable(); + requestParameters_.add(m); + } else { + requestParametersBuilder_.addMessage(m); + } + break; + } // case 58 + case 66: { + connectorInstanceName_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000080; + break; + } // case 66 + case 74: { + connectorInstanceId_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000100; + break; + } // case 74 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object id_ = ""; + /** + * string id = 1; + * @return The id. + */ + public java.lang.String getId() { + java.lang.Object ref = id_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string id = 1; + * @return The bytes for id. + */ + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string id = 1; + * @param value The id to set. + * @return This builder for chaining. + */ + public Builder setId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + id_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string id = 1; + * @return This builder for chaining. + */ + public Builder clearId() { + id_ = getDefaultInstance().getId(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string id = 1; + * @param value The bytes for id to set. + * @return This builder for chaining. + */ + public Builder setIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + id_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object connectorId_ = ""; + /** + * string connector_id = 2; + * @return The connectorId. + */ + public java.lang.String getConnectorId() { + java.lang.Object ref = connectorId_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + connectorId_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string connector_id = 2; + * @return The bytes for connectorId. + */ + public com.google.protobuf.ByteString + getConnectorIdBytes() { + java.lang.Object ref = connectorId_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + connectorId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string connector_id = 2; + * @param value The connectorId to set. + * @return This builder for chaining. + */ + public Builder setConnectorId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + connectorId_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string connector_id = 2; + * @return This builder for chaining. + */ + public Builder clearConnectorId() { + connectorId_ = getDefaultInstance().getConnectorId(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string connector_id = 2; + * @param value The bytes for connectorId to set. + * @return This builder for chaining. + */ + public Builder setConnectorIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + connectorId_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + + private java.lang.Object name_ = ""; + /** + * string name = 3; + * @return The name. + */ + public java.lang.String getName() { + java.lang.Object ref = name_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string name = 3; + * @return The bytes for name. + */ + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string name = 3; + * @param value The name to set. + * @return This builder for chaining. + */ + public Builder setName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + name_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + /** + * string name = 3; + * @return This builder for chaining. + */ + public Builder clearName() { + name_ = getDefaultInstance().getName(); + bitField0_ = (bitField0_ & ~0x00000004); + onChanged(); + return this; + } + /** + * string name = 3; + * @param value The bytes for name to set. + * @return This builder for chaining. + */ + public Builder setNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + name_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + + private java.lang.Object description_ = ""; + /** + * optional string description = 4; + * @return Whether the description field is set. + */ + public boolean hasDescription() { + return ((bitField0_ & 0x00000008) != 0); + } + /** + * optional string description = 4; + * @return The description. + */ + public java.lang.String getDescription() { + java.lang.Object ref = description_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + description_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * optional string description = 4; + * @return The bytes for description. + */ + public com.google.protobuf.ByteString + getDescriptionBytes() { + java.lang.Object ref = description_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + description_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * optional string description = 4; + * @param value The description to set. + * @return This builder for chaining. + */ + public Builder setDescription( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + description_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + /** + * optional string description = 4; + * @return This builder for chaining. + */ + public Builder clearDescription() { + description_ = getDefaultInstance().getDescription(); + bitField0_ = (bitField0_ & ~0x00000008); + onChanged(); + return this; + } + /** + * optional string description = 4; + * @param value The bytes for description to set. + * @return This builder for chaining. + */ + public Builder setDescriptionBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + description_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + + private int methodType_ ; + /** + * int32 method_type = 5; + * @return The methodType. + */ + @java.lang.Override + public int getMethodType() { + return methodType_; + } + /** + * int32 method_type = 5; + * @param value The methodType to set. + * @return This builder for chaining. + */ + public Builder setMethodType(int value) { + + methodType_ = value; + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + /** + * int32 method_type = 5; + * @return This builder for chaining. + */ + public Builder clearMethodType() { + bitField0_ = (bitField0_ & ~0x00000010); + methodType_ = 0; + onChanged(); + return this; + } + + private java.lang.Object urlFormat_ = ""; + /** + * string url_format = 6; + * @return The urlFormat. + */ + public java.lang.String getUrlFormat() { + java.lang.Object ref = urlFormat_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + urlFormat_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string url_format = 6; + * @return The bytes for urlFormat. + */ + public com.google.protobuf.ByteString + getUrlFormatBytes() { + java.lang.Object ref = urlFormat_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + urlFormat_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string url_format = 6; + * @param value The urlFormat to set. + * @return This builder for chaining. + */ + public Builder setUrlFormat( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + urlFormat_ = value; + bitField0_ |= 0x00000020; + onChanged(); + return this; + } + /** + * string url_format = 6; + * @return This builder for chaining. + */ + public Builder clearUrlFormat() { + urlFormat_ = getDefaultInstance().getUrlFormat(); + bitField0_ = (bitField0_ & ~0x00000020); + onChanged(); + return this; + } + /** + * string url_format = 6; + * @param value The bytes for urlFormat to set. + * @return This builder for chaining. + */ + public Builder setUrlFormatBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + urlFormat_ = value; + bitField0_ |= 0x00000020; + onChanged(); + return this; + } + + private java.util.List requestParameters_ = + java.util.Collections.emptyList(); + private void ensureRequestParametersIsMutable() { + if (!((bitField0_ & 0x00000040) != 0)) { + requestParameters_ = new java.util.ArrayList(requestParameters_); + bitField0_ |= 0x00000040; + } + } + + private com.google.protobuf.RepeatedFieldBuilderV3< + io.trino.spi.grpc.Endpoints.Parameter, io.trino.spi.grpc.Endpoints.Parameter.Builder, io.trino.spi.grpc.Endpoints.ParameterOrBuilder> requestParametersBuilder_; + + /** + * repeated .grpc.Parameter request_parameters = 7; + */ + public java.util.List getRequestParametersList() { + if (requestParametersBuilder_ == null) { + return java.util.Collections.unmodifiableList(requestParameters_); + } else { + return requestParametersBuilder_.getMessageList(); + } + } + /** + * repeated .grpc.Parameter request_parameters = 7; + */ + public int getRequestParametersCount() { + if (requestParametersBuilder_ == null) { + return requestParameters_.size(); + } else { + return requestParametersBuilder_.getCount(); + } + } + /** + * repeated .grpc.Parameter request_parameters = 7; + */ + public io.trino.spi.grpc.Endpoints.Parameter getRequestParameters(int index) { + if (requestParametersBuilder_ == null) { + return requestParameters_.get(index); + } else { + return requestParametersBuilder_.getMessage(index); + } + } + /** + * repeated .grpc.Parameter request_parameters = 7; + */ + public Builder setRequestParameters( + int index, io.trino.spi.grpc.Endpoints.Parameter value) { + if (requestParametersBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + ensureRequestParametersIsMutable(); + requestParameters_.set(index, value); + onChanged(); + } else { + requestParametersBuilder_.setMessage(index, value); + } + return this; + } + /** + * repeated .grpc.Parameter request_parameters = 7; + */ + public Builder setRequestParameters( + int index, io.trino.spi.grpc.Endpoints.Parameter.Builder builderForValue) { + if (requestParametersBuilder_ == null) { + ensureRequestParametersIsMutable(); + requestParameters_.set(index, builderForValue.build()); + onChanged(); + } else { + requestParametersBuilder_.setMessage(index, builderForValue.build()); + } + return this; + } + /** + * repeated .grpc.Parameter request_parameters = 7; + */ + public Builder addRequestParameters(io.trino.spi.grpc.Endpoints.Parameter value) { + if (requestParametersBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + ensureRequestParametersIsMutable(); + requestParameters_.add(value); + onChanged(); + } else { + requestParametersBuilder_.addMessage(value); + } + return this; + } + /** + * repeated .grpc.Parameter request_parameters = 7; + */ + public Builder addRequestParameters( + int index, io.trino.spi.grpc.Endpoints.Parameter value) { + if (requestParametersBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + ensureRequestParametersIsMutable(); + requestParameters_.add(index, value); + onChanged(); + } else { + requestParametersBuilder_.addMessage(index, value); + } + return this; + } + /** + * repeated .grpc.Parameter request_parameters = 7; + */ + public Builder addRequestParameters( + io.trino.spi.grpc.Endpoints.Parameter.Builder builderForValue) { + if (requestParametersBuilder_ == null) { + ensureRequestParametersIsMutable(); + requestParameters_.add(builderForValue.build()); + onChanged(); + } else { + requestParametersBuilder_.addMessage(builderForValue.build()); + } + return this; + } + /** + * repeated .grpc.Parameter request_parameters = 7; + */ + public Builder addRequestParameters( + int index, io.trino.spi.grpc.Endpoints.Parameter.Builder builderForValue) { + if (requestParametersBuilder_ == null) { + ensureRequestParametersIsMutable(); + requestParameters_.add(index, builderForValue.build()); + onChanged(); + } else { + requestParametersBuilder_.addMessage(index, builderForValue.build()); + } + return this; + } + /** + * repeated .grpc.Parameter request_parameters = 7; + */ + public Builder addAllRequestParameters( + java.lang.Iterable values) { + if (requestParametersBuilder_ == null) { + ensureRequestParametersIsMutable(); + com.google.protobuf.AbstractMessageLite.Builder.addAll( + values, requestParameters_); + onChanged(); + } else { + requestParametersBuilder_.addAllMessages(values); + } + return this; + } + /** + * repeated .grpc.Parameter request_parameters = 7; + */ + public Builder clearRequestParameters() { + if (requestParametersBuilder_ == null) { + requestParameters_ = java.util.Collections.emptyList(); + bitField0_ = (bitField0_ & ~0x00000040); + onChanged(); + } else { + requestParametersBuilder_.clear(); + } + return this; + } + /** + * repeated .grpc.Parameter request_parameters = 7; + */ + public Builder removeRequestParameters(int index) { + if (requestParametersBuilder_ == null) { + ensureRequestParametersIsMutable(); + requestParameters_.remove(index); + onChanged(); + } else { + requestParametersBuilder_.remove(index); + } + return this; + } + /** + * repeated .grpc.Parameter request_parameters = 7; + */ + public io.trino.spi.grpc.Endpoints.Parameter.Builder getRequestParametersBuilder( + int index) { + return getRequestParametersFieldBuilder().getBuilder(index); + } + /** + * repeated .grpc.Parameter request_parameters = 7; + */ + public io.trino.spi.grpc.Endpoints.ParameterOrBuilder getRequestParametersOrBuilder( + int index) { + if (requestParametersBuilder_ == null) { + return requestParameters_.get(index); } else { + return requestParametersBuilder_.getMessageOrBuilder(index); + } + } + /** + * repeated .grpc.Parameter request_parameters = 7; + */ + public java.util.List + getRequestParametersOrBuilderList() { + if (requestParametersBuilder_ != null) { + return requestParametersBuilder_.getMessageOrBuilderList(); + } else { + return java.util.Collections.unmodifiableList(requestParameters_); + } + } + /** + * repeated .grpc.Parameter request_parameters = 7; + */ + public io.trino.spi.grpc.Endpoints.Parameter.Builder addRequestParametersBuilder() { + return getRequestParametersFieldBuilder().addBuilder( + io.trino.spi.grpc.Endpoints.Parameter.getDefaultInstance()); + } + /** + * repeated .grpc.Parameter request_parameters = 7; + */ + public io.trino.spi.grpc.Endpoints.Parameter.Builder addRequestParametersBuilder( + int index) { + return getRequestParametersFieldBuilder().addBuilder( + index, io.trino.spi.grpc.Endpoints.Parameter.getDefaultInstance()); + } + /** + * repeated .grpc.Parameter request_parameters = 7; + */ + public java.util.List + getRequestParametersBuilderList() { + return getRequestParametersFieldBuilder().getBuilderList(); + } + private com.google.protobuf.RepeatedFieldBuilderV3< + io.trino.spi.grpc.Endpoints.Parameter, io.trino.spi.grpc.Endpoints.Parameter.Builder, io.trino.spi.grpc.Endpoints.ParameterOrBuilder> + getRequestParametersFieldBuilder() { + if (requestParametersBuilder_ == null) { + requestParametersBuilder_ = new com.google.protobuf.RepeatedFieldBuilderV3< + io.trino.spi.grpc.Endpoints.Parameter, io.trino.spi.grpc.Endpoints.Parameter.Builder, io.trino.spi.grpc.Endpoints.ParameterOrBuilder>( + requestParameters_, + ((bitField0_ & 0x00000040) != 0), + getParentForChildren(), + isClean()); + requestParameters_ = null; + } + return requestParametersBuilder_; + } + + private java.lang.Object connectorInstanceName_ = ""; + /** + * string connector_instance_name = 8; + * @return The connectorInstanceName. + */ + public java.lang.String getConnectorInstanceName() { + java.lang.Object ref = connectorInstanceName_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + connectorInstanceName_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string connector_instance_name = 8; + * @return The bytes for connectorInstanceName. + */ + public com.google.protobuf.ByteString + getConnectorInstanceNameBytes() { + java.lang.Object ref = connectorInstanceName_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + connectorInstanceName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string connector_instance_name = 8; + * @param value The connectorInstanceName to set. + * @return This builder for chaining. + */ + public Builder setConnectorInstanceName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + connectorInstanceName_ = value; + bitField0_ |= 0x00000080; + onChanged(); + return this; + } + /** + * string connector_instance_name = 8; + * @return This builder for chaining. + */ + public Builder clearConnectorInstanceName() { + connectorInstanceName_ = getDefaultInstance().getConnectorInstanceName(); + bitField0_ = (bitField0_ & ~0x00000080); + onChanged(); + return this; + } + /** + * string connector_instance_name = 8; + * @param value The bytes for connectorInstanceName to set. + * @return This builder for chaining. + */ + public Builder setConnectorInstanceNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + connectorInstanceName_ = value; + bitField0_ |= 0x00000080; + onChanged(); + return this; + } + + private java.lang.Object connectorInstanceId_ = ""; + /** + * string connector_instance_id = 9; + * @return The connectorInstanceId. + */ + public java.lang.String getConnectorInstanceId() { + java.lang.Object ref = connectorInstanceId_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + connectorInstanceId_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string connector_instance_id = 9; + * @return The bytes for connectorInstanceId. + */ + public com.google.protobuf.ByteString + getConnectorInstanceIdBytes() { + java.lang.Object ref = connectorInstanceId_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + connectorInstanceId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string connector_instance_id = 9; + * @param value The connectorInstanceId to set. + * @return This builder for chaining. + */ + public Builder setConnectorInstanceId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + connectorInstanceId_ = value; + bitField0_ |= 0x00000100; + onChanged(); + return this; + } + /** + * string connector_instance_id = 9; + * @return This builder for chaining. + */ + public Builder clearConnectorInstanceId() { + connectorInstanceId_ = getDefaultInstance().getConnectorInstanceId(); + bitField0_ = (bitField0_ & ~0x00000100); + onChanged(); + return this; + } + /** + * string connector_instance_id = 9; + * @param value The bytes for connectorInstanceId to set. + * @return This builder for chaining. + */ + public Builder setConnectorInstanceIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + connectorInstanceId_ = value; + bitField0_ |= 0x00000100; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.HttpEndpoint) + } + + // @@protoc_insertion_point(class_scope:grpc.HttpEndpoint) + private static final io.trino.spi.grpc.Endpoints.HttpEndpoint DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.HttpEndpoint(); + } + + public static io.trino.spi.grpc.Endpoints.HttpEndpoint getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public HttpEndpoint parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.HttpEndpoint getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface BoolResponseOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.BoolResponse) + com.google.protobuf.MessageOrBuilder { + + /** + * bool istrue = 1; + * @return The istrue. + */ + boolean getIstrue(); + } + /** + * Protobuf type {@code grpc.BoolResponse} + */ + public static final class BoolResponse extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.BoolResponse) + BoolResponseOrBuilder { + private static final long serialVersionUID = 0L; + // Use BoolResponse.newBuilder() to construct. + private BoolResponse(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private BoolResponse() { + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new BoolResponse(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BoolResponse_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BoolResponse_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.BoolResponse.class, io.trino.spi.grpc.Endpoints.BoolResponse.Builder.class); + } + + public static final int ISTRUE_FIELD_NUMBER = 1; + private boolean istrue_ = false; + /** + * bool istrue = 1; + * @return The istrue. + */ + @java.lang.Override + public boolean getIstrue() { + return istrue_; + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (istrue_ != false) { + output.writeBool(1, istrue_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (istrue_ != false) { + size += com.google.protobuf.CodedOutputStream + .computeBoolSize(1, istrue_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.BoolResponse)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.BoolResponse other = (io.trino.spi.grpc.Endpoints.BoolResponse) obj; + + if (getIstrue() + != other.getIstrue()) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + ISTRUE_FIELD_NUMBER; + hash = (53 * hash) + com.google.protobuf.Internal.hashBoolean( + getIstrue()); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.BoolResponse parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.BoolResponse parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.BoolResponse parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.BoolResponse parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.BoolResponse parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.BoolResponse parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.BoolResponse parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.BoolResponse parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.BoolResponse parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.BoolResponse parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.BoolResponse parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.BoolResponse parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.BoolResponse prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.BoolResponse} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.BoolResponse) + io.trino.spi.grpc.Endpoints.BoolResponseOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BoolResponse_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BoolResponse_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.BoolResponse.class, io.trino.spi.grpc.Endpoints.BoolResponse.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.BoolResponse.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + istrue_ = false; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BoolResponse_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BoolResponse getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.BoolResponse.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BoolResponse build() { + io.trino.spi.grpc.Endpoints.BoolResponse result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BoolResponse buildPartial() { + io.trino.spi.grpc.Endpoints.BoolResponse result = new io.trino.spi.grpc.Endpoints.BoolResponse(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.BoolResponse result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.istrue_ = istrue_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.BoolResponse) { + return mergeFrom((io.trino.spi.grpc.Endpoints.BoolResponse)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.BoolResponse other) { + if (other == io.trino.spi.grpc.Endpoints.BoolResponse.getDefaultInstance()) return this; + if (other.getIstrue() != false) { + setIstrue(other.getIstrue()); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 8: { + istrue_ = input.readBool(); + bitField0_ |= 0x00000001; + break; + } // case 8 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private boolean istrue_ ; + /** + * bool istrue = 1; + * @return The istrue. + */ + @java.lang.Override + public boolean getIstrue() { + return istrue_; + } + /** + * bool istrue = 1; + * @param value The istrue to set. + * @return This builder for chaining. + */ + public Builder setIstrue(boolean value) { + + istrue_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * bool istrue = 1; + * @return This builder for chaining. + */ + public Builder clearIstrue() { + bitField0_ = (bitField0_ & ~0x00000001); + istrue_ = false; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.BoolResponse) + } + + // @@protoc_insertion_point(class_scope:grpc.BoolResponse) + private static final io.trino.spi.grpc.Endpoints.BoolResponse DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.BoolResponse(); + } + + public static io.trino.spi.grpc.Endpoints.BoolResponse getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public BoolResponse parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BoolResponse getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface BrokerPublicIPOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.BrokerPublicIP) + com.google.protobuf.MessageOrBuilder { + + /** + * string tenant_name = 1; + * @return The tenantName. + */ + java.lang.String getTenantName(); + /** + * string tenant_name = 1; + * @return The bytes for tenantName. + */ + com.google.protobuf.ByteString + getTenantNameBytes(); + + /** + * string public_ip = 2; + * @return The publicIp. + */ + java.lang.String getPublicIp(); + /** + * string public_ip = 2; + * @return The bytes for publicIp. + */ + com.google.protobuf.ByteString + getPublicIpBytes(); + } + /** + * Protobuf type {@code grpc.BrokerPublicIP} + */ + public static final class BrokerPublicIP extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.BrokerPublicIP) + BrokerPublicIPOrBuilder { + private static final long serialVersionUID = 0L; + // Use BrokerPublicIP.newBuilder() to construct. + private BrokerPublicIP(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private BrokerPublicIP() { + tenantName_ = ""; + publicIp_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new BrokerPublicIP(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BrokerPublicIP_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BrokerPublicIP_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.BrokerPublicIP.class, io.trino.spi.grpc.Endpoints.BrokerPublicIP.Builder.class); + } + + public static final int TENANT_NAME_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object tenantName_ = ""; + /** + * string tenant_name = 1; + * @return The tenantName. + */ + @java.lang.Override + public java.lang.String getTenantName() { + java.lang.Object ref = tenantName_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenantName_ = s; + return s; + } + } + /** + * string tenant_name = 1; + * @return The bytes for tenantName. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantNameBytes() { + java.lang.Object ref = tenantName_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenantName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int PUBLIC_IP_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object publicIp_ = ""; + /** + * string public_ip = 2; + * @return The publicIp. + */ + @java.lang.Override + public java.lang.String getPublicIp() { + java.lang.Object ref = publicIp_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + publicIp_ = s; + return s; + } + } + /** + * string public_ip = 2; + * @return The bytes for publicIp. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getPublicIpBytes() { + java.lang.Object ref = publicIp_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + publicIp_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenantName_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, tenantName_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(publicIp_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, publicIp_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenantName_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, tenantName_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(publicIp_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, publicIp_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.BrokerPublicIP)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.BrokerPublicIP other = (io.trino.spi.grpc.Endpoints.BrokerPublicIP) obj; + + if (!getTenantName() + .equals(other.getTenantName())) return false; + if (!getPublicIp() + .equals(other.getPublicIp())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + TENANT_NAME_FIELD_NUMBER; + hash = (53 * hash) + getTenantName().hashCode(); + hash = (37 * hash) + PUBLIC_IP_FIELD_NUMBER; + hash = (53 * hash) + getPublicIp().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.BrokerPublicIP parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.BrokerPublicIP parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.BrokerPublicIP parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.BrokerPublicIP parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.BrokerPublicIP parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.BrokerPublicIP parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.BrokerPublicIP parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.BrokerPublicIP parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.BrokerPublicIP parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.BrokerPublicIP parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.BrokerPublicIP parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.BrokerPublicIP parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.BrokerPublicIP prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.BrokerPublicIP} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.BrokerPublicIP) + io.trino.spi.grpc.Endpoints.BrokerPublicIPOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BrokerPublicIP_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BrokerPublicIP_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.BrokerPublicIP.class, io.trino.spi.grpc.Endpoints.BrokerPublicIP.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.BrokerPublicIP.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + tenantName_ = ""; + publicIp_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BrokerPublicIP_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BrokerPublicIP getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.BrokerPublicIP.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BrokerPublicIP build() { + io.trino.spi.grpc.Endpoints.BrokerPublicIP result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BrokerPublicIP buildPartial() { + io.trino.spi.grpc.Endpoints.BrokerPublicIP result = new io.trino.spi.grpc.Endpoints.BrokerPublicIP(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.BrokerPublicIP result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.tenantName_ = tenantName_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.publicIp_ = publicIp_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.BrokerPublicIP) { + return mergeFrom((io.trino.spi.grpc.Endpoints.BrokerPublicIP)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.BrokerPublicIP other) { + if (other == io.trino.spi.grpc.Endpoints.BrokerPublicIP.getDefaultInstance()) return this; + if (!other.getTenantName().isEmpty()) { + tenantName_ = other.tenantName_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getPublicIp().isEmpty()) { + publicIp_ = other.publicIp_; + bitField0_ |= 0x00000002; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + tenantName_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + publicIp_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object tenantName_ = ""; + /** + * string tenant_name = 1; + * @return The tenantName. + */ + public java.lang.String getTenantName() { + java.lang.Object ref = tenantName_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenantName_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant_name = 1; + * @return The bytes for tenantName. + */ + public com.google.protobuf.ByteString + getTenantNameBytes() { + java.lang.Object ref = tenantName_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenantName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant_name = 1; + * @param value The tenantName to set. + * @return This builder for chaining. + */ + public Builder setTenantName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenantName_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string tenant_name = 1; + * @return This builder for chaining. + */ + public Builder clearTenantName() { + tenantName_ = getDefaultInstance().getTenantName(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string tenant_name = 1; + * @param value The bytes for tenantName to set. + * @return This builder for chaining. + */ + public Builder setTenantNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenantName_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object publicIp_ = ""; + /** + * string public_ip = 2; + * @return The publicIp. + */ + public java.lang.String getPublicIp() { + java.lang.Object ref = publicIp_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + publicIp_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string public_ip = 2; + * @return The bytes for publicIp. + */ + public com.google.protobuf.ByteString + getPublicIpBytes() { + java.lang.Object ref = publicIp_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + publicIp_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string public_ip = 2; + * @param value The publicIp to set. + * @return This builder for chaining. + */ + public Builder setPublicIp( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + publicIp_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string public_ip = 2; + * @return This builder for chaining. + */ + public Builder clearPublicIp() { + publicIp_ = getDefaultInstance().getPublicIp(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string public_ip = 2; + * @param value The bytes for publicIp to set. + * @return This builder for chaining. + */ + public Builder setPublicIpBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + publicIp_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.BrokerPublicIP) + } + + // @@protoc_insertion_point(class_scope:grpc.BrokerPublicIP) + private static final io.trino.spi.grpc.Endpoints.BrokerPublicIP DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.BrokerPublicIP(); + } + + public static io.trino.spi.grpc.Endpoints.BrokerPublicIP getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public BrokerPublicIP parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BrokerPublicIP getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface BrokerProxyDetailsOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.BrokerProxyDetails) + com.google.protobuf.MessageOrBuilder { + + /** + * string broker_server_ip = 1; + * @return The brokerServerIp. + */ + java.lang.String getBrokerServerIp(); + /** + * string broker_server_ip = 1; + * @return The bytes for brokerServerIp. + */ + com.google.protobuf.ByteString + getBrokerServerIpBytes(); + + /** + * int32 broker_server_port = 2; + * @return The brokerServerPort. + */ + int getBrokerServerPort(); + + /** + * string broker_server_token = 3; + * @return The brokerServerToken. + */ + java.lang.String getBrokerServerToken(); + /** + * string broker_server_token = 3; + * @return The bytes for brokerServerToken. + */ + com.google.protobuf.ByteString + getBrokerServerTokenBytes(); + + /** + * string proxy_name = 4; + * @return The proxyName. + */ + java.lang.String getProxyName(); + /** + * string proxy_name = 4; + * @return The bytes for proxyName. + */ + com.google.protobuf.ByteString + getProxyNameBytes(); + + /** + * string proxy_password = 5; + * @return The proxyPassword. + */ + java.lang.String getProxyPassword(); + /** + * string proxy_password = 5; + * @return The bytes for proxyPassword. + */ + com.google.protobuf.ByteString + getProxyPasswordBytes(); + + /** + * string socks_proxy_username = 6; + * @return The socksProxyUsername. + */ + java.lang.String getSocksProxyUsername(); + /** + * string socks_proxy_username = 6; + * @return The bytes for socksProxyUsername. + */ + com.google.protobuf.ByteString + getSocksProxyUsernameBytes(); + + /** + * string socks_proxy_password = 7; + * @return The socksProxyPassword. + */ + java.lang.String getSocksProxyPassword(); + /** + * string socks_proxy_password = 7; + * @return The bytes for socksProxyPassword. + */ + com.google.protobuf.ByteString + getSocksProxyPasswordBytes(); + + /** + * int32 subnet = 8; + * @return The subnet. + */ + int getSubnet(); + + /** + * int32 VisitorPort = 9; + * @return The visitorPort. + */ + int getVisitorPort(); + + /** + * string tenant_name = 10; + * @return The tenantName. + */ + java.lang.String getTenantName(); + /** + * string tenant_name = 10; + * @return The bytes for tenantName. + */ + com.google.protobuf.ByteString + getTenantNameBytes(); + } + /** + * Protobuf type {@code grpc.BrokerProxyDetails} + */ + public static final class BrokerProxyDetails extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.BrokerProxyDetails) + BrokerProxyDetailsOrBuilder { + private static final long serialVersionUID = 0L; + // Use BrokerProxyDetails.newBuilder() to construct. + private BrokerProxyDetails(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private BrokerProxyDetails() { + brokerServerIp_ = ""; + brokerServerToken_ = ""; + proxyName_ = ""; + proxyPassword_ = ""; + socksProxyUsername_ = ""; + socksProxyPassword_ = ""; + tenantName_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new BrokerProxyDetails(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BrokerProxyDetails_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BrokerProxyDetails_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.BrokerProxyDetails.class, io.trino.spi.grpc.Endpoints.BrokerProxyDetails.Builder.class); + } + + public static final int BROKER_SERVER_IP_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object brokerServerIp_ = ""; + /** + * string broker_server_ip = 1; + * @return The brokerServerIp. + */ + @java.lang.Override + public java.lang.String getBrokerServerIp() { + java.lang.Object ref = brokerServerIp_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + brokerServerIp_ = s; + return s; + } + } + /** + * string broker_server_ip = 1; + * @return The bytes for brokerServerIp. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getBrokerServerIpBytes() { + java.lang.Object ref = brokerServerIp_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + brokerServerIp_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int BROKER_SERVER_PORT_FIELD_NUMBER = 2; + private int brokerServerPort_ = 0; + /** + * int32 broker_server_port = 2; + * @return The brokerServerPort. + */ + @java.lang.Override + public int getBrokerServerPort() { + return brokerServerPort_; + } + + public static final int BROKER_SERVER_TOKEN_FIELD_NUMBER = 3; + @SuppressWarnings("serial") + private volatile java.lang.Object brokerServerToken_ = ""; + /** + * string broker_server_token = 3; + * @return The brokerServerToken. + */ + @java.lang.Override + public java.lang.String getBrokerServerToken() { + java.lang.Object ref = brokerServerToken_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + brokerServerToken_ = s; + return s; + } + } + /** + * string broker_server_token = 3; + * @return The bytes for brokerServerToken. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getBrokerServerTokenBytes() { + java.lang.Object ref = brokerServerToken_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + brokerServerToken_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int PROXY_NAME_FIELD_NUMBER = 4; + @SuppressWarnings("serial") + private volatile java.lang.Object proxyName_ = ""; + /** + * string proxy_name = 4; + * @return The proxyName. + */ + @java.lang.Override + public java.lang.String getProxyName() { + java.lang.Object ref = proxyName_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + proxyName_ = s; + return s; + } + } + /** + * string proxy_name = 4; + * @return The bytes for proxyName. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getProxyNameBytes() { + java.lang.Object ref = proxyName_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + proxyName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int PROXY_PASSWORD_FIELD_NUMBER = 5; + @SuppressWarnings("serial") + private volatile java.lang.Object proxyPassword_ = ""; + /** + * string proxy_password = 5; + * @return The proxyPassword. + */ + @java.lang.Override + public java.lang.String getProxyPassword() { + java.lang.Object ref = proxyPassword_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + proxyPassword_ = s; + return s; + } + } + /** + * string proxy_password = 5; + * @return The bytes for proxyPassword. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getProxyPasswordBytes() { + java.lang.Object ref = proxyPassword_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + proxyPassword_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int SOCKS_PROXY_USERNAME_FIELD_NUMBER = 6; + @SuppressWarnings("serial") + private volatile java.lang.Object socksProxyUsername_ = ""; + /** + * string socks_proxy_username = 6; + * @return The socksProxyUsername. + */ + @java.lang.Override + public java.lang.String getSocksProxyUsername() { + java.lang.Object ref = socksProxyUsername_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + socksProxyUsername_ = s; + return s; + } + } + /** + * string socks_proxy_username = 6; + * @return The bytes for socksProxyUsername. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getSocksProxyUsernameBytes() { + java.lang.Object ref = socksProxyUsername_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + socksProxyUsername_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int SOCKS_PROXY_PASSWORD_FIELD_NUMBER = 7; + @SuppressWarnings("serial") + private volatile java.lang.Object socksProxyPassword_ = ""; + /** + * string socks_proxy_password = 7; + * @return The socksProxyPassword. + */ + @java.lang.Override + public java.lang.String getSocksProxyPassword() { + java.lang.Object ref = socksProxyPassword_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + socksProxyPassword_ = s; + return s; + } + } + /** + * string socks_proxy_password = 7; + * @return The bytes for socksProxyPassword. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getSocksProxyPasswordBytes() { + java.lang.Object ref = socksProxyPassword_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + socksProxyPassword_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int SUBNET_FIELD_NUMBER = 8; + private int subnet_ = 0; + /** + * int32 subnet = 8; + * @return The subnet. + */ + @java.lang.Override + public int getSubnet() { + return subnet_; + } + + public static final int VISITORPORT_FIELD_NUMBER = 9; + private int visitorPort_ = 0; + /** + * int32 VisitorPort = 9; + * @return The visitorPort. + */ + @java.lang.Override + public int getVisitorPort() { + return visitorPort_; + } + + public static final int TENANT_NAME_FIELD_NUMBER = 10; + @SuppressWarnings("serial") + private volatile java.lang.Object tenantName_ = ""; + /** + * string tenant_name = 10; + * @return The tenantName. + */ + @java.lang.Override + public java.lang.String getTenantName() { + java.lang.Object ref = tenantName_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenantName_ = s; + return s; + } + } + /** + * string tenant_name = 10; + * @return The bytes for tenantName. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantNameBytes() { + java.lang.Object ref = tenantName_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenantName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(brokerServerIp_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, brokerServerIp_); + } + if (brokerServerPort_ != 0) { + output.writeInt32(2, brokerServerPort_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(brokerServerToken_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 3, brokerServerToken_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(proxyName_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 4, proxyName_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(proxyPassword_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 5, proxyPassword_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(socksProxyUsername_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 6, socksProxyUsername_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(socksProxyPassword_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 7, socksProxyPassword_); + } + if (subnet_ != 0) { + output.writeInt32(8, subnet_); + } + if (visitorPort_ != 0) { + output.writeInt32(9, visitorPort_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenantName_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 10, tenantName_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(brokerServerIp_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, brokerServerIp_); + } + if (brokerServerPort_ != 0) { + size += com.google.protobuf.CodedOutputStream + .computeInt32Size(2, brokerServerPort_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(brokerServerToken_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(3, brokerServerToken_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(proxyName_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(4, proxyName_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(proxyPassword_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(5, proxyPassword_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(socksProxyUsername_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(6, socksProxyUsername_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(socksProxyPassword_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(7, socksProxyPassword_); + } + if (subnet_ != 0) { + size += com.google.protobuf.CodedOutputStream + .computeInt32Size(8, subnet_); + } + if (visitorPort_ != 0) { + size += com.google.protobuf.CodedOutputStream + .computeInt32Size(9, visitorPort_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenantName_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(10, tenantName_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.BrokerProxyDetails)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.BrokerProxyDetails other = (io.trino.spi.grpc.Endpoints.BrokerProxyDetails) obj; + + if (!getBrokerServerIp() + .equals(other.getBrokerServerIp())) return false; + if (getBrokerServerPort() + != other.getBrokerServerPort()) return false; + if (!getBrokerServerToken() + .equals(other.getBrokerServerToken())) return false; + if (!getProxyName() + .equals(other.getProxyName())) return false; + if (!getProxyPassword() + .equals(other.getProxyPassword())) return false; + if (!getSocksProxyUsername() + .equals(other.getSocksProxyUsername())) return false; + if (!getSocksProxyPassword() + .equals(other.getSocksProxyPassword())) return false; + if (getSubnet() + != other.getSubnet()) return false; + if (getVisitorPort() + != other.getVisitorPort()) return false; + if (!getTenantName() + .equals(other.getTenantName())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + BROKER_SERVER_IP_FIELD_NUMBER; + hash = (53 * hash) + getBrokerServerIp().hashCode(); + hash = (37 * hash) + BROKER_SERVER_PORT_FIELD_NUMBER; + hash = (53 * hash) + getBrokerServerPort(); + hash = (37 * hash) + BROKER_SERVER_TOKEN_FIELD_NUMBER; + hash = (53 * hash) + getBrokerServerToken().hashCode(); + hash = (37 * hash) + PROXY_NAME_FIELD_NUMBER; + hash = (53 * hash) + getProxyName().hashCode(); + hash = (37 * hash) + PROXY_PASSWORD_FIELD_NUMBER; + hash = (53 * hash) + getProxyPassword().hashCode(); + hash = (37 * hash) + SOCKS_PROXY_USERNAME_FIELD_NUMBER; + hash = (53 * hash) + getSocksProxyUsername().hashCode(); + hash = (37 * hash) + SOCKS_PROXY_PASSWORD_FIELD_NUMBER; + hash = (53 * hash) + getSocksProxyPassword().hashCode(); + hash = (37 * hash) + SUBNET_FIELD_NUMBER; + hash = (53 * hash) + getSubnet(); + hash = (37 * hash) + VISITORPORT_FIELD_NUMBER; + hash = (53 * hash) + getVisitorPort(); + hash = (37 * hash) + TENANT_NAME_FIELD_NUMBER; + hash = (53 * hash) + getTenantName().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.BrokerProxyDetails parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.BrokerProxyDetails parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.BrokerProxyDetails parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.BrokerProxyDetails parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.BrokerProxyDetails parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.BrokerProxyDetails parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.BrokerProxyDetails parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.BrokerProxyDetails parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.BrokerProxyDetails parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.BrokerProxyDetails parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.BrokerProxyDetails parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.BrokerProxyDetails parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.BrokerProxyDetails prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.BrokerProxyDetails} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.BrokerProxyDetails) + io.trino.spi.grpc.Endpoints.BrokerProxyDetailsOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BrokerProxyDetails_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BrokerProxyDetails_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.BrokerProxyDetails.class, io.trino.spi.grpc.Endpoints.BrokerProxyDetails.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.BrokerProxyDetails.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + brokerServerIp_ = ""; + brokerServerPort_ = 0; + brokerServerToken_ = ""; + proxyName_ = ""; + proxyPassword_ = ""; + socksProxyUsername_ = ""; + socksProxyPassword_ = ""; + subnet_ = 0; + visitorPort_ = 0; + tenantName_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BrokerProxyDetails_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BrokerProxyDetails getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.BrokerProxyDetails.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BrokerProxyDetails build() { + io.trino.spi.grpc.Endpoints.BrokerProxyDetails result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BrokerProxyDetails buildPartial() { + io.trino.spi.grpc.Endpoints.BrokerProxyDetails result = new io.trino.spi.grpc.Endpoints.BrokerProxyDetails(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.BrokerProxyDetails result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.brokerServerIp_ = brokerServerIp_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.brokerServerPort_ = brokerServerPort_; + } + if (((from_bitField0_ & 0x00000004) != 0)) { + result.brokerServerToken_ = brokerServerToken_; + } + if (((from_bitField0_ & 0x00000008) != 0)) { + result.proxyName_ = proxyName_; + } + if (((from_bitField0_ & 0x00000010) != 0)) { + result.proxyPassword_ = proxyPassword_; + } + if (((from_bitField0_ & 0x00000020) != 0)) { + result.socksProxyUsername_ = socksProxyUsername_; + } + if (((from_bitField0_ & 0x00000040) != 0)) { + result.socksProxyPassword_ = socksProxyPassword_; + } + if (((from_bitField0_ & 0x00000080) != 0)) { + result.subnet_ = subnet_; + } + if (((from_bitField0_ & 0x00000100) != 0)) { + result.visitorPort_ = visitorPort_; + } + if (((from_bitField0_ & 0x00000200) != 0)) { + result.tenantName_ = tenantName_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.BrokerProxyDetails) { + return mergeFrom((io.trino.spi.grpc.Endpoints.BrokerProxyDetails)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.BrokerProxyDetails other) { + if (other == io.trino.spi.grpc.Endpoints.BrokerProxyDetails.getDefaultInstance()) return this; + if (!other.getBrokerServerIp().isEmpty()) { + brokerServerIp_ = other.brokerServerIp_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (other.getBrokerServerPort() != 0) { + setBrokerServerPort(other.getBrokerServerPort()); + } + if (!other.getBrokerServerToken().isEmpty()) { + brokerServerToken_ = other.brokerServerToken_; + bitField0_ |= 0x00000004; + onChanged(); + } + if (!other.getProxyName().isEmpty()) { + proxyName_ = other.proxyName_; + bitField0_ |= 0x00000008; + onChanged(); + } + if (!other.getProxyPassword().isEmpty()) { + proxyPassword_ = other.proxyPassword_; + bitField0_ |= 0x00000010; + onChanged(); + } + if (!other.getSocksProxyUsername().isEmpty()) { + socksProxyUsername_ = other.socksProxyUsername_; + bitField0_ |= 0x00000020; + onChanged(); + } + if (!other.getSocksProxyPassword().isEmpty()) { + socksProxyPassword_ = other.socksProxyPassword_; + bitField0_ |= 0x00000040; + onChanged(); + } + if (other.getSubnet() != 0) { + setSubnet(other.getSubnet()); + } + if (other.getVisitorPort() != 0) { + setVisitorPort(other.getVisitorPort()); + } + if (!other.getTenantName().isEmpty()) { + tenantName_ = other.tenantName_; + bitField0_ |= 0x00000200; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + brokerServerIp_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 16: { + brokerServerPort_ = input.readInt32(); + bitField0_ |= 0x00000002; + break; + } // case 16 + case 26: { + brokerServerToken_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000004; + break; + } // case 26 + case 34: { + proxyName_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000008; + break; + } // case 34 + case 42: { + proxyPassword_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000010; + break; + } // case 42 + case 50: { + socksProxyUsername_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000020; + break; + } // case 50 + case 58: { + socksProxyPassword_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000040; + break; + } // case 58 + case 64: { + subnet_ = input.readInt32(); + bitField0_ |= 0x00000080; + break; + } // case 64 + case 72: { + visitorPort_ = input.readInt32(); + bitField0_ |= 0x00000100; + break; + } // case 72 + case 82: { + tenantName_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000200; + break; + } // case 82 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object brokerServerIp_ = ""; + /** + * string broker_server_ip = 1; + * @return The brokerServerIp. + */ + public java.lang.String getBrokerServerIp() { + java.lang.Object ref = brokerServerIp_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + brokerServerIp_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string broker_server_ip = 1; + * @return The bytes for brokerServerIp. + */ + public com.google.protobuf.ByteString + getBrokerServerIpBytes() { + java.lang.Object ref = brokerServerIp_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + brokerServerIp_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string broker_server_ip = 1; + * @param value The brokerServerIp to set. + * @return This builder for chaining. + */ + public Builder setBrokerServerIp( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + brokerServerIp_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string broker_server_ip = 1; + * @return This builder for chaining. + */ + public Builder clearBrokerServerIp() { + brokerServerIp_ = getDefaultInstance().getBrokerServerIp(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string broker_server_ip = 1; + * @param value The bytes for brokerServerIp to set. + * @return This builder for chaining. + */ + public Builder setBrokerServerIpBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + brokerServerIp_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private int brokerServerPort_ ; + /** + * int32 broker_server_port = 2; + * @return The brokerServerPort. + */ + @java.lang.Override + public int getBrokerServerPort() { + return brokerServerPort_; + } + /** + * int32 broker_server_port = 2; + * @param value The brokerServerPort to set. + * @return This builder for chaining. + */ + public Builder setBrokerServerPort(int value) { + + brokerServerPort_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * int32 broker_server_port = 2; + * @return This builder for chaining. + */ + public Builder clearBrokerServerPort() { + bitField0_ = (bitField0_ & ~0x00000002); + brokerServerPort_ = 0; + onChanged(); + return this; + } + + private java.lang.Object brokerServerToken_ = ""; + /** + * string broker_server_token = 3; + * @return The brokerServerToken. + */ + public java.lang.String getBrokerServerToken() { + java.lang.Object ref = brokerServerToken_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + brokerServerToken_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string broker_server_token = 3; + * @return The bytes for brokerServerToken. + */ + public com.google.protobuf.ByteString + getBrokerServerTokenBytes() { + java.lang.Object ref = brokerServerToken_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + brokerServerToken_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string broker_server_token = 3; + * @param value The brokerServerToken to set. + * @return This builder for chaining. + */ + public Builder setBrokerServerToken( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + brokerServerToken_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + /** + * string broker_server_token = 3; + * @return This builder for chaining. + */ + public Builder clearBrokerServerToken() { + brokerServerToken_ = getDefaultInstance().getBrokerServerToken(); + bitField0_ = (bitField0_ & ~0x00000004); + onChanged(); + return this; + } + /** + * string broker_server_token = 3; + * @param value The bytes for brokerServerToken to set. + * @return This builder for chaining. + */ + public Builder setBrokerServerTokenBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + brokerServerToken_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + + private java.lang.Object proxyName_ = ""; + /** + * string proxy_name = 4; + * @return The proxyName. + */ + public java.lang.String getProxyName() { + java.lang.Object ref = proxyName_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + proxyName_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string proxy_name = 4; + * @return The bytes for proxyName. + */ + public com.google.protobuf.ByteString + getProxyNameBytes() { + java.lang.Object ref = proxyName_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + proxyName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string proxy_name = 4; + * @param value The proxyName to set. + * @return This builder for chaining. + */ + public Builder setProxyName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + proxyName_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + /** + * string proxy_name = 4; + * @return This builder for chaining. + */ + public Builder clearProxyName() { + proxyName_ = getDefaultInstance().getProxyName(); + bitField0_ = (bitField0_ & ~0x00000008); + onChanged(); + return this; + } + /** + * string proxy_name = 4; + * @param value The bytes for proxyName to set. + * @return This builder for chaining. + */ + public Builder setProxyNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + proxyName_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + + private java.lang.Object proxyPassword_ = ""; + /** + * string proxy_password = 5; + * @return The proxyPassword. + */ + public java.lang.String getProxyPassword() { + java.lang.Object ref = proxyPassword_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + proxyPassword_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string proxy_password = 5; + * @return The bytes for proxyPassword. + */ + public com.google.protobuf.ByteString + getProxyPasswordBytes() { + java.lang.Object ref = proxyPassword_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + proxyPassword_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string proxy_password = 5; + * @param value The proxyPassword to set. + * @return This builder for chaining. + */ + public Builder setProxyPassword( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + proxyPassword_ = value; + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + /** + * string proxy_password = 5; + * @return This builder for chaining. + */ + public Builder clearProxyPassword() { + proxyPassword_ = getDefaultInstance().getProxyPassword(); + bitField0_ = (bitField0_ & ~0x00000010); + onChanged(); + return this; + } + /** + * string proxy_password = 5; + * @param value The bytes for proxyPassword to set. + * @return This builder for chaining. + */ + public Builder setProxyPasswordBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + proxyPassword_ = value; + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + + private java.lang.Object socksProxyUsername_ = ""; + /** + * string socks_proxy_username = 6; + * @return The socksProxyUsername. + */ + public java.lang.String getSocksProxyUsername() { + java.lang.Object ref = socksProxyUsername_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + socksProxyUsername_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string socks_proxy_username = 6; + * @return The bytes for socksProxyUsername. + */ + public com.google.protobuf.ByteString + getSocksProxyUsernameBytes() { + java.lang.Object ref = socksProxyUsername_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + socksProxyUsername_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string socks_proxy_username = 6; + * @param value The socksProxyUsername to set. + * @return This builder for chaining. + */ + public Builder setSocksProxyUsername( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + socksProxyUsername_ = value; + bitField0_ |= 0x00000020; + onChanged(); + return this; + } + /** + * string socks_proxy_username = 6; + * @return This builder for chaining. + */ + public Builder clearSocksProxyUsername() { + socksProxyUsername_ = getDefaultInstance().getSocksProxyUsername(); + bitField0_ = (bitField0_ & ~0x00000020); + onChanged(); + return this; + } + /** + * string socks_proxy_username = 6; + * @param value The bytes for socksProxyUsername to set. + * @return This builder for chaining. + */ + public Builder setSocksProxyUsernameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + socksProxyUsername_ = value; + bitField0_ |= 0x00000020; + onChanged(); + return this; + } + + private java.lang.Object socksProxyPassword_ = ""; + /** + * string socks_proxy_password = 7; + * @return The socksProxyPassword. + */ + public java.lang.String getSocksProxyPassword() { + java.lang.Object ref = socksProxyPassword_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + socksProxyPassword_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string socks_proxy_password = 7; + * @return The bytes for socksProxyPassword. + */ + public com.google.protobuf.ByteString + getSocksProxyPasswordBytes() { + java.lang.Object ref = socksProxyPassword_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + socksProxyPassword_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string socks_proxy_password = 7; + * @param value The socksProxyPassword to set. + * @return This builder for chaining. + */ + public Builder setSocksProxyPassword( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + socksProxyPassword_ = value; + bitField0_ |= 0x00000040; + onChanged(); + return this; + } + /** + * string socks_proxy_password = 7; + * @return This builder for chaining. + */ + public Builder clearSocksProxyPassword() { + socksProxyPassword_ = getDefaultInstance().getSocksProxyPassword(); + bitField0_ = (bitField0_ & ~0x00000040); + onChanged(); + return this; + } + /** + * string socks_proxy_password = 7; + * @param value The bytes for socksProxyPassword to set. + * @return This builder for chaining. + */ + public Builder setSocksProxyPasswordBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + socksProxyPassword_ = value; + bitField0_ |= 0x00000040; + onChanged(); + return this; + } + + private int subnet_ ; + /** + * int32 subnet = 8; + * @return The subnet. + */ + @java.lang.Override + public int getSubnet() { + return subnet_; + } + /** + * int32 subnet = 8; + * @param value The subnet to set. + * @return This builder for chaining. + */ + public Builder setSubnet(int value) { + + subnet_ = value; + bitField0_ |= 0x00000080; + onChanged(); + return this; + } + /** + * int32 subnet = 8; + * @return This builder for chaining. + */ + public Builder clearSubnet() { + bitField0_ = (bitField0_ & ~0x00000080); + subnet_ = 0; + onChanged(); + return this; + } + + private int visitorPort_ ; + /** + * int32 VisitorPort = 9; + * @return The visitorPort. + */ + @java.lang.Override + public int getVisitorPort() { + return visitorPort_; + } + /** + * int32 VisitorPort = 9; + * @param value The visitorPort to set. + * @return This builder for chaining. + */ + public Builder setVisitorPort(int value) { + + visitorPort_ = value; + bitField0_ |= 0x00000100; + onChanged(); + return this; + } + /** + * int32 VisitorPort = 9; + * @return This builder for chaining. + */ + public Builder clearVisitorPort() { + bitField0_ = (bitField0_ & ~0x00000100); + visitorPort_ = 0; + onChanged(); + return this; + } + + private java.lang.Object tenantName_ = ""; + /** + * string tenant_name = 10; + * @return The tenantName. + */ + public java.lang.String getTenantName() { + java.lang.Object ref = tenantName_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenantName_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant_name = 10; + * @return The bytes for tenantName. + */ + public com.google.protobuf.ByteString + getTenantNameBytes() { + java.lang.Object ref = tenantName_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenantName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant_name = 10; + * @param value The tenantName to set. + * @return This builder for chaining. + */ + public Builder setTenantName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenantName_ = value; + bitField0_ |= 0x00000200; + onChanged(); + return this; + } + /** + * string tenant_name = 10; + * @return This builder for chaining. + */ + public Builder clearTenantName() { + tenantName_ = getDefaultInstance().getTenantName(); + bitField0_ = (bitField0_ & ~0x00000200); + onChanged(); + return this; + } + /** + * string tenant_name = 10; + * @param value The bytes for tenantName to set. + * @return This builder for chaining. + */ + public Builder setTenantNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenantName_ = value; + bitField0_ |= 0x00000200; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.BrokerProxyDetails) + } + + // @@protoc_insertion_point(class_scope:grpc.BrokerProxyDetails) + private static final io.trino.spi.grpc.Endpoints.BrokerProxyDetails DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.BrokerProxyDetails(); + } + + public static io.trino.spi.grpc.Endpoints.BrokerProxyDetails getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public BrokerProxyDetails parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BrokerProxyDetails getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface BrokerClientDetailsOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.BrokerClientDetails) + com.google.protobuf.MessageOrBuilder { + + /** + * string tenant = 1; + * @return The tenant. + */ + java.lang.String getTenant(); + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + com.google.protobuf.ByteString + getTenantBytes(); + + /** + * string descope_id = 2; + * @return The descopeId. + */ + java.lang.String getDescopeId(); + /** + * string descope_id = 2; + * @return The bytes for descopeId. + */ + com.google.protobuf.ByteString + getDescopeIdBytes(); + + /** + * string client_ip = 3; + * @return The clientIp. + */ + java.lang.String getClientIp(); + /** + * string client_ip = 3; + * @return The bytes for clientIp. + */ + com.google.protobuf.ByteString + getClientIpBytes(); + } + /** + * Protobuf type {@code grpc.BrokerClientDetails} + */ + public static final class BrokerClientDetails extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.BrokerClientDetails) + BrokerClientDetailsOrBuilder { + private static final long serialVersionUID = 0L; + // Use BrokerClientDetails.newBuilder() to construct. + private BrokerClientDetails(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private BrokerClientDetails() { + tenant_ = ""; + descopeId_ = ""; + clientIp_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new BrokerClientDetails(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BrokerClientDetails_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BrokerClientDetails_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.BrokerClientDetails.class, io.trino.spi.grpc.Endpoints.BrokerClientDetails.Builder.class); + } + + public static final int TENANT_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + @java.lang.Override + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int DESCOPE_ID_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object descopeId_ = ""; + /** + * string descope_id = 2; + * @return The descopeId. + */ + @java.lang.Override + public java.lang.String getDescopeId() { + java.lang.Object ref = descopeId_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + descopeId_ = s; + return s; + } + } + /** + * string descope_id = 2; + * @return The bytes for descopeId. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getDescopeIdBytes() { + java.lang.Object ref = descopeId_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + descopeId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int CLIENT_IP_FIELD_NUMBER = 3; + @SuppressWarnings("serial") + private volatile java.lang.Object clientIp_ = ""; + /** + * string client_ip = 3; + * @return The clientIp. + */ + @java.lang.Override + public java.lang.String getClientIp() { + java.lang.Object ref = clientIp_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + clientIp_ = s; + return s; + } + } + /** + * string client_ip = 3; + * @return The bytes for clientIp. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getClientIpBytes() { + java.lang.Object ref = clientIp_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + clientIp_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(descopeId_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, descopeId_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(clientIp_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 3, clientIp_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(descopeId_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, descopeId_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(clientIp_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(3, clientIp_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.BrokerClientDetails)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.BrokerClientDetails other = (io.trino.spi.grpc.Endpoints.BrokerClientDetails) obj; + + if (!getTenant() + .equals(other.getTenant())) return false; + if (!getDescopeId() + .equals(other.getDescopeId())) return false; + if (!getClientIp() + .equals(other.getClientIp())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + TENANT_FIELD_NUMBER; + hash = (53 * hash) + getTenant().hashCode(); + hash = (37 * hash) + DESCOPE_ID_FIELD_NUMBER; + hash = (53 * hash) + getDescopeId().hashCode(); + hash = (37 * hash) + CLIENT_IP_FIELD_NUMBER; + hash = (53 * hash) + getClientIp().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.BrokerClientDetails parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.BrokerClientDetails parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.BrokerClientDetails parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.BrokerClientDetails parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.BrokerClientDetails parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.BrokerClientDetails parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.BrokerClientDetails parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.BrokerClientDetails parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.BrokerClientDetails parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.BrokerClientDetails parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.BrokerClientDetails parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.BrokerClientDetails parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.BrokerClientDetails prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.BrokerClientDetails} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.BrokerClientDetails) + io.trino.spi.grpc.Endpoints.BrokerClientDetailsOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BrokerClientDetails_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BrokerClientDetails_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.BrokerClientDetails.class, io.trino.spi.grpc.Endpoints.BrokerClientDetails.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.BrokerClientDetails.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + tenant_ = ""; + descopeId_ = ""; + clientIp_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BrokerClientDetails_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BrokerClientDetails getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.BrokerClientDetails.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BrokerClientDetails build() { + io.trino.spi.grpc.Endpoints.BrokerClientDetails result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BrokerClientDetails buildPartial() { + io.trino.spi.grpc.Endpoints.BrokerClientDetails result = new io.trino.spi.grpc.Endpoints.BrokerClientDetails(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.BrokerClientDetails result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.tenant_ = tenant_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.descopeId_ = descopeId_; + } + if (((from_bitField0_ & 0x00000004) != 0)) { + result.clientIp_ = clientIp_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.BrokerClientDetails) { + return mergeFrom((io.trino.spi.grpc.Endpoints.BrokerClientDetails)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.BrokerClientDetails other) { + if (other == io.trino.spi.grpc.Endpoints.BrokerClientDetails.getDefaultInstance()) return this; + if (!other.getTenant().isEmpty()) { + tenant_ = other.tenant_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getDescopeId().isEmpty()) { + descopeId_ = other.descopeId_; + bitField0_ |= 0x00000002; + onChanged(); + } + if (!other.getClientIp().isEmpty()) { + clientIp_ = other.clientIp_; + bitField0_ |= 0x00000004; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + tenant_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + descopeId_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + case 26: { + clientIp_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000004; + break; + } // case 26 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant = 1; + * @param value The tenant to set. + * @return This builder for chaining. + */ + public Builder setTenant( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string tenant = 1; + * @return This builder for chaining. + */ + public Builder clearTenant() { + tenant_ = getDefaultInstance().getTenant(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string tenant = 1; + * @param value The bytes for tenant to set. + * @return This builder for chaining. + */ + public Builder setTenantBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object descopeId_ = ""; + /** + * string descope_id = 2; + * @return The descopeId. + */ + public java.lang.String getDescopeId() { + java.lang.Object ref = descopeId_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + descopeId_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string descope_id = 2; + * @return The bytes for descopeId. + */ + public com.google.protobuf.ByteString + getDescopeIdBytes() { + java.lang.Object ref = descopeId_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + descopeId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string descope_id = 2; + * @param value The descopeId to set. + * @return This builder for chaining. + */ + public Builder setDescopeId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + descopeId_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string descope_id = 2; + * @return This builder for chaining. + */ + public Builder clearDescopeId() { + descopeId_ = getDefaultInstance().getDescopeId(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string descope_id = 2; + * @param value The bytes for descopeId to set. + * @return This builder for chaining. + */ + public Builder setDescopeIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + descopeId_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + + private java.lang.Object clientIp_ = ""; + /** + * string client_ip = 3; + * @return The clientIp. + */ + public java.lang.String getClientIp() { + java.lang.Object ref = clientIp_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + clientIp_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string client_ip = 3; + * @return The bytes for clientIp. + */ + public com.google.protobuf.ByteString + getClientIpBytes() { + java.lang.Object ref = clientIp_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + clientIp_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string client_ip = 3; + * @param value The clientIp to set. + * @return This builder for chaining. + */ + public Builder setClientIp( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + clientIp_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + /** + * string client_ip = 3; + * @return This builder for chaining. + */ + public Builder clearClientIp() { + clientIp_ = getDefaultInstance().getClientIp(); + bitField0_ = (bitField0_ & ~0x00000004); + onChanged(); + return this; + } + /** + * string client_ip = 3; + * @param value The bytes for clientIp to set. + * @return This builder for chaining. + */ + public Builder setClientIpBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + clientIp_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.BrokerClientDetails) + } + + // @@protoc_insertion_point(class_scope:grpc.BrokerClientDetails) + private static final io.trino.spi.grpc.Endpoints.BrokerClientDetails DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.BrokerClientDetails(); + } + + public static io.trino.spi.grpc.Endpoints.BrokerClientDetails getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public BrokerClientDetails parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BrokerClientDetails getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface TrinoConnectorInstanceOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.TrinoConnectorInstance) + com.google.protobuf.MessageOrBuilder { + + /** + * string id = 1; + * @return The id. + */ + java.lang.String getId(); + /** + * string id = 1; + * @return The bytes for id. + */ + com.google.protobuf.ByteString + getIdBytes(); + + /** + * string name = 2; + * @return The name. + */ + java.lang.String getName(); + /** + * string name = 2; + * @return The bytes for name. + */ + com.google.protobuf.ByteString + getNameBytes(); + + /** + * string vega_connector_name = 3; + * @return The vegaConnectorName. + */ + java.lang.String getVegaConnectorName(); + /** + * string vega_connector_name = 3; + * @return The bytes for vegaConnectorName. + */ + com.google.protobuf.ByteString + getVegaConnectorNameBytes(); + + /** + * string trino_connector_name = 4; + * @return The trinoConnectorName. + */ + java.lang.String getTrinoConnectorName(); + /** + * string trino_connector_name = 4; + * @return The bytes for trinoConnectorName. + */ + com.google.protobuf.ByteString + getTrinoConnectorNameBytes(); + + /** + * map<string, string> params = 5; + */ + int getParamsCount(); + /** + * map<string, string> params = 5; + */ + boolean containsParams( + java.lang.String key); + /** + * Use {@link #getParamsMap()} instead. + */ + @java.lang.Deprecated + java.util.Map + getParams(); + /** + * map<string, string> params = 5; + */ + java.util.Map + getParamsMap(); + /** + * map<string, string> params = 5; + */ + /* nullable */ +java.lang.String getParamsOrDefault( + java.lang.String key, + /* nullable */ +java.lang.String defaultValue); + /** + * map<string, string> params = 5; + */ + java.lang.String getParamsOrThrow( + java.lang.String key); + + /** + * repeated .grpc.DataSourceInstance data_sources = 6; + */ + java.util.List + getDataSourcesList(); + /** + * repeated .grpc.DataSourceInstance data_sources = 6; + */ + io.trino.spi.grpc.Endpoints.DataSourceInstance getDataSources(int index); + /** + * repeated .grpc.DataSourceInstance data_sources = 6; + */ + int getDataSourcesCount(); + /** + * repeated .grpc.DataSourceInstance data_sources = 6; + */ + java.util.List + getDataSourcesOrBuilderList(); + /** + * repeated .grpc.DataSourceInstance data_sources = 6; + */ + io.trino.spi.grpc.Endpoints.DataSourceInstanceOrBuilder getDataSourcesOrBuilder( + int index); + + /** + * bool is_test = 7; + * @return The isTest. + */ + boolean getIsTest(); + + /** + * string tenant_name = 8; + * @return The tenantName. + */ + java.lang.String getTenantName(); + /** + * string tenant_name = 8; + * @return The bytes for tenantName. + */ + com.google.protobuf.ByteString + getTenantNameBytes(); + } + /** + * Protobuf type {@code grpc.TrinoConnectorInstance} + */ + public static final class TrinoConnectorInstance extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.TrinoConnectorInstance) + TrinoConnectorInstanceOrBuilder { + private static final long serialVersionUID = 0L; + // Use TrinoConnectorInstance.newBuilder() to construct. + private TrinoConnectorInstance(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private TrinoConnectorInstance() { + id_ = ""; + name_ = ""; + vegaConnectorName_ = ""; + trinoConnectorName_ = ""; + dataSources_ = java.util.Collections.emptyList(); + tenantName_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new TrinoConnectorInstance(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_TrinoConnectorInstance_descriptor; + } + + @SuppressWarnings({"rawtypes"}) + @java.lang.Override + protected com.google.protobuf.MapField internalGetMapField( + int number) { + switch (number) { + case 5: + return internalGetParams(); + default: + throw new RuntimeException( + "Invalid map field number: " + number); + } + } + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_TrinoConnectorInstance_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.TrinoConnectorInstance.class, io.trino.spi.grpc.Endpoints.TrinoConnectorInstance.Builder.class); + } + + public static final int ID_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object id_ = ""; + /** + * string id = 1; + * @return The id. + */ + @java.lang.Override + public java.lang.String getId() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } + } + /** + * string id = 1; + * @return The bytes for id. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int NAME_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object name_ = ""; + /** + * string name = 2; + * @return The name. + */ + @java.lang.Override + public java.lang.String getName() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } + } + /** + * string name = 2; + * @return The bytes for name. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int VEGA_CONNECTOR_NAME_FIELD_NUMBER = 3; + @SuppressWarnings("serial") + private volatile java.lang.Object vegaConnectorName_ = ""; + /** + * string vega_connector_name = 3; + * @return The vegaConnectorName. + */ + @java.lang.Override + public java.lang.String getVegaConnectorName() { + java.lang.Object ref = vegaConnectorName_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + vegaConnectorName_ = s; + return s; + } + } + /** + * string vega_connector_name = 3; + * @return The bytes for vegaConnectorName. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getVegaConnectorNameBytes() { + java.lang.Object ref = vegaConnectorName_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + vegaConnectorName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int TRINO_CONNECTOR_NAME_FIELD_NUMBER = 4; + @SuppressWarnings("serial") + private volatile java.lang.Object trinoConnectorName_ = ""; + /** + * string trino_connector_name = 4; + * @return The trinoConnectorName. + */ + @java.lang.Override + public java.lang.String getTrinoConnectorName() { + java.lang.Object ref = trinoConnectorName_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + trinoConnectorName_ = s; + return s; + } + } + /** + * string trino_connector_name = 4; + * @return The bytes for trinoConnectorName. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTrinoConnectorNameBytes() { + java.lang.Object ref = trinoConnectorName_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + trinoConnectorName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int PARAMS_FIELD_NUMBER = 5; + private static final class ParamsDefaultEntryHolder { + static final com.google.protobuf.MapEntry< + java.lang.String, java.lang.String> defaultEntry = + com.google.protobuf.MapEntry + .newDefaultInstance( + io.trino.spi.grpc.Endpoints.internal_static_grpc_TrinoConnectorInstance_ParamsEntry_descriptor, + com.google.protobuf.WireFormat.FieldType.STRING, + "", + com.google.protobuf.WireFormat.FieldType.STRING, + ""); + } + @SuppressWarnings("serial") + private com.google.protobuf.MapField< + java.lang.String, java.lang.String> params_; + private com.google.protobuf.MapField + internalGetParams() { + if (params_ == null) { + return com.google.protobuf.MapField.emptyMapField( + ParamsDefaultEntryHolder.defaultEntry); + } + return params_; + } + public int getParamsCount() { + return internalGetParams().getMap().size(); + } + /** + * map<string, string> params = 5; + */ + @java.lang.Override + public boolean containsParams( + java.lang.String key) { + if (key == null) { throw new NullPointerException("map key"); } + return internalGetParams().getMap().containsKey(key); + } + /** + * Use {@link #getParamsMap()} instead. + */ + @java.lang.Override + @java.lang.Deprecated + public java.util.Map getParams() { + return getParamsMap(); + } + /** + * map<string, string> params = 5; + */ + @java.lang.Override + public java.util.Map getParamsMap() { + return internalGetParams().getMap(); + } + /** + * map<string, string> params = 5; + */ + @java.lang.Override + public /* nullable */ +java.lang.String getParamsOrDefault( + java.lang.String key, + /* nullable */ +java.lang.String defaultValue) { + if (key == null) { throw new NullPointerException("map key"); } + java.util.Map map = + internalGetParams().getMap(); + return map.containsKey(key) ? map.get(key) : defaultValue; + } + /** + * map<string, string> params = 5; + */ + @java.lang.Override + public java.lang.String getParamsOrThrow( + java.lang.String key) { + if (key == null) { throw new NullPointerException("map key"); } + java.util.Map map = + internalGetParams().getMap(); + if (!map.containsKey(key)) { + throw new java.lang.IllegalArgumentException(); + } + return map.get(key); + } + + public static final int DATA_SOURCES_FIELD_NUMBER = 6; + @SuppressWarnings("serial") + private java.util.List dataSources_; + /** + * repeated .grpc.DataSourceInstance data_sources = 6; + */ + @java.lang.Override + public java.util.List getDataSourcesList() { + return dataSources_; + } + /** + * repeated .grpc.DataSourceInstance data_sources = 6; + */ + @java.lang.Override + public java.util.List + getDataSourcesOrBuilderList() { + return dataSources_; + } + /** + * repeated .grpc.DataSourceInstance data_sources = 6; + */ + @java.lang.Override + public int getDataSourcesCount() { + return dataSources_.size(); + } + /** + * repeated .grpc.DataSourceInstance data_sources = 6; + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceInstance getDataSources(int index) { + return dataSources_.get(index); + } + /** + * repeated .grpc.DataSourceInstance data_sources = 6; + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceInstanceOrBuilder getDataSourcesOrBuilder( + int index) { + return dataSources_.get(index); + } + + public static final int IS_TEST_FIELD_NUMBER = 7; + private boolean isTest_ = false; + /** + * bool is_test = 7; + * @return The isTest. + */ + @java.lang.Override + public boolean getIsTest() { + return isTest_; + } + + public static final int TENANT_NAME_FIELD_NUMBER = 8; + @SuppressWarnings("serial") + private volatile java.lang.Object tenantName_ = ""; + /** + * string tenant_name = 8; + * @return The tenantName. + */ + @java.lang.Override + public java.lang.String getTenantName() { + java.lang.Object ref = tenantName_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenantName_ = s; + return s; + } + } + /** + * string tenant_name = 8; + * @return The bytes for tenantName. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantNameBytes() { + java.lang.Object ref = tenantName_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenantName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, id_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(name_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, name_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(vegaConnectorName_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 3, vegaConnectorName_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(trinoConnectorName_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 4, trinoConnectorName_); + } + com.google.protobuf.GeneratedMessageV3 + .serializeStringMapTo( + output, + internalGetParams(), + ParamsDefaultEntryHolder.defaultEntry, + 5); + for (int i = 0; i < dataSources_.size(); i++) { + output.writeMessage(6, dataSources_.get(i)); + } + if (isTest_ != false) { + output.writeBool(7, isTest_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenantName_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 8, tenantName_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, id_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(name_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, name_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(vegaConnectorName_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(3, vegaConnectorName_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(trinoConnectorName_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(4, trinoConnectorName_); + } + for (java.util.Map.Entry entry + : internalGetParams().getMap().entrySet()) { + com.google.protobuf.MapEntry + params__ = ParamsDefaultEntryHolder.defaultEntry.newBuilderForType() + .setKey(entry.getKey()) + .setValue(entry.getValue()) + .build(); + size += com.google.protobuf.CodedOutputStream + .computeMessageSize(5, params__); + } + for (int i = 0; i < dataSources_.size(); i++) { + size += com.google.protobuf.CodedOutputStream + .computeMessageSize(6, dataSources_.get(i)); + } + if (isTest_ != false) { + size += com.google.protobuf.CodedOutputStream + .computeBoolSize(7, isTest_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenantName_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(8, tenantName_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.TrinoConnectorInstance)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.TrinoConnectorInstance other = (io.trino.spi.grpc.Endpoints.TrinoConnectorInstance) obj; + + if (!getId() + .equals(other.getId())) return false; + if (!getName() + .equals(other.getName())) return false; + if (!getVegaConnectorName() + .equals(other.getVegaConnectorName())) return false; + if (!getTrinoConnectorName() + .equals(other.getTrinoConnectorName())) return false; + if (!internalGetParams().equals( + other.internalGetParams())) return false; + if (!getDataSourcesList() + .equals(other.getDataSourcesList())) return false; + if (getIsTest() + != other.getIsTest()) return false; + if (!getTenantName() + .equals(other.getTenantName())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + ID_FIELD_NUMBER; + hash = (53 * hash) + getId().hashCode(); + hash = (37 * hash) + NAME_FIELD_NUMBER; + hash = (53 * hash) + getName().hashCode(); + hash = (37 * hash) + VEGA_CONNECTOR_NAME_FIELD_NUMBER; + hash = (53 * hash) + getVegaConnectorName().hashCode(); + hash = (37 * hash) + TRINO_CONNECTOR_NAME_FIELD_NUMBER; + hash = (53 * hash) + getTrinoConnectorName().hashCode(); + if (!internalGetParams().getMap().isEmpty()) { + hash = (37 * hash) + PARAMS_FIELD_NUMBER; + hash = (53 * hash) + internalGetParams().hashCode(); + } + if (getDataSourcesCount() > 0) { + hash = (37 * hash) + DATA_SOURCES_FIELD_NUMBER; + hash = (53 * hash) + getDataSourcesList().hashCode(); + } + hash = (37 * hash) + IS_TEST_FIELD_NUMBER; + hash = (53 * hash) + com.google.protobuf.Internal.hashBoolean( + getIsTest()); + hash = (37 * hash) + TENANT_NAME_FIELD_NUMBER; + hash = (53 * hash) + getTenantName().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.TrinoConnectorInstance parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.TrinoConnectorInstance parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.TrinoConnectorInstance parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.TrinoConnectorInstance parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.TrinoConnectorInstance parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.TrinoConnectorInstance parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.TrinoConnectorInstance parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.TrinoConnectorInstance parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.TrinoConnectorInstance parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.TrinoConnectorInstance parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.TrinoConnectorInstance parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.TrinoConnectorInstance parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.TrinoConnectorInstance prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.TrinoConnectorInstance} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.TrinoConnectorInstance) + io.trino.spi.grpc.Endpoints.TrinoConnectorInstanceOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_TrinoConnectorInstance_descriptor; + } + + @SuppressWarnings({"rawtypes"}) + protected com.google.protobuf.MapField internalGetMapField( + int number) { + switch (number) { + case 5: + return internalGetParams(); + default: + throw new RuntimeException( + "Invalid map field number: " + number); + } + } + @SuppressWarnings({"rawtypes"}) + protected com.google.protobuf.MapField internalGetMutableMapField( + int number) { + switch (number) { + case 5: + return internalGetMutableParams(); + default: + throw new RuntimeException( + "Invalid map field number: " + number); + } + } + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_TrinoConnectorInstance_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.TrinoConnectorInstance.class, io.trino.spi.grpc.Endpoints.TrinoConnectorInstance.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.TrinoConnectorInstance.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + id_ = ""; + name_ = ""; + vegaConnectorName_ = ""; + trinoConnectorName_ = ""; + internalGetMutableParams().clear(); + if (dataSourcesBuilder_ == null) { + dataSources_ = java.util.Collections.emptyList(); + } else { + dataSources_ = null; + dataSourcesBuilder_.clear(); + } + bitField0_ = (bitField0_ & ~0x00000020); + isTest_ = false; + tenantName_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_TrinoConnectorInstance_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.TrinoConnectorInstance getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.TrinoConnectorInstance.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.TrinoConnectorInstance build() { + io.trino.spi.grpc.Endpoints.TrinoConnectorInstance result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.TrinoConnectorInstance buildPartial() { + io.trino.spi.grpc.Endpoints.TrinoConnectorInstance result = new io.trino.spi.grpc.Endpoints.TrinoConnectorInstance(this); + buildPartialRepeatedFields(result); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartialRepeatedFields(io.trino.spi.grpc.Endpoints.TrinoConnectorInstance result) { + if (dataSourcesBuilder_ == null) { + if (((bitField0_ & 0x00000020) != 0)) { + dataSources_ = java.util.Collections.unmodifiableList(dataSources_); + bitField0_ = (bitField0_ & ~0x00000020); + } + result.dataSources_ = dataSources_; + } else { + result.dataSources_ = dataSourcesBuilder_.build(); + } + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.TrinoConnectorInstance result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.id_ = id_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.name_ = name_; + } + if (((from_bitField0_ & 0x00000004) != 0)) { + result.vegaConnectorName_ = vegaConnectorName_; + } + if (((from_bitField0_ & 0x00000008) != 0)) { + result.trinoConnectorName_ = trinoConnectorName_; + } + if (((from_bitField0_ & 0x00000010) != 0)) { + result.params_ = internalGetParams(); + result.params_.makeImmutable(); + } + if (((from_bitField0_ & 0x00000040) != 0)) { + result.isTest_ = isTest_; + } + if (((from_bitField0_ & 0x00000080) != 0)) { + result.tenantName_ = tenantName_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.TrinoConnectorInstance) { + return mergeFrom((io.trino.spi.grpc.Endpoints.TrinoConnectorInstance)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.TrinoConnectorInstance other) { + if (other == io.trino.spi.grpc.Endpoints.TrinoConnectorInstance.getDefaultInstance()) return this; + if (!other.getId().isEmpty()) { + id_ = other.id_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getName().isEmpty()) { + name_ = other.name_; + bitField0_ |= 0x00000002; + onChanged(); + } + if (!other.getVegaConnectorName().isEmpty()) { + vegaConnectorName_ = other.vegaConnectorName_; + bitField0_ |= 0x00000004; + onChanged(); + } + if (!other.getTrinoConnectorName().isEmpty()) { + trinoConnectorName_ = other.trinoConnectorName_; + bitField0_ |= 0x00000008; + onChanged(); + } + internalGetMutableParams().mergeFrom( + other.internalGetParams()); + bitField0_ |= 0x00000010; + if (dataSourcesBuilder_ == null) { + if (!other.dataSources_.isEmpty()) { + if (dataSources_.isEmpty()) { + dataSources_ = other.dataSources_; + bitField0_ = (bitField0_ & ~0x00000020); + } else { + ensureDataSourcesIsMutable(); + dataSources_.addAll(other.dataSources_); + } + onChanged(); + } + } else { + if (!other.dataSources_.isEmpty()) { + if (dataSourcesBuilder_.isEmpty()) { + dataSourcesBuilder_.dispose(); + dataSourcesBuilder_ = null; + dataSources_ = other.dataSources_; + bitField0_ = (bitField0_ & ~0x00000020); + dataSourcesBuilder_ = + com.google.protobuf.GeneratedMessageV3.alwaysUseFieldBuilders ? + getDataSourcesFieldBuilder() : null; + } else { + dataSourcesBuilder_.addAllMessages(other.dataSources_); + } + } + } + if (other.getIsTest() != false) { + setIsTest(other.getIsTest()); + } + if (!other.getTenantName().isEmpty()) { + tenantName_ = other.tenantName_; + bitField0_ |= 0x00000080; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + id_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + name_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + case 26: { + vegaConnectorName_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000004; + break; + } // case 26 + case 34: { + trinoConnectorName_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000008; + break; + } // case 34 + case 42: { + com.google.protobuf.MapEntry + params__ = input.readMessage( + ParamsDefaultEntryHolder.defaultEntry.getParserForType(), extensionRegistry); + internalGetMutableParams().getMutableMap().put( + params__.getKey(), params__.getValue()); + bitField0_ |= 0x00000010; + break; + } // case 42 + case 50: { + io.trino.spi.grpc.Endpoints.DataSourceInstance m = + input.readMessage( + io.trino.spi.grpc.Endpoints.DataSourceInstance.parser(), + extensionRegistry); + if (dataSourcesBuilder_ == null) { + ensureDataSourcesIsMutable(); + dataSources_.add(m); + } else { + dataSourcesBuilder_.addMessage(m); + } + break; + } // case 50 + case 56: { + isTest_ = input.readBool(); + bitField0_ |= 0x00000040; + break; + } // case 56 + case 66: { + tenantName_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000080; + break; + } // case 66 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object id_ = ""; + /** + * string id = 1; + * @return The id. + */ + public java.lang.String getId() { + java.lang.Object ref = id_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string id = 1; + * @return The bytes for id. + */ + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string id = 1; + * @param value The id to set. + * @return This builder for chaining. + */ + public Builder setId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + id_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string id = 1; + * @return This builder for chaining. + */ + public Builder clearId() { + id_ = getDefaultInstance().getId(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string id = 1; + * @param value The bytes for id to set. + * @return This builder for chaining. + */ + public Builder setIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + id_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object name_ = ""; + /** + * string name = 2; + * @return The name. + */ + public java.lang.String getName() { + java.lang.Object ref = name_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string name = 2; + * @return The bytes for name. + */ + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string name = 2; + * @param value The name to set. + * @return This builder for chaining. + */ + public Builder setName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + name_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string name = 2; + * @return This builder for chaining. + */ + public Builder clearName() { + name_ = getDefaultInstance().getName(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string name = 2; + * @param value The bytes for name to set. + * @return This builder for chaining. + */ + public Builder setNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + name_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + + private java.lang.Object vegaConnectorName_ = ""; + /** + * string vega_connector_name = 3; + * @return The vegaConnectorName. + */ + public java.lang.String getVegaConnectorName() { + java.lang.Object ref = vegaConnectorName_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + vegaConnectorName_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string vega_connector_name = 3; + * @return The bytes for vegaConnectorName. + */ + public com.google.protobuf.ByteString + getVegaConnectorNameBytes() { + java.lang.Object ref = vegaConnectorName_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + vegaConnectorName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string vega_connector_name = 3; + * @param value The vegaConnectorName to set. + * @return This builder for chaining. + */ + public Builder setVegaConnectorName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + vegaConnectorName_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + /** + * string vega_connector_name = 3; + * @return This builder for chaining. + */ + public Builder clearVegaConnectorName() { + vegaConnectorName_ = getDefaultInstance().getVegaConnectorName(); + bitField0_ = (bitField0_ & ~0x00000004); + onChanged(); + return this; + } + /** + * string vega_connector_name = 3; + * @param value The bytes for vegaConnectorName to set. + * @return This builder for chaining. + */ + public Builder setVegaConnectorNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + vegaConnectorName_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + + private java.lang.Object trinoConnectorName_ = ""; + /** + * string trino_connector_name = 4; + * @return The trinoConnectorName. + */ + public java.lang.String getTrinoConnectorName() { + java.lang.Object ref = trinoConnectorName_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + trinoConnectorName_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string trino_connector_name = 4; + * @return The bytes for trinoConnectorName. + */ + public com.google.protobuf.ByteString + getTrinoConnectorNameBytes() { + java.lang.Object ref = trinoConnectorName_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + trinoConnectorName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string trino_connector_name = 4; + * @param value The trinoConnectorName to set. + * @return This builder for chaining. + */ + public Builder setTrinoConnectorName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + trinoConnectorName_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + /** + * string trino_connector_name = 4; + * @return This builder for chaining. + */ + public Builder clearTrinoConnectorName() { + trinoConnectorName_ = getDefaultInstance().getTrinoConnectorName(); + bitField0_ = (bitField0_ & ~0x00000008); + onChanged(); + return this; + } + /** + * string trino_connector_name = 4; + * @param value The bytes for trinoConnectorName to set. + * @return This builder for chaining. + */ + public Builder setTrinoConnectorNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + trinoConnectorName_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + + private com.google.protobuf.MapField< + java.lang.String, java.lang.String> params_; + private com.google.protobuf.MapField + internalGetParams() { + if (params_ == null) { + return com.google.protobuf.MapField.emptyMapField( + ParamsDefaultEntryHolder.defaultEntry); + } + return params_; + } + private com.google.protobuf.MapField + internalGetMutableParams() { + if (params_ == null) { + params_ = com.google.protobuf.MapField.newMapField( + ParamsDefaultEntryHolder.defaultEntry); + } + if (!params_.isMutable()) { + params_ = params_.copy(); + } + bitField0_ |= 0x00000010; + onChanged(); + return params_; + } + public int getParamsCount() { + return internalGetParams().getMap().size(); + } + /** + * map<string, string> params = 5; + */ + @java.lang.Override + public boolean containsParams( + java.lang.String key) { + if (key == null) { throw new NullPointerException("map key"); } + return internalGetParams().getMap().containsKey(key); + } + /** + * Use {@link #getParamsMap()} instead. + */ + @java.lang.Override + @java.lang.Deprecated + public java.util.Map getParams() { + return getParamsMap(); + } + /** + * map<string, string> params = 5; + */ + @java.lang.Override + public java.util.Map getParamsMap() { + return internalGetParams().getMap(); + } + /** + * map<string, string> params = 5; + */ + @java.lang.Override + public /* nullable */ +java.lang.String getParamsOrDefault( + java.lang.String key, + /* nullable */ +java.lang.String defaultValue) { + if (key == null) { throw new NullPointerException("map key"); } + java.util.Map map = + internalGetParams().getMap(); + return map.containsKey(key) ? map.get(key) : defaultValue; + } + /** + * map<string, string> params = 5; + */ + @java.lang.Override + public java.lang.String getParamsOrThrow( + java.lang.String key) { + if (key == null) { throw new NullPointerException("map key"); } + java.util.Map map = + internalGetParams().getMap(); + if (!map.containsKey(key)) { + throw new java.lang.IllegalArgumentException(); + } + return map.get(key); + } + public Builder clearParams() { + bitField0_ = (bitField0_ & ~0x00000010); + internalGetMutableParams().getMutableMap() + .clear(); + return this; + } + /** + * map<string, string> params = 5; + */ + public Builder removeParams( + java.lang.String key) { + if (key == null) { throw new NullPointerException("map key"); } + internalGetMutableParams().getMutableMap() + .remove(key); + return this; + } + /** + * Use alternate mutation accessors instead. + */ + @java.lang.Deprecated + public java.util.Map + getMutableParams() { + bitField0_ |= 0x00000010; + return internalGetMutableParams().getMutableMap(); + } + /** + * map<string, string> params = 5; + */ + public Builder putParams( + java.lang.String key, + java.lang.String value) { + if (key == null) { throw new NullPointerException("map key"); } + if (value == null) { throw new NullPointerException("map value"); } + internalGetMutableParams().getMutableMap() + .put(key, value); + bitField0_ |= 0x00000010; + return this; + } + /** + * map<string, string> params = 5; + */ + public Builder putAllParams( + java.util.Map values) { + internalGetMutableParams().getMutableMap() + .putAll(values); + bitField0_ |= 0x00000010; + return this; + } + + private java.util.List dataSources_ = + java.util.Collections.emptyList(); + private void ensureDataSourcesIsMutable() { + if (!((bitField0_ & 0x00000020) != 0)) { + dataSources_ = new java.util.ArrayList(dataSources_); + bitField0_ |= 0x00000020; + } + } + + private com.google.protobuf.RepeatedFieldBuilderV3< + io.trino.spi.grpc.Endpoints.DataSourceInstance, io.trino.spi.grpc.Endpoints.DataSourceInstance.Builder, io.trino.spi.grpc.Endpoints.DataSourceInstanceOrBuilder> dataSourcesBuilder_; + + /** + * repeated .grpc.DataSourceInstance data_sources = 6; + */ + public java.util.List getDataSourcesList() { + if (dataSourcesBuilder_ == null) { + return java.util.Collections.unmodifiableList(dataSources_); + } else { + return dataSourcesBuilder_.getMessageList(); + } + } + /** + * repeated .grpc.DataSourceInstance data_sources = 6; + */ + public int getDataSourcesCount() { + if (dataSourcesBuilder_ == null) { + return dataSources_.size(); + } else { + return dataSourcesBuilder_.getCount(); + } + } + /** + * repeated .grpc.DataSourceInstance data_sources = 6; + */ + public io.trino.spi.grpc.Endpoints.DataSourceInstance getDataSources(int index) { + if (dataSourcesBuilder_ == null) { + return dataSources_.get(index); + } else { + return dataSourcesBuilder_.getMessage(index); + } + } + /** + * repeated .grpc.DataSourceInstance data_sources = 6; + */ + public Builder setDataSources( + int index, io.trino.spi.grpc.Endpoints.DataSourceInstance value) { + if (dataSourcesBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + ensureDataSourcesIsMutable(); + dataSources_.set(index, value); + onChanged(); + } else { + dataSourcesBuilder_.setMessage(index, value); + } + return this; + } + /** + * repeated .grpc.DataSourceInstance data_sources = 6; + */ + public Builder setDataSources( + int index, io.trino.spi.grpc.Endpoints.DataSourceInstance.Builder builderForValue) { + if (dataSourcesBuilder_ == null) { + ensureDataSourcesIsMutable(); + dataSources_.set(index, builderForValue.build()); + onChanged(); + } else { + dataSourcesBuilder_.setMessage(index, builderForValue.build()); + } + return this; + } + /** + * repeated .grpc.DataSourceInstance data_sources = 6; + */ + public Builder addDataSources(io.trino.spi.grpc.Endpoints.DataSourceInstance value) { + if (dataSourcesBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + ensureDataSourcesIsMutable(); + dataSources_.add(value); + onChanged(); + } else { + dataSourcesBuilder_.addMessage(value); + } + return this; + } + /** + * repeated .grpc.DataSourceInstance data_sources = 6; + */ + public Builder addDataSources( + int index, io.trino.spi.grpc.Endpoints.DataSourceInstance value) { + if (dataSourcesBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + ensureDataSourcesIsMutable(); + dataSources_.add(index, value); + onChanged(); + } else { + dataSourcesBuilder_.addMessage(index, value); + } + return this; + } + /** + * repeated .grpc.DataSourceInstance data_sources = 6; + */ + public Builder addDataSources( + io.trino.spi.grpc.Endpoints.DataSourceInstance.Builder builderForValue) { + if (dataSourcesBuilder_ == null) { + ensureDataSourcesIsMutable(); + dataSources_.add(builderForValue.build()); + onChanged(); + } else { + dataSourcesBuilder_.addMessage(builderForValue.build()); + } + return this; + } + /** + * repeated .grpc.DataSourceInstance data_sources = 6; + */ + public Builder addDataSources( + int index, io.trino.spi.grpc.Endpoints.DataSourceInstance.Builder builderForValue) { + if (dataSourcesBuilder_ == null) { + ensureDataSourcesIsMutable(); + dataSources_.add(index, builderForValue.build()); + onChanged(); + } else { + dataSourcesBuilder_.addMessage(index, builderForValue.build()); + } + return this; + } + /** + * repeated .grpc.DataSourceInstance data_sources = 6; + */ + public Builder addAllDataSources( + java.lang.Iterable values) { + if (dataSourcesBuilder_ == null) { + ensureDataSourcesIsMutable(); + com.google.protobuf.AbstractMessageLite.Builder.addAll( + values, dataSources_); + onChanged(); + } else { + dataSourcesBuilder_.addAllMessages(values); + } + return this; + } + /** + * repeated .grpc.DataSourceInstance data_sources = 6; + */ + public Builder clearDataSources() { + if (dataSourcesBuilder_ == null) { + dataSources_ = java.util.Collections.emptyList(); + bitField0_ = (bitField0_ & ~0x00000020); + onChanged(); + } else { + dataSourcesBuilder_.clear(); + } + return this; + } + /** + * repeated .grpc.DataSourceInstance data_sources = 6; + */ + public Builder removeDataSources(int index) { + if (dataSourcesBuilder_ == null) { + ensureDataSourcesIsMutable(); + dataSources_.remove(index); + onChanged(); + } else { + dataSourcesBuilder_.remove(index); + } + return this; + } + /** + * repeated .grpc.DataSourceInstance data_sources = 6; + */ + public io.trino.spi.grpc.Endpoints.DataSourceInstance.Builder getDataSourcesBuilder( + int index) { + return getDataSourcesFieldBuilder().getBuilder(index); + } + /** + * repeated .grpc.DataSourceInstance data_sources = 6; + */ + public io.trino.spi.grpc.Endpoints.DataSourceInstanceOrBuilder getDataSourcesOrBuilder( + int index) { + if (dataSourcesBuilder_ == null) { + return dataSources_.get(index); } else { + return dataSourcesBuilder_.getMessageOrBuilder(index); + } + } + /** + * repeated .grpc.DataSourceInstance data_sources = 6; + */ + public java.util.List + getDataSourcesOrBuilderList() { + if (dataSourcesBuilder_ != null) { + return dataSourcesBuilder_.getMessageOrBuilderList(); + } else { + return java.util.Collections.unmodifiableList(dataSources_); + } + } + /** + * repeated .grpc.DataSourceInstance data_sources = 6; + */ + public io.trino.spi.grpc.Endpoints.DataSourceInstance.Builder addDataSourcesBuilder() { + return getDataSourcesFieldBuilder().addBuilder( + io.trino.spi.grpc.Endpoints.DataSourceInstance.getDefaultInstance()); + } + /** + * repeated .grpc.DataSourceInstance data_sources = 6; + */ + public io.trino.spi.grpc.Endpoints.DataSourceInstance.Builder addDataSourcesBuilder( + int index) { + return getDataSourcesFieldBuilder().addBuilder( + index, io.trino.spi.grpc.Endpoints.DataSourceInstance.getDefaultInstance()); + } + /** + * repeated .grpc.DataSourceInstance data_sources = 6; + */ + public java.util.List + getDataSourcesBuilderList() { + return getDataSourcesFieldBuilder().getBuilderList(); + } + private com.google.protobuf.RepeatedFieldBuilderV3< + io.trino.spi.grpc.Endpoints.DataSourceInstance, io.trino.spi.grpc.Endpoints.DataSourceInstance.Builder, io.trino.spi.grpc.Endpoints.DataSourceInstanceOrBuilder> + getDataSourcesFieldBuilder() { + if (dataSourcesBuilder_ == null) { + dataSourcesBuilder_ = new com.google.protobuf.RepeatedFieldBuilderV3< + io.trino.spi.grpc.Endpoints.DataSourceInstance, io.trino.spi.grpc.Endpoints.DataSourceInstance.Builder, io.trino.spi.grpc.Endpoints.DataSourceInstanceOrBuilder>( + dataSources_, + ((bitField0_ & 0x00000020) != 0), + getParentForChildren(), + isClean()); + dataSources_ = null; + } + return dataSourcesBuilder_; + } + + private boolean isTest_ ; + /** + * bool is_test = 7; + * @return The isTest. + */ + @java.lang.Override + public boolean getIsTest() { + return isTest_; + } + /** + * bool is_test = 7; + * @param value The isTest to set. + * @return This builder for chaining. + */ + public Builder setIsTest(boolean value) { + + isTest_ = value; + bitField0_ |= 0x00000040; + onChanged(); + return this; + } + /** + * bool is_test = 7; + * @return This builder for chaining. + */ + public Builder clearIsTest() { + bitField0_ = (bitField0_ & ~0x00000040); + isTest_ = false; + onChanged(); + return this; + } + + private java.lang.Object tenantName_ = ""; + /** + * string tenant_name = 8; + * @return The tenantName. + */ + public java.lang.String getTenantName() { + java.lang.Object ref = tenantName_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenantName_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant_name = 8; + * @return The bytes for tenantName. + */ + public com.google.protobuf.ByteString + getTenantNameBytes() { + java.lang.Object ref = tenantName_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenantName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant_name = 8; + * @param value The tenantName to set. + * @return This builder for chaining. + */ + public Builder setTenantName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenantName_ = value; + bitField0_ |= 0x00000080; + onChanged(); + return this; + } + /** + * string tenant_name = 8; + * @return This builder for chaining. + */ + public Builder clearTenantName() { + tenantName_ = getDefaultInstance().getTenantName(); + bitField0_ = (bitField0_ & ~0x00000080); + onChanged(); + return this; + } + /** + * string tenant_name = 8; + * @param value The bytes for tenantName to set. + * @return This builder for chaining. + */ + public Builder setTenantNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenantName_ = value; + bitField0_ |= 0x00000080; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.TrinoConnectorInstance) + } + + // @@protoc_insertion_point(class_scope:grpc.TrinoConnectorInstance) + private static final io.trino.spi.grpc.Endpoints.TrinoConnectorInstance DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.TrinoConnectorInstance(); + } + + public static io.trino.spi.grpc.Endpoints.TrinoConnectorInstance getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public TrinoConnectorInstance parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.TrinoConnectorInstance getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface BrokerHostnamesOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.BrokerHostnames) + com.google.protobuf.MessageOrBuilder { + + /** + * uint32 subnet = 1; + * @return The subnet. + */ + int getSubnet(); + + /** + * repeated string connector_instances_hostnames = 2; + * @return A list containing the connectorInstancesHostnames. + */ + java.util.List + getConnectorInstancesHostnamesList(); + /** + * repeated string connector_instances_hostnames = 2; + * @return The count of connectorInstancesHostnames. + */ + int getConnectorInstancesHostnamesCount(); + /** + * repeated string connector_instances_hostnames = 2; + * @param index The index of the element to return. + * @return The connectorInstancesHostnames at the given index. + */ + java.lang.String getConnectorInstancesHostnames(int index); + /** + * repeated string connector_instances_hostnames = 2; + * @param index The index of the value to return. + * @return The bytes of the connectorInstancesHostnames at the given index. + */ + com.google.protobuf.ByteString + getConnectorInstancesHostnamesBytes(int index); + } + /** + * Protobuf type {@code grpc.BrokerHostnames} + */ + public static final class BrokerHostnames extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.BrokerHostnames) + BrokerHostnamesOrBuilder { + private static final long serialVersionUID = 0L; + // Use BrokerHostnames.newBuilder() to construct. + private BrokerHostnames(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private BrokerHostnames() { + connectorInstancesHostnames_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new BrokerHostnames(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BrokerHostnames_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BrokerHostnames_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.BrokerHostnames.class, io.trino.spi.grpc.Endpoints.BrokerHostnames.Builder.class); + } + + public static final int SUBNET_FIELD_NUMBER = 1; + private int subnet_ = 0; + /** + * uint32 subnet = 1; + * @return The subnet. + */ + @java.lang.Override + public int getSubnet() { + return subnet_; + } + + public static final int CONNECTOR_INSTANCES_HOSTNAMES_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private com.google.protobuf.LazyStringArrayList connectorInstancesHostnames_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + /** + * repeated string connector_instances_hostnames = 2; + * @return A list containing the connectorInstancesHostnames. + */ + public com.google.protobuf.ProtocolStringList + getConnectorInstancesHostnamesList() { + return connectorInstancesHostnames_; + } + /** + * repeated string connector_instances_hostnames = 2; + * @return The count of connectorInstancesHostnames. + */ + public int getConnectorInstancesHostnamesCount() { + return connectorInstancesHostnames_.size(); + } + /** + * repeated string connector_instances_hostnames = 2; + * @param index The index of the element to return. + * @return The connectorInstancesHostnames at the given index. + */ + public java.lang.String getConnectorInstancesHostnames(int index) { + return connectorInstancesHostnames_.get(index); + } + /** + * repeated string connector_instances_hostnames = 2; + * @param index The index of the value to return. + * @return The bytes of the connectorInstancesHostnames at the given index. + */ + public com.google.protobuf.ByteString + getConnectorInstancesHostnamesBytes(int index) { + return connectorInstancesHostnames_.getByteString(index); + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (subnet_ != 0) { + output.writeUInt32(1, subnet_); + } + for (int i = 0; i < connectorInstancesHostnames_.size(); i++) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, connectorInstancesHostnames_.getRaw(i)); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (subnet_ != 0) { + size += com.google.protobuf.CodedOutputStream + .computeUInt32Size(1, subnet_); + } + { + int dataSize = 0; + for (int i = 0; i < connectorInstancesHostnames_.size(); i++) { + dataSize += computeStringSizeNoTag(connectorInstancesHostnames_.getRaw(i)); + } + size += dataSize; + size += 1 * getConnectorInstancesHostnamesList().size(); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.BrokerHostnames)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.BrokerHostnames other = (io.trino.spi.grpc.Endpoints.BrokerHostnames) obj; + + if (getSubnet() + != other.getSubnet()) return false; + if (!getConnectorInstancesHostnamesList() + .equals(other.getConnectorInstancesHostnamesList())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + SUBNET_FIELD_NUMBER; + hash = (53 * hash) + getSubnet(); + if (getConnectorInstancesHostnamesCount() > 0) { + hash = (37 * hash) + CONNECTOR_INSTANCES_HOSTNAMES_FIELD_NUMBER; + hash = (53 * hash) + getConnectorInstancesHostnamesList().hashCode(); + } + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.BrokerHostnames parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.BrokerHostnames parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.BrokerHostnames parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.BrokerHostnames parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.BrokerHostnames parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.BrokerHostnames parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.BrokerHostnames parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.BrokerHostnames parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.BrokerHostnames parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.BrokerHostnames parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.BrokerHostnames parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.BrokerHostnames parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.BrokerHostnames prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.BrokerHostnames} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.BrokerHostnames) + io.trino.spi.grpc.Endpoints.BrokerHostnamesOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BrokerHostnames_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BrokerHostnames_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.BrokerHostnames.class, io.trino.spi.grpc.Endpoints.BrokerHostnames.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.BrokerHostnames.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + subnet_ = 0; + connectorInstancesHostnames_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BrokerHostnames_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BrokerHostnames getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.BrokerHostnames.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BrokerHostnames build() { + io.trino.spi.grpc.Endpoints.BrokerHostnames result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BrokerHostnames buildPartial() { + io.trino.spi.grpc.Endpoints.BrokerHostnames result = new io.trino.spi.grpc.Endpoints.BrokerHostnames(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.BrokerHostnames result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.subnet_ = subnet_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + connectorInstancesHostnames_.makeImmutable(); + result.connectorInstancesHostnames_ = connectorInstancesHostnames_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.BrokerHostnames) { + return mergeFrom((io.trino.spi.grpc.Endpoints.BrokerHostnames)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.BrokerHostnames other) { + if (other == io.trino.spi.grpc.Endpoints.BrokerHostnames.getDefaultInstance()) return this; + if (other.getSubnet() != 0) { + setSubnet(other.getSubnet()); + } + if (!other.connectorInstancesHostnames_.isEmpty()) { + if (connectorInstancesHostnames_.isEmpty()) { + connectorInstancesHostnames_ = other.connectorInstancesHostnames_; + bitField0_ |= 0x00000002; + } else { + ensureConnectorInstancesHostnamesIsMutable(); + connectorInstancesHostnames_.addAll(other.connectorInstancesHostnames_); + } + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 8: { + subnet_ = input.readUInt32(); + bitField0_ |= 0x00000001; + break; + } // case 8 + case 18: { + java.lang.String s = input.readStringRequireUtf8(); + ensureConnectorInstancesHostnamesIsMutable(); + connectorInstancesHostnames_.add(s); + break; + } // case 18 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private int subnet_ ; + /** + * uint32 subnet = 1; + * @return The subnet. + */ + @java.lang.Override + public int getSubnet() { + return subnet_; + } + /** + * uint32 subnet = 1; + * @param value The subnet to set. + * @return This builder for chaining. + */ + public Builder setSubnet(int value) { + + subnet_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * uint32 subnet = 1; + * @return This builder for chaining. + */ + public Builder clearSubnet() { + bitField0_ = (bitField0_ & ~0x00000001); + subnet_ = 0; + onChanged(); + return this; + } + + private com.google.protobuf.LazyStringArrayList connectorInstancesHostnames_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + private void ensureConnectorInstancesHostnamesIsMutable() { + if (!connectorInstancesHostnames_.isModifiable()) { + connectorInstancesHostnames_ = new com.google.protobuf.LazyStringArrayList(connectorInstancesHostnames_); + } + bitField0_ |= 0x00000002; + } + /** + * repeated string connector_instances_hostnames = 2; + * @return A list containing the connectorInstancesHostnames. + */ + public com.google.protobuf.ProtocolStringList + getConnectorInstancesHostnamesList() { + connectorInstancesHostnames_.makeImmutable(); + return connectorInstancesHostnames_; + } + /** + * repeated string connector_instances_hostnames = 2; + * @return The count of connectorInstancesHostnames. + */ + public int getConnectorInstancesHostnamesCount() { + return connectorInstancesHostnames_.size(); + } + /** + * repeated string connector_instances_hostnames = 2; + * @param index The index of the element to return. + * @return The connectorInstancesHostnames at the given index. + */ + public java.lang.String getConnectorInstancesHostnames(int index) { + return connectorInstancesHostnames_.get(index); + } + /** + * repeated string connector_instances_hostnames = 2; + * @param index The index of the value to return. + * @return The bytes of the connectorInstancesHostnames at the given index. + */ + public com.google.protobuf.ByteString + getConnectorInstancesHostnamesBytes(int index) { + return connectorInstancesHostnames_.getByteString(index); + } + /** + * repeated string connector_instances_hostnames = 2; + * @param index The index to set the value at. + * @param value The connectorInstancesHostnames to set. + * @return This builder for chaining. + */ + public Builder setConnectorInstancesHostnames( + int index, java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + ensureConnectorInstancesHostnamesIsMutable(); + connectorInstancesHostnames_.set(index, value); + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * repeated string connector_instances_hostnames = 2; + * @param value The connectorInstancesHostnames to add. + * @return This builder for chaining. + */ + public Builder addConnectorInstancesHostnames( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + ensureConnectorInstancesHostnamesIsMutable(); + connectorInstancesHostnames_.add(value); + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * repeated string connector_instances_hostnames = 2; + * @param values The connectorInstancesHostnames to add. + * @return This builder for chaining. + */ + public Builder addAllConnectorInstancesHostnames( + java.lang.Iterable values) { + ensureConnectorInstancesHostnamesIsMutable(); + com.google.protobuf.AbstractMessageLite.Builder.addAll( + values, connectorInstancesHostnames_); + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * repeated string connector_instances_hostnames = 2; + * @return This builder for chaining. + */ + public Builder clearConnectorInstancesHostnames() { + connectorInstancesHostnames_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + bitField0_ = (bitField0_ & ~0x00000002);; + onChanged(); + return this; + } + /** + * repeated string connector_instances_hostnames = 2; + * @param value The bytes of the connectorInstancesHostnames to add. + * @return This builder for chaining. + */ + public Builder addConnectorInstancesHostnamesBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + ensureConnectorInstancesHostnamesIsMutable(); + connectorInstancesHostnames_.add(value); + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.BrokerHostnames) + } + + // @@protoc_insertion_point(class_scope:grpc.BrokerHostnames) + private static final io.trino.spi.grpc.Endpoints.BrokerHostnames DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.BrokerHostnames(); + } + + public static io.trino.spi.grpc.Endpoints.BrokerHostnames getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public BrokerHostnames parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BrokerHostnames getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface EmptyRequestOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.EmptyRequest) + com.google.protobuf.MessageOrBuilder { + } + /** + * Protobuf type {@code grpc.EmptyRequest} + */ + public static final class EmptyRequest extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.EmptyRequest) + EmptyRequestOrBuilder { + private static final long serialVersionUID = 0L; + // Use EmptyRequest.newBuilder() to construct. + private EmptyRequest(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private EmptyRequest() { + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new EmptyRequest(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_EmptyRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_EmptyRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.EmptyRequest.class, io.trino.spi.grpc.Endpoints.EmptyRequest.Builder.class); + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.EmptyRequest)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.EmptyRequest other = (io.trino.spi.grpc.Endpoints.EmptyRequest) obj; + + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.EmptyRequest parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.EmptyRequest parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.EmptyRequest parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.EmptyRequest parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.EmptyRequest parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.EmptyRequest parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.EmptyRequest parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.EmptyRequest parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.EmptyRequest parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.EmptyRequest parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.EmptyRequest parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.EmptyRequest parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.EmptyRequest prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.EmptyRequest} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.EmptyRequest) + io.trino.spi.grpc.Endpoints.EmptyRequestOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_EmptyRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_EmptyRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.EmptyRequest.class, io.trino.spi.grpc.Endpoints.EmptyRequest.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.EmptyRequest.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_EmptyRequest_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.EmptyRequest getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.EmptyRequest.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.EmptyRequest build() { + io.trino.spi.grpc.Endpoints.EmptyRequest result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.EmptyRequest buildPartial() { + io.trino.spi.grpc.Endpoints.EmptyRequest result = new io.trino.spi.grpc.Endpoints.EmptyRequest(this); + onBuilt(); + return result; + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.EmptyRequest) { + return mergeFrom((io.trino.spi.grpc.Endpoints.EmptyRequest)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.EmptyRequest other) { + if (other == io.trino.spi.grpc.Endpoints.EmptyRequest.getDefaultInstance()) return this; + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.EmptyRequest) + } + + // @@protoc_insertion_point(class_scope:grpc.EmptyRequest) + private static final io.trino.spi.grpc.Endpoints.EmptyRequest DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.EmptyRequest(); + } + + public static io.trino.spi.grpc.Endpoints.EmptyRequest getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public EmptyRequest parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.EmptyRequest getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface TenantRequestOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.TenantRequest) + com.google.protobuf.MessageOrBuilder { + + /** + * string tenant = 1; + * @return The tenant. + */ + java.lang.String getTenant(); + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + com.google.protobuf.ByteString + getTenantBytes(); + } + /** + * Protobuf type {@code grpc.TenantRequest} + */ + public static final class TenantRequest extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.TenantRequest) + TenantRequestOrBuilder { + private static final long serialVersionUID = 0L; + // Use TenantRequest.newBuilder() to construct. + private TenantRequest(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private TenantRequest() { + tenant_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new TenantRequest(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_TenantRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_TenantRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.TenantRequest.class, io.trino.spi.grpc.Endpoints.TenantRequest.Builder.class); + } + + public static final int TENANT_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + @java.lang.Override + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, tenant_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, tenant_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.TenantRequest)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.TenantRequest other = (io.trino.spi.grpc.Endpoints.TenantRequest) obj; + + if (!getTenant() + .equals(other.getTenant())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + TENANT_FIELD_NUMBER; + hash = (53 * hash) + getTenant().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.TenantRequest parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.TenantRequest parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.TenantRequest parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.TenantRequest parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.TenantRequest parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.TenantRequest parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.TenantRequest parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.TenantRequest parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.TenantRequest parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.TenantRequest parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.TenantRequest parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.TenantRequest parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.TenantRequest prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.TenantRequest} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.TenantRequest) + io.trino.spi.grpc.Endpoints.TenantRequestOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_TenantRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_TenantRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.TenantRequest.class, io.trino.spi.grpc.Endpoints.TenantRequest.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.TenantRequest.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + tenant_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_TenantRequest_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.TenantRequest getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.TenantRequest.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.TenantRequest build() { + io.trino.spi.grpc.Endpoints.TenantRequest result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.TenantRequest buildPartial() { + io.trino.spi.grpc.Endpoints.TenantRequest result = new io.trino.spi.grpc.Endpoints.TenantRequest(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.TenantRequest result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.tenant_ = tenant_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.TenantRequest) { + return mergeFrom((io.trino.spi.grpc.Endpoints.TenantRequest)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.TenantRequest other) { + if (other == io.trino.spi.grpc.Endpoints.TenantRequest.getDefaultInstance()) return this; + if (!other.getTenant().isEmpty()) { + tenant_ = other.tenant_; + bitField0_ |= 0x00000001; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + tenant_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant = 1; + * @param value The tenant to set. + * @return This builder for chaining. + */ + public Builder setTenant( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string tenant = 1; + * @return This builder for chaining. + */ + public Builder clearTenant() { + tenant_ = getDefaultInstance().getTenant(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string tenant = 1; + * @param value The bytes for tenant to set. + * @return This builder for chaining. + */ + public Builder setTenantBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.TenantRequest) + } + + // @@protoc_insertion_point(class_scope:grpc.TenantRequest) + private static final io.trino.spi.grpc.Endpoints.TenantRequest DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.TenantRequest(); + } + + public static io.trino.spi.grpc.Endpoints.TenantRequest getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public TenantRequest parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.TenantRequest getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface ConnectorCapabilitiesRequestOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.ConnectorCapabilitiesRequest) + com.google.protobuf.MessageOrBuilder { + + /** + * uint32 connectorCapabilities = 1; + * @return The connectorCapabilities. + */ + int getConnectorCapabilities(); + } + /** + * Protobuf type {@code grpc.ConnectorCapabilitiesRequest} + */ + public static final class ConnectorCapabilitiesRequest extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.ConnectorCapabilitiesRequest) + ConnectorCapabilitiesRequestOrBuilder { + private static final long serialVersionUID = 0L; + // Use ConnectorCapabilitiesRequest.newBuilder() to construct. + private ConnectorCapabilitiesRequest(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private ConnectorCapabilitiesRequest() { + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new ConnectorCapabilitiesRequest(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_ConnectorCapabilitiesRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_ConnectorCapabilitiesRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest.class, io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest.Builder.class); + } + + public static final int CONNECTORCAPABILITIES_FIELD_NUMBER = 1; + private int connectorCapabilities_ = 0; + /** + * uint32 connectorCapabilities = 1; + * @return The connectorCapabilities. + */ + @java.lang.Override + public int getConnectorCapabilities() { + return connectorCapabilities_; + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (connectorCapabilities_ != 0) { + output.writeUInt32(1, connectorCapabilities_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (connectorCapabilities_ != 0) { + size += com.google.protobuf.CodedOutputStream + .computeUInt32Size(1, connectorCapabilities_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest other = (io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest) obj; + + if (getConnectorCapabilities() + != other.getConnectorCapabilities()) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + CONNECTORCAPABILITIES_FIELD_NUMBER; + hash = (53 * hash) + getConnectorCapabilities(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.ConnectorCapabilitiesRequest} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.ConnectorCapabilitiesRequest) + io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequestOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_ConnectorCapabilitiesRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_ConnectorCapabilitiesRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest.class, io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + connectorCapabilities_ = 0; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_ConnectorCapabilitiesRequest_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest build() { + io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest buildPartial() { + io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest result = new io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.connectorCapabilities_ = connectorCapabilities_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest) { + return mergeFrom((io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest other) { + if (other == io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest.getDefaultInstance()) return this; + if (other.getConnectorCapabilities() != 0) { + setConnectorCapabilities(other.getConnectorCapabilities()); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 8: { + connectorCapabilities_ = input.readUInt32(); + bitField0_ |= 0x00000001; + break; + } // case 8 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private int connectorCapabilities_ ; + /** + * uint32 connectorCapabilities = 1; + * @return The connectorCapabilities. + */ + @java.lang.Override + public int getConnectorCapabilities() { + return connectorCapabilities_; + } + /** + * uint32 connectorCapabilities = 1; + * @param value The connectorCapabilities to set. + * @return This builder for chaining. + */ + public Builder setConnectorCapabilities(int value) { + + connectorCapabilities_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * uint32 connectorCapabilities = 1; + * @return This builder for chaining. + */ + public Builder clearConnectorCapabilities() { + bitField0_ = (bitField0_ & ~0x00000001); + connectorCapabilities_ = 0; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.ConnectorCapabilitiesRequest) + } + + // @@protoc_insertion_point(class_scope:grpc.ConnectorCapabilitiesRequest) + private static final io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest(); + } + + public static io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public ConnectorCapabilitiesRequest parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface EmptyReplyOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.EmptyReply) + com.google.protobuf.MessageOrBuilder { + } + /** + * Protobuf type {@code grpc.EmptyReply} + */ + public static final class EmptyReply extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.EmptyReply) + EmptyReplyOrBuilder { + private static final long serialVersionUID = 0L; + // Use EmptyReply.newBuilder() to construct. + private EmptyReply(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private EmptyReply() { + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new EmptyReply(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_EmptyReply_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_EmptyReply_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.EmptyReply.class, io.trino.spi.grpc.Endpoints.EmptyReply.Builder.class); + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.EmptyReply)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.EmptyReply other = (io.trino.spi.grpc.Endpoints.EmptyReply) obj; + + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.EmptyReply parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.EmptyReply parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.EmptyReply parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.EmptyReply parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.EmptyReply parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.EmptyReply parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.EmptyReply parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.EmptyReply parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.EmptyReply parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.EmptyReply parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.EmptyReply parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.EmptyReply parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.EmptyReply prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.EmptyReply} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.EmptyReply) + io.trino.spi.grpc.Endpoints.EmptyReplyOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_EmptyReply_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_EmptyReply_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.EmptyReply.class, io.trino.spi.grpc.Endpoints.EmptyReply.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.EmptyReply.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_EmptyReply_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.EmptyReply getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.EmptyReply.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.EmptyReply build() { + io.trino.spi.grpc.Endpoints.EmptyReply result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.EmptyReply buildPartial() { + io.trino.spi.grpc.Endpoints.EmptyReply result = new io.trino.spi.grpc.Endpoints.EmptyReply(this); + onBuilt(); + return result; + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.EmptyReply) { + return mergeFrom((io.trino.spi.grpc.Endpoints.EmptyReply)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.EmptyReply other) { + if (other == io.trino.spi.grpc.Endpoints.EmptyReply.getDefaultInstance()) return this; + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.EmptyReply) + } + + // @@protoc_insertion_point(class_scope:grpc.EmptyReply) + private static final io.trino.spi.grpc.Endpoints.EmptyReply DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.EmptyReply(); + } + + public static io.trino.spi.grpc.Endpoints.EmptyReply getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public EmptyReply parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.EmptyReply getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface SingleIDRequestOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.SingleIDRequest) + com.google.protobuf.MessageOrBuilder { + + /** + * string tenant = 1; + * @return The tenant. + */ + java.lang.String getTenant(); + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + com.google.protobuf.ByteString + getTenantBytes(); + + /** + * string id = 2; + * @return The id. + */ + java.lang.String getId(); + /** + * string id = 2; + * @return The bytes for id. + */ + com.google.protobuf.ByteString + getIdBytes(); + } + /** + * Protobuf type {@code grpc.SingleIDRequest} + */ + public static final class SingleIDRequest extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.SingleIDRequest) + SingleIDRequestOrBuilder { + private static final long serialVersionUID = 0L; + // Use SingleIDRequest.newBuilder() to construct. + private SingleIDRequest(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private SingleIDRequest() { + tenant_ = ""; + id_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new SingleIDRequest(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_SingleIDRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_SingleIDRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.SingleIDRequest.class, io.trino.spi.grpc.Endpoints.SingleIDRequest.Builder.class); + } + + public static final int TENANT_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + @java.lang.Override + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int ID_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object id_ = ""; + /** + * string id = 2; + * @return The id. + */ + @java.lang.Override + public java.lang.String getId() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } + } + /** + * string id = 2; + * @return The bytes for id. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, id_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, id_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.SingleIDRequest)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.SingleIDRequest other = (io.trino.spi.grpc.Endpoints.SingleIDRequest) obj; + + if (!getTenant() + .equals(other.getTenant())) return false; + if (!getId() + .equals(other.getId())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + TENANT_FIELD_NUMBER; + hash = (53 * hash) + getTenant().hashCode(); + hash = (37 * hash) + ID_FIELD_NUMBER; + hash = (53 * hash) + getId().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.SingleIDRequest parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.SingleIDRequest parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.SingleIDRequest parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.SingleIDRequest parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.SingleIDRequest parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.SingleIDRequest parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.SingleIDRequest parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.SingleIDRequest parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.SingleIDRequest parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.SingleIDRequest parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.SingleIDRequest parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.SingleIDRequest parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.SingleIDRequest prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.SingleIDRequest} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.SingleIDRequest) + io.trino.spi.grpc.Endpoints.SingleIDRequestOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_SingleIDRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_SingleIDRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.SingleIDRequest.class, io.trino.spi.grpc.Endpoints.SingleIDRequest.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.SingleIDRequest.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + tenant_ = ""; + id_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_SingleIDRequest_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.SingleIDRequest getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.SingleIDRequest.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.SingleIDRequest build() { + io.trino.spi.grpc.Endpoints.SingleIDRequest result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.SingleIDRequest buildPartial() { + io.trino.spi.grpc.Endpoints.SingleIDRequest result = new io.trino.spi.grpc.Endpoints.SingleIDRequest(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.SingleIDRequest result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.tenant_ = tenant_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.id_ = id_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.SingleIDRequest) { + return mergeFrom((io.trino.spi.grpc.Endpoints.SingleIDRequest)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.SingleIDRequest other) { + if (other == io.trino.spi.grpc.Endpoints.SingleIDRequest.getDefaultInstance()) return this; + if (!other.getTenant().isEmpty()) { + tenant_ = other.tenant_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getId().isEmpty()) { + id_ = other.id_; + bitField0_ |= 0x00000002; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + tenant_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + id_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant = 1; + * @param value The tenant to set. + * @return This builder for chaining. + */ + public Builder setTenant( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string tenant = 1; + * @return This builder for chaining. + */ + public Builder clearTenant() { + tenant_ = getDefaultInstance().getTenant(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string tenant = 1; + * @param value The bytes for tenant to set. + * @return This builder for chaining. + */ + public Builder setTenantBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object id_ = ""; + /** + * string id = 2; + * @return The id. + */ + public java.lang.String getId() { + java.lang.Object ref = id_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string id = 2; + * @return The bytes for id. + */ + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string id = 2; + * @param value The id to set. + * @return This builder for chaining. + */ + public Builder setId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + id_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string id = 2; + * @return This builder for chaining. + */ + public Builder clearId() { + id_ = getDefaultInstance().getId(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string id = 2; + * @param value The bytes for id to set. + * @return This builder for chaining. + */ + public Builder setIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + id_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.SingleIDRequest) + } + + // @@protoc_insertion_point(class_scope:grpc.SingleIDRequest) + private static final io.trino.spi.grpc.Endpoints.SingleIDRequest DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.SingleIDRequest(); + } + + public static io.trino.spi.grpc.Endpoints.SingleIDRequest getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public SingleIDRequest parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.SingleIDRequest getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface SingleIDReplyOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.SingleIDReply) + com.google.protobuf.MessageOrBuilder { + + /** + * string id = 1; + * @return The id. + */ + java.lang.String getId(); + /** + * string id = 1; + * @return The bytes for id. + */ + com.google.protobuf.ByteString + getIdBytes(); + } + /** + * Protobuf type {@code grpc.SingleIDReply} + */ + public static final class SingleIDReply extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.SingleIDReply) + SingleIDReplyOrBuilder { + private static final long serialVersionUID = 0L; + // Use SingleIDReply.newBuilder() to construct. + private SingleIDReply(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private SingleIDReply() { + id_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new SingleIDReply(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_SingleIDReply_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_SingleIDReply_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.SingleIDReply.class, io.trino.spi.grpc.Endpoints.SingleIDReply.Builder.class); + } + + public static final int ID_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object id_ = ""; + /** + * string id = 1; + * @return The id. + */ + @java.lang.Override + public java.lang.String getId() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } + } + /** + * string id = 1; + * @return The bytes for id. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, id_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, id_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.SingleIDReply)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.SingleIDReply other = (io.trino.spi.grpc.Endpoints.SingleIDReply) obj; + + if (!getId() + .equals(other.getId())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + ID_FIELD_NUMBER; + hash = (53 * hash) + getId().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.SingleIDReply parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.SingleIDReply parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.SingleIDReply parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.SingleIDReply parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.SingleIDReply parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.SingleIDReply parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.SingleIDReply parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.SingleIDReply parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.SingleIDReply parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.SingleIDReply parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.SingleIDReply parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.SingleIDReply parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.SingleIDReply prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.SingleIDReply} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.SingleIDReply) + io.trino.spi.grpc.Endpoints.SingleIDReplyOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_SingleIDReply_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_SingleIDReply_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.SingleIDReply.class, io.trino.spi.grpc.Endpoints.SingleIDReply.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.SingleIDReply.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + id_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_SingleIDReply_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.SingleIDReply getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.SingleIDReply.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.SingleIDReply build() { + io.trino.spi.grpc.Endpoints.SingleIDReply result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.SingleIDReply buildPartial() { + io.trino.spi.grpc.Endpoints.SingleIDReply result = new io.trino.spi.grpc.Endpoints.SingleIDReply(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.SingleIDReply result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.id_ = id_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.SingleIDReply) { + return mergeFrom((io.trino.spi.grpc.Endpoints.SingleIDReply)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.SingleIDReply other) { + if (other == io.trino.spi.grpc.Endpoints.SingleIDReply.getDefaultInstance()) return this; + if (!other.getId().isEmpty()) { + id_ = other.id_; + bitField0_ |= 0x00000001; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + id_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object id_ = ""; + /** + * string id = 1; + * @return The id. + */ + public java.lang.String getId() { + java.lang.Object ref = id_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string id = 1; + * @return The bytes for id. + */ + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string id = 1; + * @param value The id to set. + * @return This builder for chaining. + */ + public Builder setId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + id_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string id = 1; + * @return This builder for chaining. + */ + public Builder clearId() { + id_ = getDefaultInstance().getId(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string id = 1; + * @param value The bytes for id to set. + * @return This builder for chaining. + */ + public Builder setIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + id_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.SingleIDReply) + } + + // @@protoc_insertion_point(class_scope:grpc.SingleIDReply) + private static final io.trino.spi.grpc.Endpoints.SingleIDReply DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.SingleIDReply(); + } + + public static io.trino.spi.grpc.Endpoints.SingleIDReply getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public SingleIDReply parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.SingleIDReply getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface MultipleIDsRequestOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.MultipleIDsRequest) + com.google.protobuf.MessageOrBuilder { + + /** + * string tenant = 1; + * @return The tenant. + */ + java.lang.String getTenant(); + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + com.google.protobuf.ByteString + getTenantBytes(); + + /** + * repeated string ids = 2; + * @return A list containing the ids. + */ + java.util.List + getIdsList(); + /** + * repeated string ids = 2; + * @return The count of ids. + */ + int getIdsCount(); + /** + * repeated string ids = 2; + * @param index The index of the element to return. + * @return The ids at the given index. + */ + java.lang.String getIds(int index); + /** + * repeated string ids = 2; + * @param index The index of the value to return. + * @return The bytes of the ids at the given index. + */ + com.google.protobuf.ByteString + getIdsBytes(int index); + } + /** + * Protobuf type {@code grpc.MultipleIDsRequest} + */ + public static final class MultipleIDsRequest extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.MultipleIDsRequest) + MultipleIDsRequestOrBuilder { + private static final long serialVersionUID = 0L; + // Use MultipleIDsRequest.newBuilder() to construct. + private MultipleIDsRequest(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private MultipleIDsRequest() { + tenant_ = ""; + ids_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new MultipleIDsRequest(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_MultipleIDsRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_MultipleIDsRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.MultipleIDsRequest.class, io.trino.spi.grpc.Endpoints.MultipleIDsRequest.Builder.class); + } + + public static final int TENANT_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + @java.lang.Override + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int IDS_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private com.google.protobuf.LazyStringArrayList ids_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + /** + * repeated string ids = 2; + * @return A list containing the ids. + */ + public com.google.protobuf.ProtocolStringList + getIdsList() { + return ids_; + } + /** + * repeated string ids = 2; + * @return The count of ids. + */ + public int getIdsCount() { + return ids_.size(); + } + /** + * repeated string ids = 2; + * @param index The index of the element to return. + * @return The ids at the given index. + */ + public java.lang.String getIds(int index) { + return ids_.get(index); + } + /** + * repeated string ids = 2; + * @param index The index of the value to return. + * @return The bytes of the ids at the given index. + */ + public com.google.protobuf.ByteString + getIdsBytes(int index) { + return ids_.getByteString(index); + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, tenant_); + } + for (int i = 0; i < ids_.size(); i++) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, ids_.getRaw(i)); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, tenant_); + } + { + int dataSize = 0; + for (int i = 0; i < ids_.size(); i++) { + dataSize += computeStringSizeNoTag(ids_.getRaw(i)); + } + size += dataSize; + size += 1 * getIdsList().size(); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.MultipleIDsRequest)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.MultipleIDsRequest other = (io.trino.spi.grpc.Endpoints.MultipleIDsRequest) obj; + + if (!getTenant() + .equals(other.getTenant())) return false; + if (!getIdsList() + .equals(other.getIdsList())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + TENANT_FIELD_NUMBER; + hash = (53 * hash) + getTenant().hashCode(); + if (getIdsCount() > 0) { + hash = (37 * hash) + IDS_FIELD_NUMBER; + hash = (53 * hash) + getIdsList().hashCode(); + } + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.MultipleIDsRequest parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.MultipleIDsRequest parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.MultipleIDsRequest parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.MultipleIDsRequest parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.MultipleIDsRequest parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.MultipleIDsRequest parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.MultipleIDsRequest parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.MultipleIDsRequest parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.MultipleIDsRequest parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.MultipleIDsRequest parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.MultipleIDsRequest parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.MultipleIDsRequest parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.MultipleIDsRequest prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.MultipleIDsRequest} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.MultipleIDsRequest) + io.trino.spi.grpc.Endpoints.MultipleIDsRequestOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_MultipleIDsRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_MultipleIDsRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.MultipleIDsRequest.class, io.trino.spi.grpc.Endpoints.MultipleIDsRequest.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.MultipleIDsRequest.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + tenant_ = ""; + ids_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_MultipleIDsRequest_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.MultipleIDsRequest getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.MultipleIDsRequest.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.MultipleIDsRequest build() { + io.trino.spi.grpc.Endpoints.MultipleIDsRequest result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.MultipleIDsRequest buildPartial() { + io.trino.spi.grpc.Endpoints.MultipleIDsRequest result = new io.trino.spi.grpc.Endpoints.MultipleIDsRequest(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.MultipleIDsRequest result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.tenant_ = tenant_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + ids_.makeImmutable(); + result.ids_ = ids_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.MultipleIDsRequest) { + return mergeFrom((io.trino.spi.grpc.Endpoints.MultipleIDsRequest)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.MultipleIDsRequest other) { + if (other == io.trino.spi.grpc.Endpoints.MultipleIDsRequest.getDefaultInstance()) return this; + if (!other.getTenant().isEmpty()) { + tenant_ = other.tenant_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.ids_.isEmpty()) { + if (ids_.isEmpty()) { + ids_ = other.ids_; + bitField0_ |= 0x00000002; + } else { + ensureIdsIsMutable(); + ids_.addAll(other.ids_); + } + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + tenant_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + java.lang.String s = input.readStringRequireUtf8(); + ensureIdsIsMutable(); + ids_.add(s); + break; + } // case 18 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant = 1; + * @param value The tenant to set. + * @return This builder for chaining. + */ + public Builder setTenant( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string tenant = 1; + * @return This builder for chaining. + */ + public Builder clearTenant() { + tenant_ = getDefaultInstance().getTenant(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string tenant = 1; + * @param value The bytes for tenant to set. + * @return This builder for chaining. + */ + public Builder setTenantBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private com.google.protobuf.LazyStringArrayList ids_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + private void ensureIdsIsMutable() { + if (!ids_.isModifiable()) { + ids_ = new com.google.protobuf.LazyStringArrayList(ids_); + } + bitField0_ |= 0x00000002; + } + /** + * repeated string ids = 2; + * @return A list containing the ids. + */ + public com.google.protobuf.ProtocolStringList + getIdsList() { + ids_.makeImmutable(); + return ids_; + } + /** + * repeated string ids = 2; + * @return The count of ids. + */ + public int getIdsCount() { + return ids_.size(); + } + /** + * repeated string ids = 2; + * @param index The index of the element to return. + * @return The ids at the given index. + */ + public java.lang.String getIds(int index) { + return ids_.get(index); + } + /** + * repeated string ids = 2; + * @param index The index of the value to return. + * @return The bytes of the ids at the given index. + */ + public com.google.protobuf.ByteString + getIdsBytes(int index) { + return ids_.getByteString(index); + } + /** + * repeated string ids = 2; + * @param index The index to set the value at. + * @param value The ids to set. + * @return This builder for chaining. + */ + public Builder setIds( + int index, java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + ensureIdsIsMutable(); + ids_.set(index, value); + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * repeated string ids = 2; + * @param value The ids to add. + * @return This builder for chaining. + */ + public Builder addIds( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + ensureIdsIsMutable(); + ids_.add(value); + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * repeated string ids = 2; + * @param values The ids to add. + * @return This builder for chaining. + */ + public Builder addAllIds( + java.lang.Iterable values) { + ensureIdsIsMutable(); + com.google.protobuf.AbstractMessageLite.Builder.addAll( + values, ids_); + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * repeated string ids = 2; + * @return This builder for chaining. + */ + public Builder clearIds() { + ids_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + bitField0_ = (bitField0_ & ~0x00000002);; + onChanged(); + return this; + } + /** + * repeated string ids = 2; + * @param value The bytes of the ids to add. + * @return This builder for chaining. + */ + public Builder addIdsBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + ensureIdsIsMutable(); + ids_.add(value); + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.MultipleIDsRequest) + } + + // @@protoc_insertion_point(class_scope:grpc.MultipleIDsRequest) + private static final io.trino.spi.grpc.Endpoints.MultipleIDsRequest DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.MultipleIDsRequest(); + } + + public static io.trino.spi.grpc.Endpoints.MultipleIDsRequest getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public MultipleIDsRequest parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.MultipleIDsRequest getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface BrokerRequestOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.BrokerRequest) + com.google.protobuf.MessageOrBuilder { + + /** + * string id = 1; + * @return The id. + */ + java.lang.String getId(); + /** + * string id = 1; + * @return The bytes for id. + */ + com.google.protobuf.ByteString + getIdBytes(); + + /** + * bool should_create = 2; + * @return The shouldCreate. + */ + boolean getShouldCreate(); + } + /** + * Protobuf type {@code grpc.BrokerRequest} + */ + public static final class BrokerRequest extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.BrokerRequest) + BrokerRequestOrBuilder { + private static final long serialVersionUID = 0L; + // Use BrokerRequest.newBuilder() to construct. + private BrokerRequest(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private BrokerRequest() { + id_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new BrokerRequest(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BrokerRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BrokerRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.BrokerRequest.class, io.trino.spi.grpc.Endpoints.BrokerRequest.Builder.class); + } + + public static final int ID_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object id_ = ""; + /** + * string id = 1; + * @return The id. + */ + @java.lang.Override + public java.lang.String getId() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } + } + /** + * string id = 1; + * @return The bytes for id. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int SHOULD_CREATE_FIELD_NUMBER = 2; + private boolean shouldCreate_ = false; + /** + * bool should_create = 2; + * @return The shouldCreate. + */ + @java.lang.Override + public boolean getShouldCreate() { + return shouldCreate_; + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, id_); + } + if (shouldCreate_ != false) { + output.writeBool(2, shouldCreate_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, id_); + } + if (shouldCreate_ != false) { + size += com.google.protobuf.CodedOutputStream + .computeBoolSize(2, shouldCreate_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.BrokerRequest)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.BrokerRequest other = (io.trino.spi.grpc.Endpoints.BrokerRequest) obj; + + if (!getId() + .equals(other.getId())) return false; + if (getShouldCreate() + != other.getShouldCreate()) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + ID_FIELD_NUMBER; + hash = (53 * hash) + getId().hashCode(); + hash = (37 * hash) + SHOULD_CREATE_FIELD_NUMBER; + hash = (53 * hash) + com.google.protobuf.Internal.hashBoolean( + getShouldCreate()); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.BrokerRequest parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.BrokerRequest parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.BrokerRequest parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.BrokerRequest parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.BrokerRequest parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.BrokerRequest parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.BrokerRequest parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.BrokerRequest parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.BrokerRequest parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.BrokerRequest parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.BrokerRequest parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.BrokerRequest parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.BrokerRequest prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.BrokerRequest} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.BrokerRequest) + io.trino.spi.grpc.Endpoints.BrokerRequestOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BrokerRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BrokerRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.BrokerRequest.class, io.trino.spi.grpc.Endpoints.BrokerRequest.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.BrokerRequest.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + id_ = ""; + shouldCreate_ = false; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BrokerRequest_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BrokerRequest getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.BrokerRequest.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BrokerRequest build() { + io.trino.spi.grpc.Endpoints.BrokerRequest result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BrokerRequest buildPartial() { + io.trino.spi.grpc.Endpoints.BrokerRequest result = new io.trino.spi.grpc.Endpoints.BrokerRequest(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.BrokerRequest result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.id_ = id_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.shouldCreate_ = shouldCreate_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.BrokerRequest) { + return mergeFrom((io.trino.spi.grpc.Endpoints.BrokerRequest)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.BrokerRequest other) { + if (other == io.trino.spi.grpc.Endpoints.BrokerRequest.getDefaultInstance()) return this; + if (!other.getId().isEmpty()) { + id_ = other.id_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (other.getShouldCreate() != false) { + setShouldCreate(other.getShouldCreate()); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + id_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 16: { + shouldCreate_ = input.readBool(); + bitField0_ |= 0x00000002; + break; + } // case 16 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object id_ = ""; + /** + * string id = 1; + * @return The id. + */ + public java.lang.String getId() { + java.lang.Object ref = id_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string id = 1; + * @return The bytes for id. + */ + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string id = 1; + * @param value The id to set. + * @return This builder for chaining. + */ + public Builder setId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + id_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string id = 1; + * @return This builder for chaining. + */ + public Builder clearId() { + id_ = getDefaultInstance().getId(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string id = 1; + * @param value The bytes for id to set. + * @return This builder for chaining. + */ + public Builder setIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + id_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private boolean shouldCreate_ ; + /** + * bool should_create = 2; + * @return The shouldCreate. + */ + @java.lang.Override + public boolean getShouldCreate() { + return shouldCreate_; + } + /** + * bool should_create = 2; + * @param value The shouldCreate to set. + * @return This builder for chaining. + */ + public Builder setShouldCreate(boolean value) { + + shouldCreate_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * bool should_create = 2; + * @return This builder for chaining. + */ + public Builder clearShouldCreate() { + bitField0_ = (bitField0_ & ~0x00000002); + shouldCreate_ = false; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.BrokerRequest) + } + + // @@protoc_insertion_point(class_scope:grpc.BrokerRequest) + private static final io.trino.spi.grpc.Endpoints.BrokerRequest DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.BrokerRequest(); + } + + public static io.trino.spi.grpc.Endpoints.BrokerRequest getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public BrokerRequest parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BrokerRequest getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface BrokerOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.Broker) + com.google.protobuf.MessageOrBuilder { + + /** + * string id = 1; + * @return The id. + */ + java.lang.String getId(); + /** + * string id = 1; + * @return The bytes for id. + */ + com.google.protobuf.ByteString + getIdBytes(); + + /** + * int64 first_seen = 2; + * @return The firstSeen. + */ + long getFirstSeen(); + + /** + * int64 last_seen = 3; + * @return The lastSeen. + */ + long getLastSeen(); + } + /** + * Protobuf type {@code grpc.Broker} + */ + public static final class Broker extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.Broker) + BrokerOrBuilder { + private static final long serialVersionUID = 0L; + // Use Broker.newBuilder() to construct. + private Broker(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private Broker() { + id_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new Broker(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_Broker_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_Broker_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.Broker.class, io.trino.spi.grpc.Endpoints.Broker.Builder.class); + } + + public static final int ID_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object id_ = ""; + /** + * string id = 1; + * @return The id. + */ + @java.lang.Override + public java.lang.String getId() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } + } + /** + * string id = 1; + * @return The bytes for id. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int FIRST_SEEN_FIELD_NUMBER = 2; + private long firstSeen_ = 0L; + /** + * int64 first_seen = 2; + * @return The firstSeen. + */ + @java.lang.Override + public long getFirstSeen() { + return firstSeen_; + } + + public static final int LAST_SEEN_FIELD_NUMBER = 3; + private long lastSeen_ = 0L; + /** + * int64 last_seen = 3; + * @return The lastSeen. + */ + @java.lang.Override + public long getLastSeen() { + return lastSeen_; + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, id_); + } + if (firstSeen_ != 0L) { + output.writeInt64(2, firstSeen_); + } + if (lastSeen_ != 0L) { + output.writeInt64(3, lastSeen_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, id_); + } + if (firstSeen_ != 0L) { + size += com.google.protobuf.CodedOutputStream + .computeInt64Size(2, firstSeen_); + } + if (lastSeen_ != 0L) { + size += com.google.protobuf.CodedOutputStream + .computeInt64Size(3, lastSeen_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.Broker)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.Broker other = (io.trino.spi.grpc.Endpoints.Broker) obj; + + if (!getId() + .equals(other.getId())) return false; + if (getFirstSeen() + != other.getFirstSeen()) return false; + if (getLastSeen() + != other.getLastSeen()) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + ID_FIELD_NUMBER; + hash = (53 * hash) + getId().hashCode(); + hash = (37 * hash) + FIRST_SEEN_FIELD_NUMBER; + hash = (53 * hash) + com.google.protobuf.Internal.hashLong( + getFirstSeen()); + hash = (37 * hash) + LAST_SEEN_FIELD_NUMBER; + hash = (53 * hash) + com.google.protobuf.Internal.hashLong( + getLastSeen()); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.Broker parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.Broker parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.Broker parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.Broker parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.Broker parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.Broker parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.Broker parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.Broker parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.Broker parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.Broker parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.Broker parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.Broker parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.Broker prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.Broker} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.Broker) + io.trino.spi.grpc.Endpoints.BrokerOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_Broker_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_Broker_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.Broker.class, io.trino.spi.grpc.Endpoints.Broker.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.Broker.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + id_ = ""; + firstSeen_ = 0L; + lastSeen_ = 0L; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_Broker_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.Broker getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.Broker.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.Broker build() { + io.trino.spi.grpc.Endpoints.Broker result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.Broker buildPartial() { + io.trino.spi.grpc.Endpoints.Broker result = new io.trino.spi.grpc.Endpoints.Broker(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.Broker result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.id_ = id_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.firstSeen_ = firstSeen_; + } + if (((from_bitField0_ & 0x00000004) != 0)) { + result.lastSeen_ = lastSeen_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.Broker) { + return mergeFrom((io.trino.spi.grpc.Endpoints.Broker)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.Broker other) { + if (other == io.trino.spi.grpc.Endpoints.Broker.getDefaultInstance()) return this; + if (!other.getId().isEmpty()) { + id_ = other.id_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (other.getFirstSeen() != 0L) { + setFirstSeen(other.getFirstSeen()); + } + if (other.getLastSeen() != 0L) { + setLastSeen(other.getLastSeen()); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + id_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 16: { + firstSeen_ = input.readInt64(); + bitField0_ |= 0x00000002; + break; + } // case 16 + case 24: { + lastSeen_ = input.readInt64(); + bitField0_ |= 0x00000004; + break; + } // case 24 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object id_ = ""; + /** + * string id = 1; + * @return The id. + */ + public java.lang.String getId() { + java.lang.Object ref = id_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string id = 1; + * @return The bytes for id. + */ + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string id = 1; + * @param value The id to set. + * @return This builder for chaining. + */ + public Builder setId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + id_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string id = 1; + * @return This builder for chaining. + */ + public Builder clearId() { + id_ = getDefaultInstance().getId(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string id = 1; + * @param value The bytes for id to set. + * @return This builder for chaining. + */ + public Builder setIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + id_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private long firstSeen_ ; + /** + * int64 first_seen = 2; + * @return The firstSeen. + */ + @java.lang.Override + public long getFirstSeen() { + return firstSeen_; + } + /** + * int64 first_seen = 2; + * @param value The firstSeen to set. + * @return This builder for chaining. + */ + public Builder setFirstSeen(long value) { + + firstSeen_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * int64 first_seen = 2; + * @return This builder for chaining. + */ + public Builder clearFirstSeen() { + bitField0_ = (bitField0_ & ~0x00000002); + firstSeen_ = 0L; + onChanged(); + return this; + } + + private long lastSeen_ ; + /** + * int64 last_seen = 3; + * @return The lastSeen. + */ + @java.lang.Override + public long getLastSeen() { + return lastSeen_; + } + /** + * int64 last_seen = 3; + * @param value The lastSeen to set. + * @return This builder for chaining. + */ + public Builder setLastSeen(long value) { + + lastSeen_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + /** + * int64 last_seen = 3; + * @return This builder for chaining. + */ + public Builder clearLastSeen() { + bitField0_ = (bitField0_ & ~0x00000004); + lastSeen_ = 0L; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.Broker) + } + + // @@protoc_insertion_point(class_scope:grpc.Broker) + private static final io.trino.spi.grpc.Endpoints.Broker DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.Broker(); + } + + public static io.trino.spi.grpc.Endpoints.Broker getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public Broker parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.Broker getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface TenantOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.Tenant) + com.google.protobuf.MessageOrBuilder { + + /** + * string name = 1; + * @return The name. + */ + java.lang.String getName(); + /** + * string name = 1; + * @return The bytes for name. + */ + com.google.protobuf.ByteString + getNameBytes(); + + /** + * string id = 2; + * @return The id. + */ + java.lang.String getId(); + /** + * string id = 2; + * @return The bytes for id. + */ + com.google.protobuf.ByteString + getIdBytes(); + } + /** + * Protobuf type {@code grpc.Tenant} + */ + public static final class Tenant extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.Tenant) + TenantOrBuilder { + private static final long serialVersionUID = 0L; + // Use Tenant.newBuilder() to construct. + private Tenant(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private Tenant() { + name_ = ""; + id_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new Tenant(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_Tenant_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_Tenant_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.Tenant.class, io.trino.spi.grpc.Endpoints.Tenant.Builder.class); + } + + public static final int NAME_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object name_ = ""; + /** + * string name = 1; + * @return The name. + */ + @java.lang.Override + public java.lang.String getName() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } + } + /** + * string name = 1; + * @return The bytes for name. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int ID_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object id_ = ""; + /** + * string id = 2; + * @return The id. + */ + @java.lang.Override + public java.lang.String getId() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } + } + /** + * string id = 2; + * @return The bytes for id. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(name_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, name_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, id_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(name_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, name_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, id_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.Tenant)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.Tenant other = (io.trino.spi.grpc.Endpoints.Tenant) obj; + + if (!getName() + .equals(other.getName())) return false; + if (!getId() + .equals(other.getId())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + NAME_FIELD_NUMBER; + hash = (53 * hash) + getName().hashCode(); + hash = (37 * hash) + ID_FIELD_NUMBER; + hash = (53 * hash) + getId().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.Tenant parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.Tenant parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.Tenant parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.Tenant parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.Tenant parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.Tenant parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.Tenant parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.Tenant parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.Tenant parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.Tenant parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.Tenant parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.Tenant parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.Tenant prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.Tenant} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.Tenant) + io.trino.spi.grpc.Endpoints.TenantOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_Tenant_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_Tenant_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.Tenant.class, io.trino.spi.grpc.Endpoints.Tenant.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.Tenant.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + name_ = ""; + id_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_Tenant_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.Tenant getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.Tenant.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.Tenant build() { + io.trino.spi.grpc.Endpoints.Tenant result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.Tenant buildPartial() { + io.trino.spi.grpc.Endpoints.Tenant result = new io.trino.spi.grpc.Endpoints.Tenant(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.Tenant result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.name_ = name_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.id_ = id_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.Tenant) { + return mergeFrom((io.trino.spi.grpc.Endpoints.Tenant)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.Tenant other) { + if (other == io.trino.spi.grpc.Endpoints.Tenant.getDefaultInstance()) return this; + if (!other.getName().isEmpty()) { + name_ = other.name_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getId().isEmpty()) { + id_ = other.id_; + bitField0_ |= 0x00000002; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + name_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + id_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object name_ = ""; + /** + * string name = 1; + * @return The name. + */ + public java.lang.String getName() { + java.lang.Object ref = name_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string name = 1; + * @return The bytes for name. + */ + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string name = 1; + * @param value The name to set. + * @return This builder for chaining. + */ + public Builder setName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + name_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string name = 1; + * @return This builder for chaining. + */ + public Builder clearName() { + name_ = getDefaultInstance().getName(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string name = 1; + * @param value The bytes for name to set. + * @return This builder for chaining. + */ + public Builder setNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + name_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object id_ = ""; + /** + * string id = 2; + * @return The id. + */ + public java.lang.String getId() { + java.lang.Object ref = id_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string id = 2; + * @return The bytes for id. + */ + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string id = 2; + * @param value The id to set. + * @return This builder for chaining. + */ + public Builder setId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + id_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string id = 2; + * @return This builder for chaining. + */ + public Builder clearId() { + id_ = getDefaultInstance().getId(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string id = 2; + * @param value The bytes for id to set. + * @return This builder for chaining. + */ + public Builder setIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + id_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.Tenant) + } + + // @@protoc_insertion_point(class_scope:grpc.Tenant) + private static final io.trino.spi.grpc.Endpoints.Tenant DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.Tenant(); + } + + public static io.trino.spi.grpc.Endpoints.Tenant getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public Tenant parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.Tenant getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface ConnectorInstanceCreateRequestOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.ConnectorInstanceCreateRequest) + com.google.protobuf.MessageOrBuilder { + + /** + * .grpc.Tenant tenant = 1; + * @return Whether the tenant field is set. + */ + boolean hasTenant(); + /** + * .grpc.Tenant tenant = 1; + * @return The tenant. + */ + io.trino.spi.grpc.Endpoints.Tenant getTenant(); + /** + * .grpc.Tenant tenant = 1; + */ + io.trino.spi.grpc.Endpoints.TenantOrBuilder getTenantOrBuilder(); + + /** + * string id = 2; + * @return The id. + */ + java.lang.String getId(); + /** + * string id = 2; + * @return The bytes for id. + */ + com.google.protobuf.ByteString + getIdBytes(); + + /** + * string name = 3; + * @return The name. + */ + java.lang.String getName(); + /** + * string name = 3; + * @return The bytes for name. + */ + com.google.protobuf.ByteString + getNameBytes(); + + /** + * string param_values = 4; + * @return The paramValues. + */ + java.lang.String getParamValues(); + /** + * string param_values = 4; + * @return The bytes for paramValues. + */ + com.google.protobuf.ByteString + getParamValuesBytes(); + + /** + * repeated .grpc.DataSourceInstanceInput data_sources = 5; + */ + java.util.List + getDataSourcesList(); + /** + * repeated .grpc.DataSourceInstanceInput data_sources = 5; + */ + io.trino.spi.grpc.Endpoints.DataSourceInstanceInput getDataSources(int index); + /** + * repeated .grpc.DataSourceInstanceInput data_sources = 5; + */ + int getDataSourcesCount(); + /** + * repeated .grpc.DataSourceInstanceInput data_sources = 5; + */ + java.util.List + getDataSourcesOrBuilderList(); + /** + * repeated .grpc.DataSourceInstanceInput data_sources = 5; + */ + io.trino.spi.grpc.Endpoints.DataSourceInstanceInputOrBuilder getDataSourcesOrBuilder( + int index); + + /** + * optional .grpc.BrokerRequest broker = 6; + * @return Whether the broker field is set. + */ + boolean hasBroker(); + /** + * optional .grpc.BrokerRequest broker = 6; + * @return The broker. + */ + io.trino.spi.grpc.Endpoints.BrokerRequest getBroker(); + /** + * optional .grpc.BrokerRequest broker = 6; + */ + io.trino.spi.grpc.Endpoints.BrokerRequestOrBuilder getBrokerOrBuilder(); + } + /** + * Protobuf type {@code grpc.ConnectorInstanceCreateRequest} + */ + public static final class ConnectorInstanceCreateRequest extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.ConnectorInstanceCreateRequest) + ConnectorInstanceCreateRequestOrBuilder { + private static final long serialVersionUID = 0L; + // Use ConnectorInstanceCreateRequest.newBuilder() to construct. + private ConnectorInstanceCreateRequest(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private ConnectorInstanceCreateRequest() { + id_ = ""; + name_ = ""; + paramValues_ = ""; + dataSources_ = java.util.Collections.emptyList(); + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new ConnectorInstanceCreateRequest(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_ConnectorInstanceCreateRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_ConnectorInstanceCreateRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest.class, io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest.Builder.class); + } + + private int bitField0_; + public static final int TENANT_FIELD_NUMBER = 1; + private io.trino.spi.grpc.Endpoints.Tenant tenant_; + /** + * .grpc.Tenant tenant = 1; + * @return Whether the tenant field is set. + */ + @java.lang.Override + public boolean hasTenant() { + return tenant_ != null; + } + /** + * .grpc.Tenant tenant = 1; + * @return The tenant. + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.Tenant getTenant() { + return tenant_ == null ? io.trino.spi.grpc.Endpoints.Tenant.getDefaultInstance() : tenant_; + } + /** + * .grpc.Tenant tenant = 1; + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.TenantOrBuilder getTenantOrBuilder() { + return tenant_ == null ? io.trino.spi.grpc.Endpoints.Tenant.getDefaultInstance() : tenant_; + } + + public static final int ID_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object id_ = ""; + /** + * string id = 2; + * @return The id. + */ + @java.lang.Override + public java.lang.String getId() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } + } + /** + * string id = 2; + * @return The bytes for id. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int NAME_FIELD_NUMBER = 3; + @SuppressWarnings("serial") + private volatile java.lang.Object name_ = ""; + /** + * string name = 3; + * @return The name. + */ + @java.lang.Override + public java.lang.String getName() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } + } + /** + * string name = 3; + * @return The bytes for name. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int PARAM_VALUES_FIELD_NUMBER = 4; + @SuppressWarnings("serial") + private volatile java.lang.Object paramValues_ = ""; + /** + * string param_values = 4; + * @return The paramValues. + */ + @java.lang.Override + public java.lang.String getParamValues() { + java.lang.Object ref = paramValues_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + paramValues_ = s; + return s; + } + } + /** + * string param_values = 4; + * @return The bytes for paramValues. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getParamValuesBytes() { + java.lang.Object ref = paramValues_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + paramValues_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int DATA_SOURCES_FIELD_NUMBER = 5; + @SuppressWarnings("serial") + private java.util.List dataSources_; + /** + * repeated .grpc.DataSourceInstanceInput data_sources = 5; + */ + @java.lang.Override + public java.util.List getDataSourcesList() { + return dataSources_; + } + /** + * repeated .grpc.DataSourceInstanceInput data_sources = 5; + */ + @java.lang.Override + public java.util.List + getDataSourcesOrBuilderList() { + return dataSources_; + } + /** + * repeated .grpc.DataSourceInstanceInput data_sources = 5; + */ + @java.lang.Override + public int getDataSourcesCount() { + return dataSources_.size(); + } + /** + * repeated .grpc.DataSourceInstanceInput data_sources = 5; + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceInstanceInput getDataSources(int index) { + return dataSources_.get(index); + } + /** + * repeated .grpc.DataSourceInstanceInput data_sources = 5; + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceInstanceInputOrBuilder getDataSourcesOrBuilder( + int index) { + return dataSources_.get(index); + } + + public static final int BROKER_FIELD_NUMBER = 6; + private io.trino.spi.grpc.Endpoints.BrokerRequest broker_; + /** + * optional .grpc.BrokerRequest broker = 6; + * @return Whether the broker field is set. + */ + @java.lang.Override + public boolean hasBroker() { + return ((bitField0_ & 0x00000001) != 0); + } + /** + * optional .grpc.BrokerRequest broker = 6; + * @return The broker. + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BrokerRequest getBroker() { + return broker_ == null ? io.trino.spi.grpc.Endpoints.BrokerRequest.getDefaultInstance() : broker_; + } + /** + * optional .grpc.BrokerRequest broker = 6; + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BrokerRequestOrBuilder getBrokerOrBuilder() { + return broker_ == null ? io.trino.spi.grpc.Endpoints.BrokerRequest.getDefaultInstance() : broker_; + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (tenant_ != null) { + output.writeMessage(1, getTenant()); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, id_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(name_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 3, name_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(paramValues_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 4, paramValues_); + } + for (int i = 0; i < dataSources_.size(); i++) { + output.writeMessage(5, dataSources_.get(i)); + } + if (((bitField0_ & 0x00000001) != 0)) { + output.writeMessage(6, getBroker()); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (tenant_ != null) { + size += com.google.protobuf.CodedOutputStream + .computeMessageSize(1, getTenant()); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, id_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(name_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(3, name_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(paramValues_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(4, paramValues_); + } + for (int i = 0; i < dataSources_.size(); i++) { + size += com.google.protobuf.CodedOutputStream + .computeMessageSize(5, dataSources_.get(i)); + } + if (((bitField0_ & 0x00000001) != 0)) { + size += com.google.protobuf.CodedOutputStream + .computeMessageSize(6, getBroker()); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest other = (io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest) obj; + + if (hasTenant() != other.hasTenant()) return false; + if (hasTenant()) { + if (!getTenant() + .equals(other.getTenant())) return false; + } + if (!getId() + .equals(other.getId())) return false; + if (!getName() + .equals(other.getName())) return false; + if (!getParamValues() + .equals(other.getParamValues())) return false; + if (!getDataSourcesList() + .equals(other.getDataSourcesList())) return false; + if (hasBroker() != other.hasBroker()) return false; + if (hasBroker()) { + if (!getBroker() + .equals(other.getBroker())) return false; + } + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + if (hasTenant()) { + hash = (37 * hash) + TENANT_FIELD_NUMBER; + hash = (53 * hash) + getTenant().hashCode(); + } + hash = (37 * hash) + ID_FIELD_NUMBER; + hash = (53 * hash) + getId().hashCode(); + hash = (37 * hash) + NAME_FIELD_NUMBER; + hash = (53 * hash) + getName().hashCode(); + hash = (37 * hash) + PARAM_VALUES_FIELD_NUMBER; + hash = (53 * hash) + getParamValues().hashCode(); + if (getDataSourcesCount() > 0) { + hash = (37 * hash) + DATA_SOURCES_FIELD_NUMBER; + hash = (53 * hash) + getDataSourcesList().hashCode(); + } + if (hasBroker()) { + hash = (37 * hash) + BROKER_FIELD_NUMBER; + hash = (53 * hash) + getBroker().hashCode(); + } + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.ConnectorInstanceCreateRequest} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.ConnectorInstanceCreateRequest) + io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequestOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_ConnectorInstanceCreateRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_ConnectorInstanceCreateRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest.class, io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest.newBuilder() + private Builder() { + maybeForceBuilderInitialization(); + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + maybeForceBuilderInitialization(); + } + private void maybeForceBuilderInitialization() { + if (com.google.protobuf.GeneratedMessageV3 + .alwaysUseFieldBuilders) { + getTenantFieldBuilder(); + getDataSourcesFieldBuilder(); + getBrokerFieldBuilder(); + } + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + tenant_ = null; + if (tenantBuilder_ != null) { + tenantBuilder_.dispose(); + tenantBuilder_ = null; + } + id_ = ""; + name_ = ""; + paramValues_ = ""; + if (dataSourcesBuilder_ == null) { + dataSources_ = java.util.Collections.emptyList(); + } else { + dataSources_ = null; + dataSourcesBuilder_.clear(); + } + bitField0_ = (bitField0_ & ~0x00000010); + broker_ = null; + if (brokerBuilder_ != null) { + brokerBuilder_.dispose(); + brokerBuilder_ = null; + } + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_ConnectorInstanceCreateRequest_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest build() { + io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest buildPartial() { + io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest result = new io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest(this); + buildPartialRepeatedFields(result); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartialRepeatedFields(io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest result) { + if (dataSourcesBuilder_ == null) { + if (((bitField0_ & 0x00000010) != 0)) { + dataSources_ = java.util.Collections.unmodifiableList(dataSources_); + bitField0_ = (bitField0_ & ~0x00000010); + } + result.dataSources_ = dataSources_; + } else { + result.dataSources_ = dataSourcesBuilder_.build(); + } + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.tenant_ = tenantBuilder_ == null + ? tenant_ + : tenantBuilder_.build(); + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.id_ = id_; + } + if (((from_bitField0_ & 0x00000004) != 0)) { + result.name_ = name_; + } + if (((from_bitField0_ & 0x00000008) != 0)) { + result.paramValues_ = paramValues_; + } + int to_bitField0_ = 0; + if (((from_bitField0_ & 0x00000020) != 0)) { + result.broker_ = brokerBuilder_ == null + ? broker_ + : brokerBuilder_.build(); + to_bitField0_ |= 0x00000001; + } + result.bitField0_ |= to_bitField0_; + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest) { + return mergeFrom((io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest other) { + if (other == io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest.getDefaultInstance()) return this; + if (other.hasTenant()) { + mergeTenant(other.getTenant()); + } + if (!other.getId().isEmpty()) { + id_ = other.id_; + bitField0_ |= 0x00000002; + onChanged(); + } + if (!other.getName().isEmpty()) { + name_ = other.name_; + bitField0_ |= 0x00000004; + onChanged(); + } + if (!other.getParamValues().isEmpty()) { + paramValues_ = other.paramValues_; + bitField0_ |= 0x00000008; + onChanged(); + } + if (dataSourcesBuilder_ == null) { + if (!other.dataSources_.isEmpty()) { + if (dataSources_.isEmpty()) { + dataSources_ = other.dataSources_; + bitField0_ = (bitField0_ & ~0x00000010); + } else { + ensureDataSourcesIsMutable(); + dataSources_.addAll(other.dataSources_); + } + onChanged(); + } + } else { + if (!other.dataSources_.isEmpty()) { + if (dataSourcesBuilder_.isEmpty()) { + dataSourcesBuilder_.dispose(); + dataSourcesBuilder_ = null; + dataSources_ = other.dataSources_; + bitField0_ = (bitField0_ & ~0x00000010); + dataSourcesBuilder_ = + com.google.protobuf.GeneratedMessageV3.alwaysUseFieldBuilders ? + getDataSourcesFieldBuilder() : null; + } else { + dataSourcesBuilder_.addAllMessages(other.dataSources_); + } + } + } + if (other.hasBroker()) { + mergeBroker(other.getBroker()); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + input.readMessage( + getTenantFieldBuilder().getBuilder(), + extensionRegistry); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + id_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + case 26: { + name_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000004; + break; + } // case 26 + case 34: { + paramValues_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000008; + break; + } // case 34 + case 42: { + io.trino.spi.grpc.Endpoints.DataSourceInstanceInput m = + input.readMessage( + io.trino.spi.grpc.Endpoints.DataSourceInstanceInput.parser(), + extensionRegistry); + if (dataSourcesBuilder_ == null) { + ensureDataSourcesIsMutable(); + dataSources_.add(m); + } else { + dataSourcesBuilder_.addMessage(m); + } + break; + } // case 42 + case 50: { + input.readMessage( + getBrokerFieldBuilder().getBuilder(), + extensionRegistry); + bitField0_ |= 0x00000020; + break; + } // case 50 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private io.trino.spi.grpc.Endpoints.Tenant tenant_; + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.Tenant, io.trino.spi.grpc.Endpoints.Tenant.Builder, io.trino.spi.grpc.Endpoints.TenantOrBuilder> tenantBuilder_; + /** + * .grpc.Tenant tenant = 1; + * @return Whether the tenant field is set. + */ + public boolean hasTenant() { + return ((bitField0_ & 0x00000001) != 0); + } + /** + * .grpc.Tenant tenant = 1; + * @return The tenant. + */ + public io.trino.spi.grpc.Endpoints.Tenant getTenant() { + if (tenantBuilder_ == null) { + return tenant_ == null ? io.trino.spi.grpc.Endpoints.Tenant.getDefaultInstance() : tenant_; + } else { + return tenantBuilder_.getMessage(); + } + } + /** + * .grpc.Tenant tenant = 1; + */ + public Builder setTenant(io.trino.spi.grpc.Endpoints.Tenant value) { + if (tenantBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + tenant_ = value; + } else { + tenantBuilder_.setMessage(value); + } + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * .grpc.Tenant tenant = 1; + */ + public Builder setTenant( + io.trino.spi.grpc.Endpoints.Tenant.Builder builderForValue) { + if (tenantBuilder_ == null) { + tenant_ = builderForValue.build(); + } else { + tenantBuilder_.setMessage(builderForValue.build()); + } + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * .grpc.Tenant tenant = 1; + */ + public Builder mergeTenant(io.trino.spi.grpc.Endpoints.Tenant value) { + if (tenantBuilder_ == null) { + if (((bitField0_ & 0x00000001) != 0) && + tenant_ != null && + tenant_ != io.trino.spi.grpc.Endpoints.Tenant.getDefaultInstance()) { + getTenantBuilder().mergeFrom(value); + } else { + tenant_ = value; + } + } else { + tenantBuilder_.mergeFrom(value); + } + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * .grpc.Tenant tenant = 1; + */ + public Builder clearTenant() { + bitField0_ = (bitField0_ & ~0x00000001); + tenant_ = null; + if (tenantBuilder_ != null) { + tenantBuilder_.dispose(); + tenantBuilder_ = null; + } + onChanged(); + return this; + } + /** + * .grpc.Tenant tenant = 1; + */ + public io.trino.spi.grpc.Endpoints.Tenant.Builder getTenantBuilder() { + bitField0_ |= 0x00000001; + onChanged(); + return getTenantFieldBuilder().getBuilder(); + } + /** + * .grpc.Tenant tenant = 1; + */ + public io.trino.spi.grpc.Endpoints.TenantOrBuilder getTenantOrBuilder() { + if (tenantBuilder_ != null) { + return tenantBuilder_.getMessageOrBuilder(); + } else { + return tenant_ == null ? + io.trino.spi.grpc.Endpoints.Tenant.getDefaultInstance() : tenant_; + } + } + /** + * .grpc.Tenant tenant = 1; + */ + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.Tenant, io.trino.spi.grpc.Endpoints.Tenant.Builder, io.trino.spi.grpc.Endpoints.TenantOrBuilder> + getTenantFieldBuilder() { + if (tenantBuilder_ == null) { + tenantBuilder_ = new com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.Tenant, io.trino.spi.grpc.Endpoints.Tenant.Builder, io.trino.spi.grpc.Endpoints.TenantOrBuilder>( + getTenant(), + getParentForChildren(), + isClean()); + tenant_ = null; + } + return tenantBuilder_; + } + + private java.lang.Object id_ = ""; + /** + * string id = 2; + * @return The id. + */ + public java.lang.String getId() { + java.lang.Object ref = id_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string id = 2; + * @return The bytes for id. + */ + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string id = 2; + * @param value The id to set. + * @return This builder for chaining. + */ + public Builder setId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + id_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string id = 2; + * @return This builder for chaining. + */ + public Builder clearId() { + id_ = getDefaultInstance().getId(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string id = 2; + * @param value The bytes for id to set. + * @return This builder for chaining. + */ + public Builder setIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + id_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + + private java.lang.Object name_ = ""; + /** + * string name = 3; + * @return The name. + */ + public java.lang.String getName() { + java.lang.Object ref = name_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string name = 3; + * @return The bytes for name. + */ + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string name = 3; + * @param value The name to set. + * @return This builder for chaining. + */ + public Builder setName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + name_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + /** + * string name = 3; + * @return This builder for chaining. + */ + public Builder clearName() { + name_ = getDefaultInstance().getName(); + bitField0_ = (bitField0_ & ~0x00000004); + onChanged(); + return this; + } + /** + * string name = 3; + * @param value The bytes for name to set. + * @return This builder for chaining. + */ + public Builder setNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + name_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + + private java.lang.Object paramValues_ = ""; + /** + * string param_values = 4; + * @return The paramValues. + */ + public java.lang.String getParamValues() { + java.lang.Object ref = paramValues_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + paramValues_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string param_values = 4; + * @return The bytes for paramValues. + */ + public com.google.protobuf.ByteString + getParamValuesBytes() { + java.lang.Object ref = paramValues_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + paramValues_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string param_values = 4; + * @param value The paramValues to set. + * @return This builder for chaining. + */ + public Builder setParamValues( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + paramValues_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + /** + * string param_values = 4; + * @return This builder for chaining. + */ + public Builder clearParamValues() { + paramValues_ = getDefaultInstance().getParamValues(); + bitField0_ = (bitField0_ & ~0x00000008); + onChanged(); + return this; + } + /** + * string param_values = 4; + * @param value The bytes for paramValues to set. + * @return This builder for chaining. + */ + public Builder setParamValuesBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + paramValues_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + + private java.util.List dataSources_ = + java.util.Collections.emptyList(); + private void ensureDataSourcesIsMutable() { + if (!((bitField0_ & 0x00000010) != 0)) { + dataSources_ = new java.util.ArrayList(dataSources_); + bitField0_ |= 0x00000010; + } + } + + private com.google.protobuf.RepeatedFieldBuilderV3< + io.trino.spi.grpc.Endpoints.DataSourceInstanceInput, io.trino.spi.grpc.Endpoints.DataSourceInstanceInput.Builder, io.trino.spi.grpc.Endpoints.DataSourceInstanceInputOrBuilder> dataSourcesBuilder_; + + /** + * repeated .grpc.DataSourceInstanceInput data_sources = 5; + */ + public java.util.List getDataSourcesList() { + if (dataSourcesBuilder_ == null) { + return java.util.Collections.unmodifiableList(dataSources_); + } else { + return dataSourcesBuilder_.getMessageList(); + } + } + /** + * repeated .grpc.DataSourceInstanceInput data_sources = 5; + */ + public int getDataSourcesCount() { + if (dataSourcesBuilder_ == null) { + return dataSources_.size(); + } else { + return dataSourcesBuilder_.getCount(); + } + } + /** + * repeated .grpc.DataSourceInstanceInput data_sources = 5; + */ + public io.trino.spi.grpc.Endpoints.DataSourceInstanceInput getDataSources(int index) { + if (dataSourcesBuilder_ == null) { + return dataSources_.get(index); + } else { + return dataSourcesBuilder_.getMessage(index); + } + } + /** + * repeated .grpc.DataSourceInstanceInput data_sources = 5; + */ + public Builder setDataSources( + int index, io.trino.spi.grpc.Endpoints.DataSourceInstanceInput value) { + if (dataSourcesBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + ensureDataSourcesIsMutable(); + dataSources_.set(index, value); + onChanged(); + } else { + dataSourcesBuilder_.setMessage(index, value); + } + return this; + } + /** + * repeated .grpc.DataSourceInstanceInput data_sources = 5; + */ + public Builder setDataSources( + int index, io.trino.spi.grpc.Endpoints.DataSourceInstanceInput.Builder builderForValue) { + if (dataSourcesBuilder_ == null) { + ensureDataSourcesIsMutable(); + dataSources_.set(index, builderForValue.build()); + onChanged(); + } else { + dataSourcesBuilder_.setMessage(index, builderForValue.build()); + } + return this; + } + /** + * repeated .grpc.DataSourceInstanceInput data_sources = 5; + */ + public Builder addDataSources(io.trino.spi.grpc.Endpoints.DataSourceInstanceInput value) { + if (dataSourcesBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + ensureDataSourcesIsMutable(); + dataSources_.add(value); + onChanged(); + } else { + dataSourcesBuilder_.addMessage(value); + } + return this; + } + /** + * repeated .grpc.DataSourceInstanceInput data_sources = 5; + */ + public Builder addDataSources( + int index, io.trino.spi.grpc.Endpoints.DataSourceInstanceInput value) { + if (dataSourcesBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + ensureDataSourcesIsMutable(); + dataSources_.add(index, value); + onChanged(); + } else { + dataSourcesBuilder_.addMessage(index, value); + } + return this; + } + /** + * repeated .grpc.DataSourceInstanceInput data_sources = 5; + */ + public Builder addDataSources( + io.trino.spi.grpc.Endpoints.DataSourceInstanceInput.Builder builderForValue) { + if (dataSourcesBuilder_ == null) { + ensureDataSourcesIsMutable(); + dataSources_.add(builderForValue.build()); + onChanged(); + } else { + dataSourcesBuilder_.addMessage(builderForValue.build()); + } + return this; + } + /** + * repeated .grpc.DataSourceInstanceInput data_sources = 5; + */ + public Builder addDataSources( + int index, io.trino.spi.grpc.Endpoints.DataSourceInstanceInput.Builder builderForValue) { + if (dataSourcesBuilder_ == null) { + ensureDataSourcesIsMutable(); + dataSources_.add(index, builderForValue.build()); + onChanged(); + } else { + dataSourcesBuilder_.addMessage(index, builderForValue.build()); + } + return this; + } + /** + * repeated .grpc.DataSourceInstanceInput data_sources = 5; + */ + public Builder addAllDataSources( + java.lang.Iterable values) { + if (dataSourcesBuilder_ == null) { + ensureDataSourcesIsMutable(); + com.google.protobuf.AbstractMessageLite.Builder.addAll( + values, dataSources_); + onChanged(); + } else { + dataSourcesBuilder_.addAllMessages(values); + } + return this; + } + /** + * repeated .grpc.DataSourceInstanceInput data_sources = 5; + */ + public Builder clearDataSources() { + if (dataSourcesBuilder_ == null) { + dataSources_ = java.util.Collections.emptyList(); + bitField0_ = (bitField0_ & ~0x00000010); + onChanged(); + } else { + dataSourcesBuilder_.clear(); + } + return this; + } + /** + * repeated .grpc.DataSourceInstanceInput data_sources = 5; + */ + public Builder removeDataSources(int index) { + if (dataSourcesBuilder_ == null) { + ensureDataSourcesIsMutable(); + dataSources_.remove(index); + onChanged(); + } else { + dataSourcesBuilder_.remove(index); + } + return this; + } + /** + * repeated .grpc.DataSourceInstanceInput data_sources = 5; + */ + public io.trino.spi.grpc.Endpoints.DataSourceInstanceInput.Builder getDataSourcesBuilder( + int index) { + return getDataSourcesFieldBuilder().getBuilder(index); + } + /** + * repeated .grpc.DataSourceInstanceInput data_sources = 5; + */ + public io.trino.spi.grpc.Endpoints.DataSourceInstanceInputOrBuilder getDataSourcesOrBuilder( + int index) { + if (dataSourcesBuilder_ == null) { + return dataSources_.get(index); } else { + return dataSourcesBuilder_.getMessageOrBuilder(index); + } + } + /** + * repeated .grpc.DataSourceInstanceInput data_sources = 5; + */ + public java.util.List + getDataSourcesOrBuilderList() { + if (dataSourcesBuilder_ != null) { + return dataSourcesBuilder_.getMessageOrBuilderList(); + } else { + return java.util.Collections.unmodifiableList(dataSources_); + } + } + /** + * repeated .grpc.DataSourceInstanceInput data_sources = 5; + */ + public io.trino.spi.grpc.Endpoints.DataSourceInstanceInput.Builder addDataSourcesBuilder() { + return getDataSourcesFieldBuilder().addBuilder( + io.trino.spi.grpc.Endpoints.DataSourceInstanceInput.getDefaultInstance()); + } + /** + * repeated .grpc.DataSourceInstanceInput data_sources = 5; + */ + public io.trino.spi.grpc.Endpoints.DataSourceInstanceInput.Builder addDataSourcesBuilder( + int index) { + return getDataSourcesFieldBuilder().addBuilder( + index, io.trino.spi.grpc.Endpoints.DataSourceInstanceInput.getDefaultInstance()); + } + /** + * repeated .grpc.DataSourceInstanceInput data_sources = 5; + */ + public java.util.List + getDataSourcesBuilderList() { + return getDataSourcesFieldBuilder().getBuilderList(); + } + private com.google.protobuf.RepeatedFieldBuilderV3< + io.trino.spi.grpc.Endpoints.DataSourceInstanceInput, io.trino.spi.grpc.Endpoints.DataSourceInstanceInput.Builder, io.trino.spi.grpc.Endpoints.DataSourceInstanceInputOrBuilder> + getDataSourcesFieldBuilder() { + if (dataSourcesBuilder_ == null) { + dataSourcesBuilder_ = new com.google.protobuf.RepeatedFieldBuilderV3< + io.trino.spi.grpc.Endpoints.DataSourceInstanceInput, io.trino.spi.grpc.Endpoints.DataSourceInstanceInput.Builder, io.trino.spi.grpc.Endpoints.DataSourceInstanceInputOrBuilder>( + dataSources_, + ((bitField0_ & 0x00000010) != 0), + getParentForChildren(), + isClean()); + dataSources_ = null; + } + return dataSourcesBuilder_; + } + + private io.trino.spi.grpc.Endpoints.BrokerRequest broker_; + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.BrokerRequest, io.trino.spi.grpc.Endpoints.BrokerRequest.Builder, io.trino.spi.grpc.Endpoints.BrokerRequestOrBuilder> brokerBuilder_; + /** + * optional .grpc.BrokerRequest broker = 6; + * @return Whether the broker field is set. + */ + public boolean hasBroker() { + return ((bitField0_ & 0x00000020) != 0); + } + /** + * optional .grpc.BrokerRequest broker = 6; + * @return The broker. + */ + public io.trino.spi.grpc.Endpoints.BrokerRequest getBroker() { + if (brokerBuilder_ == null) { + return broker_ == null ? io.trino.spi.grpc.Endpoints.BrokerRequest.getDefaultInstance() : broker_; + } else { + return brokerBuilder_.getMessage(); + } + } + /** + * optional .grpc.BrokerRequest broker = 6; + */ + public Builder setBroker(io.trino.spi.grpc.Endpoints.BrokerRequest value) { + if (brokerBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + broker_ = value; + } else { + brokerBuilder_.setMessage(value); + } + bitField0_ |= 0x00000020; + onChanged(); + return this; + } + /** + * optional .grpc.BrokerRequest broker = 6; + */ + public Builder setBroker( + io.trino.spi.grpc.Endpoints.BrokerRequest.Builder builderForValue) { + if (brokerBuilder_ == null) { + broker_ = builderForValue.build(); + } else { + brokerBuilder_.setMessage(builderForValue.build()); + } + bitField0_ |= 0x00000020; + onChanged(); + return this; + } + /** + * optional .grpc.BrokerRequest broker = 6; + */ + public Builder mergeBroker(io.trino.spi.grpc.Endpoints.BrokerRequest value) { + if (brokerBuilder_ == null) { + if (((bitField0_ & 0x00000020) != 0) && + broker_ != null && + broker_ != io.trino.spi.grpc.Endpoints.BrokerRequest.getDefaultInstance()) { + getBrokerBuilder().mergeFrom(value); + } else { + broker_ = value; + } + } else { + brokerBuilder_.mergeFrom(value); + } + bitField0_ |= 0x00000020; + onChanged(); + return this; + } + /** + * optional .grpc.BrokerRequest broker = 6; + */ + public Builder clearBroker() { + bitField0_ = (bitField0_ & ~0x00000020); + broker_ = null; + if (brokerBuilder_ != null) { + brokerBuilder_.dispose(); + brokerBuilder_ = null; + } + onChanged(); + return this; + } + /** + * optional .grpc.BrokerRequest broker = 6; + */ + public io.trino.spi.grpc.Endpoints.BrokerRequest.Builder getBrokerBuilder() { + bitField0_ |= 0x00000020; + onChanged(); + return getBrokerFieldBuilder().getBuilder(); + } + /** + * optional .grpc.BrokerRequest broker = 6; + */ + public io.trino.spi.grpc.Endpoints.BrokerRequestOrBuilder getBrokerOrBuilder() { + if (brokerBuilder_ != null) { + return brokerBuilder_.getMessageOrBuilder(); + } else { + return broker_ == null ? + io.trino.spi.grpc.Endpoints.BrokerRequest.getDefaultInstance() : broker_; + } + } + /** + * optional .grpc.BrokerRequest broker = 6; + */ + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.BrokerRequest, io.trino.spi.grpc.Endpoints.BrokerRequest.Builder, io.trino.spi.grpc.Endpoints.BrokerRequestOrBuilder> + getBrokerFieldBuilder() { + if (brokerBuilder_ == null) { + brokerBuilder_ = new com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.BrokerRequest, io.trino.spi.grpc.Endpoints.BrokerRequest.Builder, io.trino.spi.grpc.Endpoints.BrokerRequestOrBuilder>( + getBroker(), + getParentForChildren(), + isClean()); + broker_ = null; + } + return brokerBuilder_; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.ConnectorInstanceCreateRequest) + } + + // @@protoc_insertion_point(class_scope:grpc.ConnectorInstanceCreateRequest) + private static final io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest(); + } + + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public ConnectorInstanceCreateRequest parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface DataSourceListOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.DataSourceList) + com.google.protobuf.MessageOrBuilder { + + /** + * repeated .grpc.DataSourceInstanceInput sources = 1; + */ + java.util.List + getSourcesList(); + /** + * repeated .grpc.DataSourceInstanceInput sources = 1; + */ + io.trino.spi.grpc.Endpoints.DataSourceInstanceInput getSources(int index); + /** + * repeated .grpc.DataSourceInstanceInput sources = 1; + */ + int getSourcesCount(); + /** + * repeated .grpc.DataSourceInstanceInput sources = 1; + */ + java.util.List + getSourcesOrBuilderList(); + /** + * repeated .grpc.DataSourceInstanceInput sources = 1; + */ + io.trino.spi.grpc.Endpoints.DataSourceInstanceInputOrBuilder getSourcesOrBuilder( + int index); + } + /** + *
+   * This wrapper is defined for using oneof on repeated DataSource
+   * 
+ * + * Protobuf type {@code grpc.DataSourceList} + */ + public static final class DataSourceList extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.DataSourceList) + DataSourceListOrBuilder { + private static final long serialVersionUID = 0L; + // Use DataSourceList.newBuilder() to construct. + private DataSourceList(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private DataSourceList() { + sources_ = java.util.Collections.emptyList(); + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new DataSourceList(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSourceList_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSourceList_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.DataSourceList.class, io.trino.spi.grpc.Endpoints.DataSourceList.Builder.class); + } + + public static final int SOURCES_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private java.util.List sources_; + /** + * repeated .grpc.DataSourceInstanceInput sources = 1; + */ + @java.lang.Override + public java.util.List getSourcesList() { + return sources_; + } + /** + * repeated .grpc.DataSourceInstanceInput sources = 1; + */ + @java.lang.Override + public java.util.List + getSourcesOrBuilderList() { + return sources_; + } + /** + * repeated .grpc.DataSourceInstanceInput sources = 1; + */ + @java.lang.Override + public int getSourcesCount() { + return sources_.size(); + } + /** + * repeated .grpc.DataSourceInstanceInput sources = 1; + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceInstanceInput getSources(int index) { + return sources_.get(index); + } + /** + * repeated .grpc.DataSourceInstanceInput sources = 1; + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceInstanceInputOrBuilder getSourcesOrBuilder( + int index) { + return sources_.get(index); + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + for (int i = 0; i < sources_.size(); i++) { + output.writeMessage(1, sources_.get(i)); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + for (int i = 0; i < sources_.size(); i++) { + size += com.google.protobuf.CodedOutputStream + .computeMessageSize(1, sources_.get(i)); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.DataSourceList)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.DataSourceList other = (io.trino.spi.grpc.Endpoints.DataSourceList) obj; + + if (!getSourcesList() + .equals(other.getSourcesList())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + if (getSourcesCount() > 0) { + hash = (37 * hash) + SOURCES_FIELD_NUMBER; + hash = (53 * hash) + getSourcesList().hashCode(); + } + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.DataSourceList parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.DataSourceList parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.DataSourceList parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.DataSourceList parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.DataSourceList parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.DataSourceList parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.DataSourceList parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.DataSourceList parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.DataSourceList parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.DataSourceList parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.DataSourceList parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.DataSourceList parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.DataSourceList prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + *
+     * This wrapper is defined for using oneof on repeated DataSource
+     * 
+ * + * Protobuf type {@code grpc.DataSourceList} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.DataSourceList) + io.trino.spi.grpc.Endpoints.DataSourceListOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSourceList_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSourceList_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.DataSourceList.class, io.trino.spi.grpc.Endpoints.DataSourceList.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.DataSourceList.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + if (sourcesBuilder_ == null) { + sources_ = java.util.Collections.emptyList(); + } else { + sources_ = null; + sourcesBuilder_.clear(); + } + bitField0_ = (bitField0_ & ~0x00000001); + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSourceList_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceList getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.DataSourceList.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceList build() { + io.trino.spi.grpc.Endpoints.DataSourceList result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceList buildPartial() { + io.trino.spi.grpc.Endpoints.DataSourceList result = new io.trino.spi.grpc.Endpoints.DataSourceList(this); + buildPartialRepeatedFields(result); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartialRepeatedFields(io.trino.spi.grpc.Endpoints.DataSourceList result) { + if (sourcesBuilder_ == null) { + if (((bitField0_ & 0x00000001) != 0)) { + sources_ = java.util.Collections.unmodifiableList(sources_); + bitField0_ = (bitField0_ & ~0x00000001); + } + result.sources_ = sources_; + } else { + result.sources_ = sourcesBuilder_.build(); + } + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.DataSourceList result) { + int from_bitField0_ = bitField0_; + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.DataSourceList) { + return mergeFrom((io.trino.spi.grpc.Endpoints.DataSourceList)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.DataSourceList other) { + if (other == io.trino.spi.grpc.Endpoints.DataSourceList.getDefaultInstance()) return this; + if (sourcesBuilder_ == null) { + if (!other.sources_.isEmpty()) { + if (sources_.isEmpty()) { + sources_ = other.sources_; + bitField0_ = (bitField0_ & ~0x00000001); + } else { + ensureSourcesIsMutable(); + sources_.addAll(other.sources_); + } + onChanged(); + } + } else { + if (!other.sources_.isEmpty()) { + if (sourcesBuilder_.isEmpty()) { + sourcesBuilder_.dispose(); + sourcesBuilder_ = null; + sources_ = other.sources_; + bitField0_ = (bitField0_ & ~0x00000001); + sourcesBuilder_ = + com.google.protobuf.GeneratedMessageV3.alwaysUseFieldBuilders ? + getSourcesFieldBuilder() : null; + } else { + sourcesBuilder_.addAllMessages(other.sources_); + } + } + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + io.trino.spi.grpc.Endpoints.DataSourceInstanceInput m = + input.readMessage( + io.trino.spi.grpc.Endpoints.DataSourceInstanceInput.parser(), + extensionRegistry); + if (sourcesBuilder_ == null) { + ensureSourcesIsMutable(); + sources_.add(m); + } else { + sourcesBuilder_.addMessage(m); + } + break; + } // case 10 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.util.List sources_ = + java.util.Collections.emptyList(); + private void ensureSourcesIsMutable() { + if (!((bitField0_ & 0x00000001) != 0)) { + sources_ = new java.util.ArrayList(sources_); + bitField0_ |= 0x00000001; + } + } + + private com.google.protobuf.RepeatedFieldBuilderV3< + io.trino.spi.grpc.Endpoints.DataSourceInstanceInput, io.trino.spi.grpc.Endpoints.DataSourceInstanceInput.Builder, io.trino.spi.grpc.Endpoints.DataSourceInstanceInputOrBuilder> sourcesBuilder_; + + /** + * repeated .grpc.DataSourceInstanceInput sources = 1; + */ + public java.util.List getSourcesList() { + if (sourcesBuilder_ == null) { + return java.util.Collections.unmodifiableList(sources_); + } else { + return sourcesBuilder_.getMessageList(); + } + } + /** + * repeated .grpc.DataSourceInstanceInput sources = 1; + */ + public int getSourcesCount() { + if (sourcesBuilder_ == null) { + return sources_.size(); + } else { + return sourcesBuilder_.getCount(); + } + } + /** + * repeated .grpc.DataSourceInstanceInput sources = 1; + */ + public io.trino.spi.grpc.Endpoints.DataSourceInstanceInput getSources(int index) { + if (sourcesBuilder_ == null) { + return sources_.get(index); + } else { + return sourcesBuilder_.getMessage(index); + } + } + /** + * repeated .grpc.DataSourceInstanceInput sources = 1; + */ + public Builder setSources( + int index, io.trino.spi.grpc.Endpoints.DataSourceInstanceInput value) { + if (sourcesBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + ensureSourcesIsMutable(); + sources_.set(index, value); + onChanged(); + } else { + sourcesBuilder_.setMessage(index, value); + } + return this; + } + /** + * repeated .grpc.DataSourceInstanceInput sources = 1; + */ + public Builder setSources( + int index, io.trino.spi.grpc.Endpoints.DataSourceInstanceInput.Builder builderForValue) { + if (sourcesBuilder_ == null) { + ensureSourcesIsMutable(); + sources_.set(index, builderForValue.build()); + onChanged(); + } else { + sourcesBuilder_.setMessage(index, builderForValue.build()); + } + return this; + } + /** + * repeated .grpc.DataSourceInstanceInput sources = 1; + */ + public Builder addSources(io.trino.spi.grpc.Endpoints.DataSourceInstanceInput value) { + if (sourcesBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + ensureSourcesIsMutable(); + sources_.add(value); + onChanged(); + } else { + sourcesBuilder_.addMessage(value); + } + return this; + } + /** + * repeated .grpc.DataSourceInstanceInput sources = 1; + */ + public Builder addSources( + int index, io.trino.spi.grpc.Endpoints.DataSourceInstanceInput value) { + if (sourcesBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + ensureSourcesIsMutable(); + sources_.add(index, value); + onChanged(); + } else { + sourcesBuilder_.addMessage(index, value); + } + return this; + } + /** + * repeated .grpc.DataSourceInstanceInput sources = 1; + */ + public Builder addSources( + io.trino.spi.grpc.Endpoints.DataSourceInstanceInput.Builder builderForValue) { + if (sourcesBuilder_ == null) { + ensureSourcesIsMutable(); + sources_.add(builderForValue.build()); + onChanged(); + } else { + sourcesBuilder_.addMessage(builderForValue.build()); + } + return this; + } + /** + * repeated .grpc.DataSourceInstanceInput sources = 1; + */ + public Builder addSources( + int index, io.trino.spi.grpc.Endpoints.DataSourceInstanceInput.Builder builderForValue) { + if (sourcesBuilder_ == null) { + ensureSourcesIsMutable(); + sources_.add(index, builderForValue.build()); + onChanged(); + } else { + sourcesBuilder_.addMessage(index, builderForValue.build()); + } + return this; + } + /** + * repeated .grpc.DataSourceInstanceInput sources = 1; + */ + public Builder addAllSources( + java.lang.Iterable values) { + if (sourcesBuilder_ == null) { + ensureSourcesIsMutable(); + com.google.protobuf.AbstractMessageLite.Builder.addAll( + values, sources_); + onChanged(); + } else { + sourcesBuilder_.addAllMessages(values); + } + return this; + } + /** + * repeated .grpc.DataSourceInstanceInput sources = 1; + */ + public Builder clearSources() { + if (sourcesBuilder_ == null) { + sources_ = java.util.Collections.emptyList(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + } else { + sourcesBuilder_.clear(); + } + return this; + } + /** + * repeated .grpc.DataSourceInstanceInput sources = 1; + */ + public Builder removeSources(int index) { + if (sourcesBuilder_ == null) { + ensureSourcesIsMutable(); + sources_.remove(index); + onChanged(); + } else { + sourcesBuilder_.remove(index); + } + return this; + } + /** + * repeated .grpc.DataSourceInstanceInput sources = 1; + */ + public io.trino.spi.grpc.Endpoints.DataSourceInstanceInput.Builder getSourcesBuilder( + int index) { + return getSourcesFieldBuilder().getBuilder(index); + } + /** + * repeated .grpc.DataSourceInstanceInput sources = 1; + */ + public io.trino.spi.grpc.Endpoints.DataSourceInstanceInputOrBuilder getSourcesOrBuilder( + int index) { + if (sourcesBuilder_ == null) { + return sources_.get(index); } else { + return sourcesBuilder_.getMessageOrBuilder(index); + } + } + /** + * repeated .grpc.DataSourceInstanceInput sources = 1; + */ + public java.util.List + getSourcesOrBuilderList() { + if (sourcesBuilder_ != null) { + return sourcesBuilder_.getMessageOrBuilderList(); + } else { + return java.util.Collections.unmodifiableList(sources_); + } + } + /** + * repeated .grpc.DataSourceInstanceInput sources = 1; + */ + public io.trino.spi.grpc.Endpoints.DataSourceInstanceInput.Builder addSourcesBuilder() { + return getSourcesFieldBuilder().addBuilder( + io.trino.spi.grpc.Endpoints.DataSourceInstanceInput.getDefaultInstance()); + } + /** + * repeated .grpc.DataSourceInstanceInput sources = 1; + */ + public io.trino.spi.grpc.Endpoints.DataSourceInstanceInput.Builder addSourcesBuilder( + int index) { + return getSourcesFieldBuilder().addBuilder( + index, io.trino.spi.grpc.Endpoints.DataSourceInstanceInput.getDefaultInstance()); + } + /** + * repeated .grpc.DataSourceInstanceInput sources = 1; + */ + public java.util.List + getSourcesBuilderList() { + return getSourcesFieldBuilder().getBuilderList(); + } + private com.google.protobuf.RepeatedFieldBuilderV3< + io.trino.spi.grpc.Endpoints.DataSourceInstanceInput, io.trino.spi.grpc.Endpoints.DataSourceInstanceInput.Builder, io.trino.spi.grpc.Endpoints.DataSourceInstanceInputOrBuilder> + getSourcesFieldBuilder() { + if (sourcesBuilder_ == null) { + sourcesBuilder_ = new com.google.protobuf.RepeatedFieldBuilderV3< + io.trino.spi.grpc.Endpoints.DataSourceInstanceInput, io.trino.spi.grpc.Endpoints.DataSourceInstanceInput.Builder, io.trino.spi.grpc.Endpoints.DataSourceInstanceInputOrBuilder>( + sources_, + ((bitField0_ & 0x00000001) != 0), + getParentForChildren(), + isClean()); + sources_ = null; + } + return sourcesBuilder_; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.DataSourceList) + } + + // @@protoc_insertion_point(class_scope:grpc.DataSourceList) + private static final io.trino.spi.grpc.Endpoints.DataSourceList DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.DataSourceList(); + } + + public static io.trino.spi.grpc.Endpoints.DataSourceList getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public DataSourceList parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceList getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface ConnectorInstanceEditRequestOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.ConnectorInstanceEditRequest) + com.google.protobuf.MessageOrBuilder { + + /** + * .grpc.Tenant tenant = 1; + * @return Whether the tenant field is set. + */ + boolean hasTenant(); + /** + * .grpc.Tenant tenant = 1; + * @return The tenant. + */ + io.trino.spi.grpc.Endpoints.Tenant getTenant(); + /** + * .grpc.Tenant tenant = 1; + */ + io.trino.spi.grpc.Endpoints.TenantOrBuilder getTenantOrBuilder(); + + /** + * string id = 2; + * @return The id. + */ + java.lang.String getId(); + /** + * string id = 2; + * @return The bytes for id. + */ + com.google.protobuf.ByteString + getIdBytes(); + + /** + * optional string name = 3; + * @return Whether the name field is set. + */ + boolean hasName(); + /** + * optional string name = 3; + * @return The name. + */ + java.lang.String getName(); + /** + * optional string name = 3; + * @return The bytes for name. + */ + com.google.protobuf.ByteString + getNameBytes(); + + /** + * optional string param_values = 4; + * @return Whether the paramValues field is set. + */ + boolean hasParamValues(); + /** + * optional string param_values = 4; + * @return The paramValues. + */ + java.lang.String getParamValues(); + /** + * optional string param_values = 4; + * @return The bytes for paramValues. + */ + com.google.protobuf.ByteString + getParamValuesBytes(); + + /** + *
+     * Represent nil.
+     * 
+ * + * .grpc.EmptyRequest no_data_sources = 5; + * @return Whether the noDataSources field is set. + */ + boolean hasNoDataSources(); + /** + *
+     * Represent nil.
+     * 
+ * + * .grpc.EmptyRequest no_data_sources = 5; + * @return The noDataSources. + */ + io.trino.spi.grpc.Endpoints.EmptyRequest getNoDataSources(); + /** + *
+     * Represent nil.
+     * 
+ * + * .grpc.EmptyRequest no_data_sources = 5; + */ + io.trino.spi.grpc.Endpoints.EmptyRequestOrBuilder getNoDataSourcesOrBuilder(); + + /** + *
+     * Represent non-nil.
+     * 
+ * + * .grpc.DataSourceList data_source_list = 6; + * @return Whether the dataSourceList field is set. + */ + boolean hasDataSourceList(); + /** + *
+     * Represent non-nil.
+     * 
+ * + * .grpc.DataSourceList data_source_list = 6; + * @return The dataSourceList. + */ + io.trino.spi.grpc.Endpoints.DataSourceList getDataSourceList(); + /** + *
+     * Represent non-nil.
+     * 
+ * + * .grpc.DataSourceList data_source_list = 6; + */ + io.trino.spi.grpc.Endpoints.DataSourceListOrBuilder getDataSourceListOrBuilder(); + + io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest.DataSourcesModeCase getDataSourcesModeCase(); + } + /** + * Protobuf type {@code grpc.ConnectorInstanceEditRequest} + */ + public static final class ConnectorInstanceEditRequest extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.ConnectorInstanceEditRequest) + ConnectorInstanceEditRequestOrBuilder { + private static final long serialVersionUID = 0L; + // Use ConnectorInstanceEditRequest.newBuilder() to construct. + private ConnectorInstanceEditRequest(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private ConnectorInstanceEditRequest() { + id_ = ""; + name_ = ""; + paramValues_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new ConnectorInstanceEditRequest(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_ConnectorInstanceEditRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_ConnectorInstanceEditRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest.class, io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest.Builder.class); + } + + private int bitField0_; + private int dataSourcesModeCase_ = 0; + @SuppressWarnings("serial") + private java.lang.Object dataSourcesMode_; + public enum DataSourcesModeCase + implements com.google.protobuf.Internal.EnumLite, + com.google.protobuf.AbstractMessage.InternalOneOfEnum { + NO_DATA_SOURCES(5), + DATA_SOURCE_LIST(6), + DATASOURCESMODE_NOT_SET(0); + private final int value; + private DataSourcesModeCase(int value) { + this.value = value; + } + /** + * @param value The number of the enum to look for. + * @return The enum associated with the given number. + * @deprecated Use {@link #forNumber(int)} instead. + */ + @java.lang.Deprecated + public static DataSourcesModeCase valueOf(int value) { + return forNumber(value); + } + + public static DataSourcesModeCase forNumber(int value) { + switch (value) { + case 5: return NO_DATA_SOURCES; + case 6: return DATA_SOURCE_LIST; + case 0: return DATASOURCESMODE_NOT_SET; + default: return null; + } + } + public int getNumber() { + return this.value; + } + }; + + public DataSourcesModeCase + getDataSourcesModeCase() { + return DataSourcesModeCase.forNumber( + dataSourcesModeCase_); + } + + public static final int TENANT_FIELD_NUMBER = 1; + private io.trino.spi.grpc.Endpoints.Tenant tenant_; + /** + * .grpc.Tenant tenant = 1; + * @return Whether the tenant field is set. + */ + @java.lang.Override + public boolean hasTenant() { + return tenant_ != null; + } + /** + * .grpc.Tenant tenant = 1; + * @return The tenant. + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.Tenant getTenant() { + return tenant_ == null ? io.trino.spi.grpc.Endpoints.Tenant.getDefaultInstance() : tenant_; + } + /** + * .grpc.Tenant tenant = 1; + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.TenantOrBuilder getTenantOrBuilder() { + return tenant_ == null ? io.trino.spi.grpc.Endpoints.Tenant.getDefaultInstance() : tenant_; + } + + public static final int ID_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object id_ = ""; + /** + * string id = 2; + * @return The id. + */ + @java.lang.Override + public java.lang.String getId() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } + } + /** + * string id = 2; + * @return The bytes for id. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int NAME_FIELD_NUMBER = 3; + @SuppressWarnings("serial") + private volatile java.lang.Object name_ = ""; + /** + * optional string name = 3; + * @return Whether the name field is set. + */ + @java.lang.Override + public boolean hasName() { + return ((bitField0_ & 0x00000001) != 0); + } + /** + * optional string name = 3; + * @return The name. + */ + @java.lang.Override + public java.lang.String getName() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } + } + /** + * optional string name = 3; + * @return The bytes for name. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int PARAM_VALUES_FIELD_NUMBER = 4; + @SuppressWarnings("serial") + private volatile java.lang.Object paramValues_ = ""; + /** + * optional string param_values = 4; + * @return Whether the paramValues field is set. + */ + @java.lang.Override + public boolean hasParamValues() { + return ((bitField0_ & 0x00000002) != 0); + } + /** + * optional string param_values = 4; + * @return The paramValues. + */ + @java.lang.Override + public java.lang.String getParamValues() { + java.lang.Object ref = paramValues_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + paramValues_ = s; + return s; + } + } + /** + * optional string param_values = 4; + * @return The bytes for paramValues. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getParamValuesBytes() { + java.lang.Object ref = paramValues_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + paramValues_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int NO_DATA_SOURCES_FIELD_NUMBER = 5; + /** + *
+     * Represent nil.
+     * 
+ * + * .grpc.EmptyRequest no_data_sources = 5; + * @return Whether the noDataSources field is set. + */ + @java.lang.Override + public boolean hasNoDataSources() { + return dataSourcesModeCase_ == 5; + } + /** + *
+     * Represent nil.
+     * 
+ * + * .grpc.EmptyRequest no_data_sources = 5; + * @return The noDataSources. + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.EmptyRequest getNoDataSources() { + if (dataSourcesModeCase_ == 5) { + return (io.trino.spi.grpc.Endpoints.EmptyRequest) dataSourcesMode_; + } + return io.trino.spi.grpc.Endpoints.EmptyRequest.getDefaultInstance(); + } + /** + *
+     * Represent nil.
+     * 
+ * + * .grpc.EmptyRequest no_data_sources = 5; + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.EmptyRequestOrBuilder getNoDataSourcesOrBuilder() { + if (dataSourcesModeCase_ == 5) { + return (io.trino.spi.grpc.Endpoints.EmptyRequest) dataSourcesMode_; + } + return io.trino.spi.grpc.Endpoints.EmptyRequest.getDefaultInstance(); + } + + public static final int DATA_SOURCE_LIST_FIELD_NUMBER = 6; + /** + *
+     * Represent non-nil.
+     * 
+ * + * .grpc.DataSourceList data_source_list = 6; + * @return Whether the dataSourceList field is set. + */ + @java.lang.Override + public boolean hasDataSourceList() { + return dataSourcesModeCase_ == 6; + } + /** + *
+     * Represent non-nil.
+     * 
+ * + * .grpc.DataSourceList data_source_list = 6; + * @return The dataSourceList. + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceList getDataSourceList() { + if (dataSourcesModeCase_ == 6) { + return (io.trino.spi.grpc.Endpoints.DataSourceList) dataSourcesMode_; + } + return io.trino.spi.grpc.Endpoints.DataSourceList.getDefaultInstance(); + } + /** + *
+     * Represent non-nil.
+     * 
+ * + * .grpc.DataSourceList data_source_list = 6; + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceListOrBuilder getDataSourceListOrBuilder() { + if (dataSourcesModeCase_ == 6) { + return (io.trino.spi.grpc.Endpoints.DataSourceList) dataSourcesMode_; + } + return io.trino.spi.grpc.Endpoints.DataSourceList.getDefaultInstance(); + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (tenant_ != null) { + output.writeMessage(1, getTenant()); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, id_); + } + if (((bitField0_ & 0x00000001) != 0)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 3, name_); + } + if (((bitField0_ & 0x00000002) != 0)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 4, paramValues_); + } + if (dataSourcesModeCase_ == 5) { + output.writeMessage(5, (io.trino.spi.grpc.Endpoints.EmptyRequest) dataSourcesMode_); + } + if (dataSourcesModeCase_ == 6) { + output.writeMessage(6, (io.trino.spi.grpc.Endpoints.DataSourceList) dataSourcesMode_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (tenant_ != null) { + size += com.google.protobuf.CodedOutputStream + .computeMessageSize(1, getTenant()); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, id_); + } + if (((bitField0_ & 0x00000001) != 0)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(3, name_); + } + if (((bitField0_ & 0x00000002) != 0)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(4, paramValues_); + } + if (dataSourcesModeCase_ == 5) { + size += com.google.protobuf.CodedOutputStream + .computeMessageSize(5, (io.trino.spi.grpc.Endpoints.EmptyRequest) dataSourcesMode_); + } + if (dataSourcesModeCase_ == 6) { + size += com.google.protobuf.CodedOutputStream + .computeMessageSize(6, (io.trino.spi.grpc.Endpoints.DataSourceList) dataSourcesMode_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest other = (io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest) obj; + + if (hasTenant() != other.hasTenant()) return false; + if (hasTenant()) { + if (!getTenant() + .equals(other.getTenant())) return false; + } + if (!getId() + .equals(other.getId())) return false; + if (hasName() != other.hasName()) return false; + if (hasName()) { + if (!getName() + .equals(other.getName())) return false; + } + if (hasParamValues() != other.hasParamValues()) return false; + if (hasParamValues()) { + if (!getParamValues() + .equals(other.getParamValues())) return false; + } + if (!getDataSourcesModeCase().equals(other.getDataSourcesModeCase())) return false; + switch (dataSourcesModeCase_) { + case 5: + if (!getNoDataSources() + .equals(other.getNoDataSources())) return false; + break; + case 6: + if (!getDataSourceList() + .equals(other.getDataSourceList())) return false; + break; + case 0: + default: + } + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + if (hasTenant()) { + hash = (37 * hash) + TENANT_FIELD_NUMBER; + hash = (53 * hash) + getTenant().hashCode(); + } + hash = (37 * hash) + ID_FIELD_NUMBER; + hash = (53 * hash) + getId().hashCode(); + if (hasName()) { + hash = (37 * hash) + NAME_FIELD_NUMBER; + hash = (53 * hash) + getName().hashCode(); + } + if (hasParamValues()) { + hash = (37 * hash) + PARAM_VALUES_FIELD_NUMBER; + hash = (53 * hash) + getParamValues().hashCode(); + } + switch (dataSourcesModeCase_) { + case 5: + hash = (37 * hash) + NO_DATA_SOURCES_FIELD_NUMBER; + hash = (53 * hash) + getNoDataSources().hashCode(); + break; + case 6: + hash = (37 * hash) + DATA_SOURCE_LIST_FIELD_NUMBER; + hash = (53 * hash) + getDataSourceList().hashCode(); + break; + case 0: + default: + } + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.ConnectorInstanceEditRequest} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.ConnectorInstanceEditRequest) + io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequestOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_ConnectorInstanceEditRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_ConnectorInstanceEditRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest.class, io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + tenant_ = null; + if (tenantBuilder_ != null) { + tenantBuilder_.dispose(); + tenantBuilder_ = null; + } + id_ = ""; + name_ = ""; + paramValues_ = ""; + if (noDataSourcesBuilder_ != null) { + noDataSourcesBuilder_.clear(); + } + if (dataSourceListBuilder_ != null) { + dataSourceListBuilder_.clear(); + } + dataSourcesModeCase_ = 0; + dataSourcesMode_ = null; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_ConnectorInstanceEditRequest_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest build() { + io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest buildPartial() { + io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest result = new io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest(this); + if (bitField0_ != 0) { buildPartial0(result); } + buildPartialOneofs(result); + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.tenant_ = tenantBuilder_ == null + ? tenant_ + : tenantBuilder_.build(); + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.id_ = id_; + } + int to_bitField0_ = 0; + if (((from_bitField0_ & 0x00000004) != 0)) { + result.name_ = name_; + to_bitField0_ |= 0x00000001; + } + if (((from_bitField0_ & 0x00000008) != 0)) { + result.paramValues_ = paramValues_; + to_bitField0_ |= 0x00000002; + } + result.bitField0_ |= to_bitField0_; + } + + private void buildPartialOneofs(io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest result) { + result.dataSourcesModeCase_ = dataSourcesModeCase_; + result.dataSourcesMode_ = this.dataSourcesMode_; + if (dataSourcesModeCase_ == 5 && + noDataSourcesBuilder_ != null) { + result.dataSourcesMode_ = noDataSourcesBuilder_.build(); + } + if (dataSourcesModeCase_ == 6 && + dataSourceListBuilder_ != null) { + result.dataSourcesMode_ = dataSourceListBuilder_.build(); + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest) { + return mergeFrom((io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest other) { + if (other == io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest.getDefaultInstance()) return this; + if (other.hasTenant()) { + mergeTenant(other.getTenant()); + } + if (!other.getId().isEmpty()) { + id_ = other.id_; + bitField0_ |= 0x00000002; + onChanged(); + } + if (other.hasName()) { + name_ = other.name_; + bitField0_ |= 0x00000004; + onChanged(); + } + if (other.hasParamValues()) { + paramValues_ = other.paramValues_; + bitField0_ |= 0x00000008; + onChanged(); + } + switch (other.getDataSourcesModeCase()) { + case NO_DATA_SOURCES: { + mergeNoDataSources(other.getNoDataSources()); + break; + } + case DATA_SOURCE_LIST: { + mergeDataSourceList(other.getDataSourceList()); + break; + } + case DATASOURCESMODE_NOT_SET: { + break; + } + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + input.readMessage( + getTenantFieldBuilder().getBuilder(), + extensionRegistry); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + id_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + case 26: { + name_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000004; + break; + } // case 26 + case 34: { + paramValues_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000008; + break; + } // case 34 + case 42: { + input.readMessage( + getNoDataSourcesFieldBuilder().getBuilder(), + extensionRegistry); + dataSourcesModeCase_ = 5; + break; + } // case 42 + case 50: { + input.readMessage( + getDataSourceListFieldBuilder().getBuilder(), + extensionRegistry); + dataSourcesModeCase_ = 6; + break; + } // case 50 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int dataSourcesModeCase_ = 0; + private java.lang.Object dataSourcesMode_; + public DataSourcesModeCase + getDataSourcesModeCase() { + return DataSourcesModeCase.forNumber( + dataSourcesModeCase_); + } + + public Builder clearDataSourcesMode() { + dataSourcesModeCase_ = 0; + dataSourcesMode_ = null; + onChanged(); + return this; + } + + private int bitField0_; + + private io.trino.spi.grpc.Endpoints.Tenant tenant_; + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.Tenant, io.trino.spi.grpc.Endpoints.Tenant.Builder, io.trino.spi.grpc.Endpoints.TenantOrBuilder> tenantBuilder_; + /** + * .grpc.Tenant tenant = 1; + * @return Whether the tenant field is set. + */ + public boolean hasTenant() { + return ((bitField0_ & 0x00000001) != 0); + } + /** + * .grpc.Tenant tenant = 1; + * @return The tenant. + */ + public io.trino.spi.grpc.Endpoints.Tenant getTenant() { + if (tenantBuilder_ == null) { + return tenant_ == null ? io.trino.spi.grpc.Endpoints.Tenant.getDefaultInstance() : tenant_; + } else { + return tenantBuilder_.getMessage(); + } + } + /** + * .grpc.Tenant tenant = 1; + */ + public Builder setTenant(io.trino.spi.grpc.Endpoints.Tenant value) { + if (tenantBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + tenant_ = value; + } else { + tenantBuilder_.setMessage(value); + } + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * .grpc.Tenant tenant = 1; + */ + public Builder setTenant( + io.trino.spi.grpc.Endpoints.Tenant.Builder builderForValue) { + if (tenantBuilder_ == null) { + tenant_ = builderForValue.build(); + } else { + tenantBuilder_.setMessage(builderForValue.build()); + } + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * .grpc.Tenant tenant = 1; + */ + public Builder mergeTenant(io.trino.spi.grpc.Endpoints.Tenant value) { + if (tenantBuilder_ == null) { + if (((bitField0_ & 0x00000001) != 0) && + tenant_ != null && + tenant_ != io.trino.spi.grpc.Endpoints.Tenant.getDefaultInstance()) { + getTenantBuilder().mergeFrom(value); + } else { + tenant_ = value; + } + } else { + tenantBuilder_.mergeFrom(value); + } + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * .grpc.Tenant tenant = 1; + */ + public Builder clearTenant() { + bitField0_ = (bitField0_ & ~0x00000001); + tenant_ = null; + if (tenantBuilder_ != null) { + tenantBuilder_.dispose(); + tenantBuilder_ = null; + } + onChanged(); + return this; + } + /** + * .grpc.Tenant tenant = 1; + */ + public io.trino.spi.grpc.Endpoints.Tenant.Builder getTenantBuilder() { + bitField0_ |= 0x00000001; + onChanged(); + return getTenantFieldBuilder().getBuilder(); + } + /** + * .grpc.Tenant tenant = 1; + */ + public io.trino.spi.grpc.Endpoints.TenantOrBuilder getTenantOrBuilder() { + if (tenantBuilder_ != null) { + return tenantBuilder_.getMessageOrBuilder(); + } else { + return tenant_ == null ? + io.trino.spi.grpc.Endpoints.Tenant.getDefaultInstance() : tenant_; + } + } + /** + * .grpc.Tenant tenant = 1; + */ + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.Tenant, io.trino.spi.grpc.Endpoints.Tenant.Builder, io.trino.spi.grpc.Endpoints.TenantOrBuilder> + getTenantFieldBuilder() { + if (tenantBuilder_ == null) { + tenantBuilder_ = new com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.Tenant, io.trino.spi.grpc.Endpoints.Tenant.Builder, io.trino.spi.grpc.Endpoints.TenantOrBuilder>( + getTenant(), + getParentForChildren(), + isClean()); + tenant_ = null; + } + return tenantBuilder_; + } + + private java.lang.Object id_ = ""; + /** + * string id = 2; + * @return The id. + */ + public java.lang.String getId() { + java.lang.Object ref = id_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string id = 2; + * @return The bytes for id. + */ + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string id = 2; + * @param value The id to set. + * @return This builder for chaining. + */ + public Builder setId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + id_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string id = 2; + * @return This builder for chaining. + */ + public Builder clearId() { + id_ = getDefaultInstance().getId(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string id = 2; + * @param value The bytes for id to set. + * @return This builder for chaining. + */ + public Builder setIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + id_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + + private java.lang.Object name_ = ""; + /** + * optional string name = 3; + * @return Whether the name field is set. + */ + public boolean hasName() { + return ((bitField0_ & 0x00000004) != 0); + } + /** + * optional string name = 3; + * @return The name. + */ + public java.lang.String getName() { + java.lang.Object ref = name_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * optional string name = 3; + * @return The bytes for name. + */ + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * optional string name = 3; + * @param value The name to set. + * @return This builder for chaining. + */ + public Builder setName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + name_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + /** + * optional string name = 3; + * @return This builder for chaining. + */ + public Builder clearName() { + name_ = getDefaultInstance().getName(); + bitField0_ = (bitField0_ & ~0x00000004); + onChanged(); + return this; + } + /** + * optional string name = 3; + * @param value The bytes for name to set. + * @return This builder for chaining. + */ + public Builder setNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + name_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + + private java.lang.Object paramValues_ = ""; + /** + * optional string param_values = 4; + * @return Whether the paramValues field is set. + */ + public boolean hasParamValues() { + return ((bitField0_ & 0x00000008) != 0); + } + /** + * optional string param_values = 4; + * @return The paramValues. + */ + public java.lang.String getParamValues() { + java.lang.Object ref = paramValues_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + paramValues_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * optional string param_values = 4; + * @return The bytes for paramValues. + */ + public com.google.protobuf.ByteString + getParamValuesBytes() { + java.lang.Object ref = paramValues_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + paramValues_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * optional string param_values = 4; + * @param value The paramValues to set. + * @return This builder for chaining. + */ + public Builder setParamValues( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + paramValues_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + /** + * optional string param_values = 4; + * @return This builder for chaining. + */ + public Builder clearParamValues() { + paramValues_ = getDefaultInstance().getParamValues(); + bitField0_ = (bitField0_ & ~0x00000008); + onChanged(); + return this; + } + /** + * optional string param_values = 4; + * @param value The bytes for paramValues to set. + * @return This builder for chaining. + */ + public Builder setParamValuesBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + paramValues_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.EmptyRequest, io.trino.spi.grpc.Endpoints.EmptyRequest.Builder, io.trino.spi.grpc.Endpoints.EmptyRequestOrBuilder> noDataSourcesBuilder_; + /** + *
+       * Represent nil.
+       * 
+ * + * .grpc.EmptyRequest no_data_sources = 5; + * @return Whether the noDataSources field is set. + */ + @java.lang.Override + public boolean hasNoDataSources() { + return dataSourcesModeCase_ == 5; + } + /** + *
+       * Represent nil.
+       * 
+ * + * .grpc.EmptyRequest no_data_sources = 5; + * @return The noDataSources. + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.EmptyRequest getNoDataSources() { + if (noDataSourcesBuilder_ == null) { + if (dataSourcesModeCase_ == 5) { + return (io.trino.spi.grpc.Endpoints.EmptyRequest) dataSourcesMode_; + } + return io.trino.spi.grpc.Endpoints.EmptyRequest.getDefaultInstance(); + } else { + if (dataSourcesModeCase_ == 5) { + return noDataSourcesBuilder_.getMessage(); + } + return io.trino.spi.grpc.Endpoints.EmptyRequest.getDefaultInstance(); + } + } + /** + *
+       * Represent nil.
+       * 
+ * + * .grpc.EmptyRequest no_data_sources = 5; + */ + public Builder setNoDataSources(io.trino.spi.grpc.Endpoints.EmptyRequest value) { + if (noDataSourcesBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + dataSourcesMode_ = value; + onChanged(); + } else { + noDataSourcesBuilder_.setMessage(value); + } + dataSourcesModeCase_ = 5; + return this; + } + /** + *
+       * Represent nil.
+       * 
+ * + * .grpc.EmptyRequest no_data_sources = 5; + */ + public Builder setNoDataSources( + io.trino.spi.grpc.Endpoints.EmptyRequest.Builder builderForValue) { + if (noDataSourcesBuilder_ == null) { + dataSourcesMode_ = builderForValue.build(); + onChanged(); + } else { + noDataSourcesBuilder_.setMessage(builderForValue.build()); + } + dataSourcesModeCase_ = 5; + return this; + } + /** + *
+       * Represent nil.
+       * 
+ * + * .grpc.EmptyRequest no_data_sources = 5; + */ + public Builder mergeNoDataSources(io.trino.spi.grpc.Endpoints.EmptyRequest value) { + if (noDataSourcesBuilder_ == null) { + if (dataSourcesModeCase_ == 5 && + dataSourcesMode_ != io.trino.spi.grpc.Endpoints.EmptyRequest.getDefaultInstance()) { + dataSourcesMode_ = io.trino.spi.grpc.Endpoints.EmptyRequest.newBuilder((io.trino.spi.grpc.Endpoints.EmptyRequest) dataSourcesMode_) + .mergeFrom(value).buildPartial(); + } else { + dataSourcesMode_ = value; + } + onChanged(); + } else { + if (dataSourcesModeCase_ == 5) { + noDataSourcesBuilder_.mergeFrom(value); + } else { + noDataSourcesBuilder_.setMessage(value); + } + } + dataSourcesModeCase_ = 5; + return this; + } + /** + *
+       * Represent nil.
+       * 
+ * + * .grpc.EmptyRequest no_data_sources = 5; + */ + public Builder clearNoDataSources() { + if (noDataSourcesBuilder_ == null) { + if (dataSourcesModeCase_ == 5) { + dataSourcesModeCase_ = 0; + dataSourcesMode_ = null; + onChanged(); + } + } else { + if (dataSourcesModeCase_ == 5) { + dataSourcesModeCase_ = 0; + dataSourcesMode_ = null; + } + noDataSourcesBuilder_.clear(); + } + return this; + } + /** + *
+       * Represent nil.
+       * 
+ * + * .grpc.EmptyRequest no_data_sources = 5; + */ + public io.trino.spi.grpc.Endpoints.EmptyRequest.Builder getNoDataSourcesBuilder() { + return getNoDataSourcesFieldBuilder().getBuilder(); + } + /** + *
+       * Represent nil.
+       * 
+ * + * .grpc.EmptyRequest no_data_sources = 5; + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.EmptyRequestOrBuilder getNoDataSourcesOrBuilder() { + if ((dataSourcesModeCase_ == 5) && (noDataSourcesBuilder_ != null)) { + return noDataSourcesBuilder_.getMessageOrBuilder(); + } else { + if (dataSourcesModeCase_ == 5) { + return (io.trino.spi.grpc.Endpoints.EmptyRequest) dataSourcesMode_; + } + return io.trino.spi.grpc.Endpoints.EmptyRequest.getDefaultInstance(); + } + } + /** + *
+       * Represent nil.
+       * 
+ * + * .grpc.EmptyRequest no_data_sources = 5; + */ + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.EmptyRequest, io.trino.spi.grpc.Endpoints.EmptyRequest.Builder, io.trino.spi.grpc.Endpoints.EmptyRequestOrBuilder> + getNoDataSourcesFieldBuilder() { + if (noDataSourcesBuilder_ == null) { + if (!(dataSourcesModeCase_ == 5)) { + dataSourcesMode_ = io.trino.spi.grpc.Endpoints.EmptyRequest.getDefaultInstance(); + } + noDataSourcesBuilder_ = new com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.EmptyRequest, io.trino.spi.grpc.Endpoints.EmptyRequest.Builder, io.trino.spi.grpc.Endpoints.EmptyRequestOrBuilder>( + (io.trino.spi.grpc.Endpoints.EmptyRequest) dataSourcesMode_, + getParentForChildren(), + isClean()); + dataSourcesMode_ = null; + } + dataSourcesModeCase_ = 5; + onChanged(); + return noDataSourcesBuilder_; + } + + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.DataSourceList, io.trino.spi.grpc.Endpoints.DataSourceList.Builder, io.trino.spi.grpc.Endpoints.DataSourceListOrBuilder> dataSourceListBuilder_; + /** + *
+       * Represent non-nil.
+       * 
+ * + * .grpc.DataSourceList data_source_list = 6; + * @return Whether the dataSourceList field is set. + */ + @java.lang.Override + public boolean hasDataSourceList() { + return dataSourcesModeCase_ == 6; + } + /** + *
+       * Represent non-nil.
+       * 
+ * + * .grpc.DataSourceList data_source_list = 6; + * @return The dataSourceList. + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceList getDataSourceList() { + if (dataSourceListBuilder_ == null) { + if (dataSourcesModeCase_ == 6) { + return (io.trino.spi.grpc.Endpoints.DataSourceList) dataSourcesMode_; + } + return io.trino.spi.grpc.Endpoints.DataSourceList.getDefaultInstance(); + } else { + if (dataSourcesModeCase_ == 6) { + return dataSourceListBuilder_.getMessage(); + } + return io.trino.spi.grpc.Endpoints.DataSourceList.getDefaultInstance(); + } + } + /** + *
+       * Represent non-nil.
+       * 
+ * + * .grpc.DataSourceList data_source_list = 6; + */ + public Builder setDataSourceList(io.trino.spi.grpc.Endpoints.DataSourceList value) { + if (dataSourceListBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + dataSourcesMode_ = value; + onChanged(); + } else { + dataSourceListBuilder_.setMessage(value); + } + dataSourcesModeCase_ = 6; + return this; + } + /** + *
+       * Represent non-nil.
+       * 
+ * + * .grpc.DataSourceList data_source_list = 6; + */ + public Builder setDataSourceList( + io.trino.spi.grpc.Endpoints.DataSourceList.Builder builderForValue) { + if (dataSourceListBuilder_ == null) { + dataSourcesMode_ = builderForValue.build(); + onChanged(); + } else { + dataSourceListBuilder_.setMessage(builderForValue.build()); + } + dataSourcesModeCase_ = 6; + return this; + } + /** + *
+       * Represent non-nil.
+       * 
+ * + * .grpc.DataSourceList data_source_list = 6; + */ + public Builder mergeDataSourceList(io.trino.spi.grpc.Endpoints.DataSourceList value) { + if (dataSourceListBuilder_ == null) { + if (dataSourcesModeCase_ == 6 && + dataSourcesMode_ != io.trino.spi.grpc.Endpoints.DataSourceList.getDefaultInstance()) { + dataSourcesMode_ = io.trino.spi.grpc.Endpoints.DataSourceList.newBuilder((io.trino.spi.grpc.Endpoints.DataSourceList) dataSourcesMode_) + .mergeFrom(value).buildPartial(); + } else { + dataSourcesMode_ = value; + } + onChanged(); + } else { + if (dataSourcesModeCase_ == 6) { + dataSourceListBuilder_.mergeFrom(value); + } else { + dataSourceListBuilder_.setMessage(value); + } + } + dataSourcesModeCase_ = 6; + return this; + } + /** + *
+       * Represent non-nil.
+       * 
+ * + * .grpc.DataSourceList data_source_list = 6; + */ + public Builder clearDataSourceList() { + if (dataSourceListBuilder_ == null) { + if (dataSourcesModeCase_ == 6) { + dataSourcesModeCase_ = 0; + dataSourcesMode_ = null; + onChanged(); + } + } else { + if (dataSourcesModeCase_ == 6) { + dataSourcesModeCase_ = 0; + dataSourcesMode_ = null; + } + dataSourceListBuilder_.clear(); + } + return this; + } + /** + *
+       * Represent non-nil.
+       * 
+ * + * .grpc.DataSourceList data_source_list = 6; + */ + public io.trino.spi.grpc.Endpoints.DataSourceList.Builder getDataSourceListBuilder() { + return getDataSourceListFieldBuilder().getBuilder(); + } + /** + *
+       * Represent non-nil.
+       * 
+ * + * .grpc.DataSourceList data_source_list = 6; + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceListOrBuilder getDataSourceListOrBuilder() { + if ((dataSourcesModeCase_ == 6) && (dataSourceListBuilder_ != null)) { + return dataSourceListBuilder_.getMessageOrBuilder(); + } else { + if (dataSourcesModeCase_ == 6) { + return (io.trino.spi.grpc.Endpoints.DataSourceList) dataSourcesMode_; + } + return io.trino.spi.grpc.Endpoints.DataSourceList.getDefaultInstance(); + } + } + /** + *
+       * Represent non-nil.
+       * 
+ * + * .grpc.DataSourceList data_source_list = 6; + */ + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.DataSourceList, io.trino.spi.grpc.Endpoints.DataSourceList.Builder, io.trino.spi.grpc.Endpoints.DataSourceListOrBuilder> + getDataSourceListFieldBuilder() { + if (dataSourceListBuilder_ == null) { + if (!(dataSourcesModeCase_ == 6)) { + dataSourcesMode_ = io.trino.spi.grpc.Endpoints.DataSourceList.getDefaultInstance(); + } + dataSourceListBuilder_ = new com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.DataSourceList, io.trino.spi.grpc.Endpoints.DataSourceList.Builder, io.trino.spi.grpc.Endpoints.DataSourceListOrBuilder>( + (io.trino.spi.grpc.Endpoints.DataSourceList) dataSourcesMode_, + getParentForChildren(), + isClean()); + dataSourcesMode_ = null; + } + dataSourcesModeCase_ = 6; + onChanged(); + return dataSourceListBuilder_; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.ConnectorInstanceEditRequest) + } + + // @@protoc_insertion_point(class_scope:grpc.ConnectorInstanceEditRequest) + private static final io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest(); + } + + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public ConnectorInstanceEditRequest parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface BrokerAuthOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.BrokerAuth) + com.google.protobuf.MessageOrBuilder { + + /** + * string id = 1; + * @return The id. + */ + java.lang.String getId(); + /** + * string id = 1; + * @return The bytes for id. + */ + com.google.protobuf.ByteString + getIdBytes(); + + /** + * string access_key = 2; + * @return The accessKey. + */ + java.lang.String getAccessKey(); + /** + * string access_key = 2; + * @return The bytes for accessKey. + */ + com.google.protobuf.ByteString + getAccessKeyBytes(); + } + /** + * Protobuf type {@code grpc.BrokerAuth} + */ + public static final class BrokerAuth extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.BrokerAuth) + BrokerAuthOrBuilder { + private static final long serialVersionUID = 0L; + // Use BrokerAuth.newBuilder() to construct. + private BrokerAuth(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private BrokerAuth() { + id_ = ""; + accessKey_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new BrokerAuth(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BrokerAuth_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BrokerAuth_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.BrokerAuth.class, io.trino.spi.grpc.Endpoints.BrokerAuth.Builder.class); + } + + public static final int ID_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object id_ = ""; + /** + * string id = 1; + * @return The id. + */ + @java.lang.Override + public java.lang.String getId() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } + } + /** + * string id = 1; + * @return The bytes for id. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int ACCESS_KEY_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object accessKey_ = ""; + /** + * string access_key = 2; + * @return The accessKey. + */ + @java.lang.Override + public java.lang.String getAccessKey() { + java.lang.Object ref = accessKey_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + accessKey_ = s; + return s; + } + } + /** + * string access_key = 2; + * @return The bytes for accessKey. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getAccessKeyBytes() { + java.lang.Object ref = accessKey_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + accessKey_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, id_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(accessKey_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, accessKey_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, id_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(accessKey_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, accessKey_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.BrokerAuth)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.BrokerAuth other = (io.trino.spi.grpc.Endpoints.BrokerAuth) obj; + + if (!getId() + .equals(other.getId())) return false; + if (!getAccessKey() + .equals(other.getAccessKey())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + ID_FIELD_NUMBER; + hash = (53 * hash) + getId().hashCode(); + hash = (37 * hash) + ACCESS_KEY_FIELD_NUMBER; + hash = (53 * hash) + getAccessKey().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.BrokerAuth parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.BrokerAuth parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.BrokerAuth parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.BrokerAuth parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.BrokerAuth parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.BrokerAuth parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.BrokerAuth parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.BrokerAuth parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.BrokerAuth parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.BrokerAuth parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.BrokerAuth parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.BrokerAuth parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.BrokerAuth prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.BrokerAuth} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.BrokerAuth) + io.trino.spi.grpc.Endpoints.BrokerAuthOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BrokerAuth_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BrokerAuth_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.BrokerAuth.class, io.trino.spi.grpc.Endpoints.BrokerAuth.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.BrokerAuth.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + id_ = ""; + accessKey_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_BrokerAuth_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BrokerAuth getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.BrokerAuth.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BrokerAuth build() { + io.trino.spi.grpc.Endpoints.BrokerAuth result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BrokerAuth buildPartial() { + io.trino.spi.grpc.Endpoints.BrokerAuth result = new io.trino.spi.grpc.Endpoints.BrokerAuth(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.BrokerAuth result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.id_ = id_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.accessKey_ = accessKey_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.BrokerAuth) { + return mergeFrom((io.trino.spi.grpc.Endpoints.BrokerAuth)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.BrokerAuth other) { + if (other == io.trino.spi.grpc.Endpoints.BrokerAuth.getDefaultInstance()) return this; + if (!other.getId().isEmpty()) { + id_ = other.id_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getAccessKey().isEmpty()) { + accessKey_ = other.accessKey_; + bitField0_ |= 0x00000002; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + id_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + accessKey_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object id_ = ""; + /** + * string id = 1; + * @return The id. + */ + public java.lang.String getId() { + java.lang.Object ref = id_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string id = 1; + * @return The bytes for id. + */ + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string id = 1; + * @param value The id to set. + * @return This builder for chaining. + */ + public Builder setId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + id_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string id = 1; + * @return This builder for chaining. + */ + public Builder clearId() { + id_ = getDefaultInstance().getId(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string id = 1; + * @param value The bytes for id to set. + * @return This builder for chaining. + */ + public Builder setIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + id_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object accessKey_ = ""; + /** + * string access_key = 2; + * @return The accessKey. + */ + public java.lang.String getAccessKey() { + java.lang.Object ref = accessKey_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + accessKey_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string access_key = 2; + * @return The bytes for accessKey. + */ + public com.google.protobuf.ByteString + getAccessKeyBytes() { + java.lang.Object ref = accessKey_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + accessKey_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string access_key = 2; + * @param value The accessKey to set. + * @return This builder for chaining. + */ + public Builder setAccessKey( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + accessKey_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string access_key = 2; + * @return This builder for chaining. + */ + public Builder clearAccessKey() { + accessKey_ = getDefaultInstance().getAccessKey(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string access_key = 2; + * @param value The bytes for accessKey to set. + * @return This builder for chaining. + */ + public Builder setAccessKeyBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + accessKey_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.BrokerAuth) + } + + // @@protoc_insertion_point(class_scope:grpc.BrokerAuth) + private static final io.trino.spi.grpc.Endpoints.BrokerAuth DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.BrokerAuth(); + } + + public static io.trino.spi.grpc.Endpoints.BrokerAuth getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public BrokerAuth parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BrokerAuth getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface ConnectorInstanceDetailsOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.ConnectorInstanceDetails) + com.google.protobuf.MessageOrBuilder { + + /** + * .grpc.ConnectorInstance connectorInstance = 1; + * @return Whether the connectorInstance field is set. + */ + boolean hasConnectorInstance(); + /** + * .grpc.ConnectorInstance connectorInstance = 1; + * @return The connectorInstance. + */ + io.trino.spi.grpc.Endpoints.ConnectorInstance getConnectorInstance(); + /** + * .grpc.ConnectorInstance connectorInstance = 1; + */ + io.trino.spi.grpc.Endpoints.ConnectorInstanceOrBuilder getConnectorInstanceOrBuilder(); + + /** + * .grpc.BrokerAuth brokerAuth = 2; + * @return Whether the brokerAuth field is set. + */ + boolean hasBrokerAuth(); + /** + * .grpc.BrokerAuth brokerAuth = 2; + * @return The brokerAuth. + */ + io.trino.spi.grpc.Endpoints.BrokerAuth getBrokerAuth(); + /** + * .grpc.BrokerAuth brokerAuth = 2; + */ + io.trino.spi.grpc.Endpoints.BrokerAuthOrBuilder getBrokerAuthOrBuilder(); + } + /** + * Protobuf type {@code grpc.ConnectorInstanceDetails} + */ + public static final class ConnectorInstanceDetails extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.ConnectorInstanceDetails) + ConnectorInstanceDetailsOrBuilder { + private static final long serialVersionUID = 0L; + // Use ConnectorInstanceDetails.newBuilder() to construct. + private ConnectorInstanceDetails(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private ConnectorInstanceDetails() { + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new ConnectorInstanceDetails(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_ConnectorInstanceDetails_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_ConnectorInstanceDetails_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails.class, io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails.Builder.class); + } + + public static final int CONNECTORINSTANCE_FIELD_NUMBER = 1; + private io.trino.spi.grpc.Endpoints.ConnectorInstance connectorInstance_; + /** + * .grpc.ConnectorInstance connectorInstance = 1; + * @return Whether the connectorInstance field is set. + */ + @java.lang.Override + public boolean hasConnectorInstance() { + return connectorInstance_ != null; + } + /** + * .grpc.ConnectorInstance connectorInstance = 1; + * @return The connectorInstance. + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.ConnectorInstance getConnectorInstance() { + return connectorInstance_ == null ? io.trino.spi.grpc.Endpoints.ConnectorInstance.getDefaultInstance() : connectorInstance_; + } + /** + * .grpc.ConnectorInstance connectorInstance = 1; + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.ConnectorInstanceOrBuilder getConnectorInstanceOrBuilder() { + return connectorInstance_ == null ? io.trino.spi.grpc.Endpoints.ConnectorInstance.getDefaultInstance() : connectorInstance_; + } + + public static final int BROKERAUTH_FIELD_NUMBER = 2; + private io.trino.spi.grpc.Endpoints.BrokerAuth brokerAuth_; + /** + * .grpc.BrokerAuth brokerAuth = 2; + * @return Whether the brokerAuth field is set. + */ + @java.lang.Override + public boolean hasBrokerAuth() { + return brokerAuth_ != null; + } + /** + * .grpc.BrokerAuth brokerAuth = 2; + * @return The brokerAuth. + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BrokerAuth getBrokerAuth() { + return brokerAuth_ == null ? io.trino.spi.grpc.Endpoints.BrokerAuth.getDefaultInstance() : brokerAuth_; + } + /** + * .grpc.BrokerAuth brokerAuth = 2; + */ + @java.lang.Override + public io.trino.spi.grpc.Endpoints.BrokerAuthOrBuilder getBrokerAuthOrBuilder() { + return brokerAuth_ == null ? io.trino.spi.grpc.Endpoints.BrokerAuth.getDefaultInstance() : brokerAuth_; + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (connectorInstance_ != null) { + output.writeMessage(1, getConnectorInstance()); + } + if (brokerAuth_ != null) { + output.writeMessage(2, getBrokerAuth()); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (connectorInstance_ != null) { + size += com.google.protobuf.CodedOutputStream + .computeMessageSize(1, getConnectorInstance()); + } + if (brokerAuth_ != null) { + size += com.google.protobuf.CodedOutputStream + .computeMessageSize(2, getBrokerAuth()); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails other = (io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails) obj; + + if (hasConnectorInstance() != other.hasConnectorInstance()) return false; + if (hasConnectorInstance()) { + if (!getConnectorInstance() + .equals(other.getConnectorInstance())) return false; + } + if (hasBrokerAuth() != other.hasBrokerAuth()) return false; + if (hasBrokerAuth()) { + if (!getBrokerAuth() + .equals(other.getBrokerAuth())) return false; + } + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + if (hasConnectorInstance()) { + hash = (37 * hash) + CONNECTORINSTANCE_FIELD_NUMBER; + hash = (53 * hash) + getConnectorInstance().hashCode(); + } + if (hasBrokerAuth()) { + hash = (37 * hash) + BROKERAUTH_FIELD_NUMBER; + hash = (53 * hash) + getBrokerAuth().hashCode(); + } + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.ConnectorInstanceDetails} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.ConnectorInstanceDetails) + io.trino.spi.grpc.Endpoints.ConnectorInstanceDetailsOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_ConnectorInstanceDetails_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_ConnectorInstanceDetails_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails.class, io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + connectorInstance_ = null; + if (connectorInstanceBuilder_ != null) { + connectorInstanceBuilder_.dispose(); + connectorInstanceBuilder_ = null; + } + brokerAuth_ = null; + if (brokerAuthBuilder_ != null) { + brokerAuthBuilder_.dispose(); + brokerAuthBuilder_ = null; + } + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_ConnectorInstanceDetails_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails build() { + io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails buildPartial() { + io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails result = new io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.connectorInstance_ = connectorInstanceBuilder_ == null + ? connectorInstance_ + : connectorInstanceBuilder_.build(); + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.brokerAuth_ = brokerAuthBuilder_ == null + ? brokerAuth_ + : brokerAuthBuilder_.build(); + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails) { + return mergeFrom((io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails other) { + if (other == io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails.getDefaultInstance()) return this; + if (other.hasConnectorInstance()) { + mergeConnectorInstance(other.getConnectorInstance()); + } + if (other.hasBrokerAuth()) { + mergeBrokerAuth(other.getBrokerAuth()); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + input.readMessage( + getConnectorInstanceFieldBuilder().getBuilder(), + extensionRegistry); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + input.readMessage( + getBrokerAuthFieldBuilder().getBuilder(), + extensionRegistry); + bitField0_ |= 0x00000002; + break; + } // case 18 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private io.trino.spi.grpc.Endpoints.ConnectorInstance connectorInstance_; + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.ConnectorInstance, io.trino.spi.grpc.Endpoints.ConnectorInstance.Builder, io.trino.spi.grpc.Endpoints.ConnectorInstanceOrBuilder> connectorInstanceBuilder_; + /** + * .grpc.ConnectorInstance connectorInstance = 1; + * @return Whether the connectorInstance field is set. + */ + public boolean hasConnectorInstance() { + return ((bitField0_ & 0x00000001) != 0); + } + /** + * .grpc.ConnectorInstance connectorInstance = 1; + * @return The connectorInstance. + */ + public io.trino.spi.grpc.Endpoints.ConnectorInstance getConnectorInstance() { + if (connectorInstanceBuilder_ == null) { + return connectorInstance_ == null ? io.trino.spi.grpc.Endpoints.ConnectorInstance.getDefaultInstance() : connectorInstance_; + } else { + return connectorInstanceBuilder_.getMessage(); + } + } + /** + * .grpc.ConnectorInstance connectorInstance = 1; + */ + public Builder setConnectorInstance(io.trino.spi.grpc.Endpoints.ConnectorInstance value) { + if (connectorInstanceBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + connectorInstance_ = value; + } else { + connectorInstanceBuilder_.setMessage(value); + } + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * .grpc.ConnectorInstance connectorInstance = 1; + */ + public Builder setConnectorInstance( + io.trino.spi.grpc.Endpoints.ConnectorInstance.Builder builderForValue) { + if (connectorInstanceBuilder_ == null) { + connectorInstance_ = builderForValue.build(); + } else { + connectorInstanceBuilder_.setMessage(builderForValue.build()); + } + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * .grpc.ConnectorInstance connectorInstance = 1; + */ + public Builder mergeConnectorInstance(io.trino.spi.grpc.Endpoints.ConnectorInstance value) { + if (connectorInstanceBuilder_ == null) { + if (((bitField0_ & 0x00000001) != 0) && + connectorInstance_ != null && + connectorInstance_ != io.trino.spi.grpc.Endpoints.ConnectorInstance.getDefaultInstance()) { + getConnectorInstanceBuilder().mergeFrom(value); + } else { + connectorInstance_ = value; + } + } else { + connectorInstanceBuilder_.mergeFrom(value); + } + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * .grpc.ConnectorInstance connectorInstance = 1; + */ + public Builder clearConnectorInstance() { + bitField0_ = (bitField0_ & ~0x00000001); + connectorInstance_ = null; + if (connectorInstanceBuilder_ != null) { + connectorInstanceBuilder_.dispose(); + connectorInstanceBuilder_ = null; + } + onChanged(); + return this; + } + /** + * .grpc.ConnectorInstance connectorInstance = 1; + */ + public io.trino.spi.grpc.Endpoints.ConnectorInstance.Builder getConnectorInstanceBuilder() { + bitField0_ |= 0x00000001; + onChanged(); + return getConnectorInstanceFieldBuilder().getBuilder(); + } + /** + * .grpc.ConnectorInstance connectorInstance = 1; + */ + public io.trino.spi.grpc.Endpoints.ConnectorInstanceOrBuilder getConnectorInstanceOrBuilder() { + if (connectorInstanceBuilder_ != null) { + return connectorInstanceBuilder_.getMessageOrBuilder(); + } else { + return connectorInstance_ == null ? + io.trino.spi.grpc.Endpoints.ConnectorInstance.getDefaultInstance() : connectorInstance_; + } + } + /** + * .grpc.ConnectorInstance connectorInstance = 1; + */ + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.ConnectorInstance, io.trino.spi.grpc.Endpoints.ConnectorInstance.Builder, io.trino.spi.grpc.Endpoints.ConnectorInstanceOrBuilder> + getConnectorInstanceFieldBuilder() { + if (connectorInstanceBuilder_ == null) { + connectorInstanceBuilder_ = new com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.ConnectorInstance, io.trino.spi.grpc.Endpoints.ConnectorInstance.Builder, io.trino.spi.grpc.Endpoints.ConnectorInstanceOrBuilder>( + getConnectorInstance(), + getParentForChildren(), + isClean()); + connectorInstance_ = null; + } + return connectorInstanceBuilder_; + } + + private io.trino.spi.grpc.Endpoints.BrokerAuth brokerAuth_; + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.BrokerAuth, io.trino.spi.grpc.Endpoints.BrokerAuth.Builder, io.trino.spi.grpc.Endpoints.BrokerAuthOrBuilder> brokerAuthBuilder_; + /** + * .grpc.BrokerAuth brokerAuth = 2; + * @return Whether the brokerAuth field is set. + */ + public boolean hasBrokerAuth() { + return ((bitField0_ & 0x00000002) != 0); + } + /** + * .grpc.BrokerAuth brokerAuth = 2; + * @return The brokerAuth. + */ + public io.trino.spi.grpc.Endpoints.BrokerAuth getBrokerAuth() { + if (brokerAuthBuilder_ == null) { + return brokerAuth_ == null ? io.trino.spi.grpc.Endpoints.BrokerAuth.getDefaultInstance() : brokerAuth_; + } else { + return brokerAuthBuilder_.getMessage(); + } + } + /** + * .grpc.BrokerAuth brokerAuth = 2; + */ + public Builder setBrokerAuth(io.trino.spi.grpc.Endpoints.BrokerAuth value) { + if (brokerAuthBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + brokerAuth_ = value; + } else { + brokerAuthBuilder_.setMessage(value); + } + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * .grpc.BrokerAuth brokerAuth = 2; + */ + public Builder setBrokerAuth( + io.trino.spi.grpc.Endpoints.BrokerAuth.Builder builderForValue) { + if (brokerAuthBuilder_ == null) { + brokerAuth_ = builderForValue.build(); + } else { + brokerAuthBuilder_.setMessage(builderForValue.build()); + } + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * .grpc.BrokerAuth brokerAuth = 2; + */ + public Builder mergeBrokerAuth(io.trino.spi.grpc.Endpoints.BrokerAuth value) { + if (brokerAuthBuilder_ == null) { + if (((bitField0_ & 0x00000002) != 0) && + brokerAuth_ != null && + brokerAuth_ != io.trino.spi.grpc.Endpoints.BrokerAuth.getDefaultInstance()) { + getBrokerAuthBuilder().mergeFrom(value); + } else { + brokerAuth_ = value; + } + } else { + brokerAuthBuilder_.mergeFrom(value); + } + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * .grpc.BrokerAuth brokerAuth = 2; + */ + public Builder clearBrokerAuth() { + bitField0_ = (bitField0_ & ~0x00000002); + brokerAuth_ = null; + if (brokerAuthBuilder_ != null) { + brokerAuthBuilder_.dispose(); + brokerAuthBuilder_ = null; + } + onChanged(); + return this; + } + /** + * .grpc.BrokerAuth brokerAuth = 2; + */ + public io.trino.spi.grpc.Endpoints.BrokerAuth.Builder getBrokerAuthBuilder() { + bitField0_ |= 0x00000002; + onChanged(); + return getBrokerAuthFieldBuilder().getBuilder(); + } + /** + * .grpc.BrokerAuth brokerAuth = 2; + */ + public io.trino.spi.grpc.Endpoints.BrokerAuthOrBuilder getBrokerAuthOrBuilder() { + if (brokerAuthBuilder_ != null) { + return brokerAuthBuilder_.getMessageOrBuilder(); + } else { + return brokerAuth_ == null ? + io.trino.spi.grpc.Endpoints.BrokerAuth.getDefaultInstance() : brokerAuth_; + } + } + /** + * .grpc.BrokerAuth brokerAuth = 2; + */ + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.BrokerAuth, io.trino.spi.grpc.Endpoints.BrokerAuth.Builder, io.trino.spi.grpc.Endpoints.BrokerAuthOrBuilder> + getBrokerAuthFieldBuilder() { + if (brokerAuthBuilder_ == null) { + brokerAuthBuilder_ = new com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Endpoints.BrokerAuth, io.trino.spi.grpc.Endpoints.BrokerAuth.Builder, io.trino.spi.grpc.Endpoints.BrokerAuthOrBuilder>( + getBrokerAuth(), + getParentForChildren(), + isClean()); + brokerAuth_ = null; + } + return brokerAuthBuilder_; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.ConnectorInstanceDetails) + } + + // @@protoc_insertion_point(class_scope:grpc.ConnectorInstanceDetails) + private static final io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails(); + } + + public static io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public ConnectorInstanceDetails parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface InvokeEndpointRequestOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.InvokeEndpointRequest) + com.google.protobuf.MessageOrBuilder { + + /** + * string tenant = 1; + * @return The tenant. + */ + java.lang.String getTenant(); + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + com.google.protobuf.ByteString + getTenantBytes(); + + /** + * string connector_instance_id = 2; + * @return The connectorInstanceId. + */ + java.lang.String getConnectorInstanceId(); + /** + * string connector_instance_id = 2; + * @return The bytes for connectorInstanceId. + */ + com.google.protobuf.ByteString + getConnectorInstanceIdBytes(); + + /** + * string endpoint_id = 3; + * @return The endpointId. + */ + java.lang.String getEndpointId(); + /** + * string endpoint_id = 3; + * @return The bytes for endpointId. + */ + com.google.protobuf.ByteString + getEndpointIdBytes(); + + /** + * string param_values = 4; + * @return The paramValues. + */ + java.lang.String getParamValues(); + /** + * string param_values = 4; + * @return The bytes for paramValues. + */ + com.google.protobuf.ByteString + getParamValuesBytes(); + + /** + * optional int32 max_pagination_depth = 5; + * @return Whether the maxPaginationDepth field is set. + */ + boolean hasMaxPaginationDepth(); + /** + * optional int32 max_pagination_depth = 5; + * @return The maxPaginationDepth. + */ + int getMaxPaginationDepth(); + } + /** + * Protobuf type {@code grpc.InvokeEndpointRequest} + */ + public static final class InvokeEndpointRequest extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.InvokeEndpointRequest) + InvokeEndpointRequestOrBuilder { + private static final long serialVersionUID = 0L; + // Use InvokeEndpointRequest.newBuilder() to construct. + private InvokeEndpointRequest(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private InvokeEndpointRequest() { + tenant_ = ""; + connectorInstanceId_ = ""; + endpointId_ = ""; + paramValues_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new InvokeEndpointRequest(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_InvokeEndpointRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_InvokeEndpointRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.InvokeEndpointRequest.class, io.trino.spi.grpc.Endpoints.InvokeEndpointRequest.Builder.class); + } + + private int bitField0_; + public static final int TENANT_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + @java.lang.Override + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int CONNECTOR_INSTANCE_ID_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object connectorInstanceId_ = ""; + /** + * string connector_instance_id = 2; + * @return The connectorInstanceId. + */ + @java.lang.Override + public java.lang.String getConnectorInstanceId() { + java.lang.Object ref = connectorInstanceId_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + connectorInstanceId_ = s; + return s; + } + } + /** + * string connector_instance_id = 2; + * @return The bytes for connectorInstanceId. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getConnectorInstanceIdBytes() { + java.lang.Object ref = connectorInstanceId_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + connectorInstanceId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int ENDPOINT_ID_FIELD_NUMBER = 3; + @SuppressWarnings("serial") + private volatile java.lang.Object endpointId_ = ""; + /** + * string endpoint_id = 3; + * @return The endpointId. + */ + @java.lang.Override + public java.lang.String getEndpointId() { + java.lang.Object ref = endpointId_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + endpointId_ = s; + return s; + } + } + /** + * string endpoint_id = 3; + * @return The bytes for endpointId. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getEndpointIdBytes() { + java.lang.Object ref = endpointId_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + endpointId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int PARAM_VALUES_FIELD_NUMBER = 4; + @SuppressWarnings("serial") + private volatile java.lang.Object paramValues_ = ""; + /** + * string param_values = 4; + * @return The paramValues. + */ + @java.lang.Override + public java.lang.String getParamValues() { + java.lang.Object ref = paramValues_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + paramValues_ = s; + return s; + } + } + /** + * string param_values = 4; + * @return The bytes for paramValues. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getParamValuesBytes() { + java.lang.Object ref = paramValues_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + paramValues_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int MAX_PAGINATION_DEPTH_FIELD_NUMBER = 5; + private int maxPaginationDepth_ = 0; + /** + * optional int32 max_pagination_depth = 5; + * @return Whether the maxPaginationDepth field is set. + */ + @java.lang.Override + public boolean hasMaxPaginationDepth() { + return ((bitField0_ & 0x00000001) != 0); + } + /** + * optional int32 max_pagination_depth = 5; + * @return The maxPaginationDepth. + */ + @java.lang.Override + public int getMaxPaginationDepth() { + return maxPaginationDepth_; + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(connectorInstanceId_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, connectorInstanceId_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(endpointId_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 3, endpointId_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(paramValues_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 4, paramValues_); + } + if (((bitField0_ & 0x00000001) != 0)) { + output.writeInt32(5, maxPaginationDepth_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(connectorInstanceId_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, connectorInstanceId_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(endpointId_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(3, endpointId_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(paramValues_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(4, paramValues_); + } + if (((bitField0_ & 0x00000001) != 0)) { + size += com.google.protobuf.CodedOutputStream + .computeInt32Size(5, maxPaginationDepth_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.InvokeEndpointRequest)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.InvokeEndpointRequest other = (io.trino.spi.grpc.Endpoints.InvokeEndpointRequest) obj; + + if (!getTenant() + .equals(other.getTenant())) return false; + if (!getConnectorInstanceId() + .equals(other.getConnectorInstanceId())) return false; + if (!getEndpointId() + .equals(other.getEndpointId())) return false; + if (!getParamValues() + .equals(other.getParamValues())) return false; + if (hasMaxPaginationDepth() != other.hasMaxPaginationDepth()) return false; + if (hasMaxPaginationDepth()) { + if (getMaxPaginationDepth() + != other.getMaxPaginationDepth()) return false; + } + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + TENANT_FIELD_NUMBER; + hash = (53 * hash) + getTenant().hashCode(); + hash = (37 * hash) + CONNECTOR_INSTANCE_ID_FIELD_NUMBER; + hash = (53 * hash) + getConnectorInstanceId().hashCode(); + hash = (37 * hash) + ENDPOINT_ID_FIELD_NUMBER; + hash = (53 * hash) + getEndpointId().hashCode(); + hash = (37 * hash) + PARAM_VALUES_FIELD_NUMBER; + hash = (53 * hash) + getParamValues().hashCode(); + if (hasMaxPaginationDepth()) { + hash = (37 * hash) + MAX_PAGINATION_DEPTH_FIELD_NUMBER; + hash = (53 * hash) + getMaxPaginationDepth(); + } + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.InvokeEndpointRequest parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.InvokeEndpointRequest parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.InvokeEndpointRequest parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.InvokeEndpointRequest parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.InvokeEndpointRequest parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.InvokeEndpointRequest parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.InvokeEndpointRequest parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.InvokeEndpointRequest parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.InvokeEndpointRequest parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.InvokeEndpointRequest parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.InvokeEndpointRequest parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.InvokeEndpointRequest parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.InvokeEndpointRequest prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.InvokeEndpointRequest} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.InvokeEndpointRequest) + io.trino.spi.grpc.Endpoints.InvokeEndpointRequestOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_InvokeEndpointRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_InvokeEndpointRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.InvokeEndpointRequest.class, io.trino.spi.grpc.Endpoints.InvokeEndpointRequest.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.InvokeEndpointRequest.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + tenant_ = ""; + connectorInstanceId_ = ""; + endpointId_ = ""; + paramValues_ = ""; + maxPaginationDepth_ = 0; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_InvokeEndpointRequest_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.InvokeEndpointRequest getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.InvokeEndpointRequest.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.InvokeEndpointRequest build() { + io.trino.spi.grpc.Endpoints.InvokeEndpointRequest result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.InvokeEndpointRequest buildPartial() { + io.trino.spi.grpc.Endpoints.InvokeEndpointRequest result = new io.trino.spi.grpc.Endpoints.InvokeEndpointRequest(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.InvokeEndpointRequest result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.tenant_ = tenant_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.connectorInstanceId_ = connectorInstanceId_; + } + if (((from_bitField0_ & 0x00000004) != 0)) { + result.endpointId_ = endpointId_; + } + if (((from_bitField0_ & 0x00000008) != 0)) { + result.paramValues_ = paramValues_; + } + int to_bitField0_ = 0; + if (((from_bitField0_ & 0x00000010) != 0)) { + result.maxPaginationDepth_ = maxPaginationDepth_; + to_bitField0_ |= 0x00000001; + } + result.bitField0_ |= to_bitField0_; + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.InvokeEndpointRequest) { + return mergeFrom((io.trino.spi.grpc.Endpoints.InvokeEndpointRequest)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.InvokeEndpointRequest other) { + if (other == io.trino.spi.grpc.Endpoints.InvokeEndpointRequest.getDefaultInstance()) return this; + if (!other.getTenant().isEmpty()) { + tenant_ = other.tenant_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getConnectorInstanceId().isEmpty()) { + connectorInstanceId_ = other.connectorInstanceId_; + bitField0_ |= 0x00000002; + onChanged(); + } + if (!other.getEndpointId().isEmpty()) { + endpointId_ = other.endpointId_; + bitField0_ |= 0x00000004; + onChanged(); + } + if (!other.getParamValues().isEmpty()) { + paramValues_ = other.paramValues_; + bitField0_ |= 0x00000008; + onChanged(); + } + if (other.hasMaxPaginationDepth()) { + setMaxPaginationDepth(other.getMaxPaginationDepth()); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + tenant_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + connectorInstanceId_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + case 26: { + endpointId_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000004; + break; + } // case 26 + case 34: { + paramValues_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000008; + break; + } // case 34 + case 40: { + maxPaginationDepth_ = input.readInt32(); + bitField0_ |= 0x00000010; + break; + } // case 40 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant = 1; + * @param value The tenant to set. + * @return This builder for chaining. + */ + public Builder setTenant( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string tenant = 1; + * @return This builder for chaining. + */ + public Builder clearTenant() { + tenant_ = getDefaultInstance().getTenant(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string tenant = 1; + * @param value The bytes for tenant to set. + * @return This builder for chaining. + */ + public Builder setTenantBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object connectorInstanceId_ = ""; + /** + * string connector_instance_id = 2; + * @return The connectorInstanceId. + */ + public java.lang.String getConnectorInstanceId() { + java.lang.Object ref = connectorInstanceId_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + connectorInstanceId_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string connector_instance_id = 2; + * @return The bytes for connectorInstanceId. + */ + public com.google.protobuf.ByteString + getConnectorInstanceIdBytes() { + java.lang.Object ref = connectorInstanceId_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + connectorInstanceId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string connector_instance_id = 2; + * @param value The connectorInstanceId to set. + * @return This builder for chaining. + */ + public Builder setConnectorInstanceId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + connectorInstanceId_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string connector_instance_id = 2; + * @return This builder for chaining. + */ + public Builder clearConnectorInstanceId() { + connectorInstanceId_ = getDefaultInstance().getConnectorInstanceId(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string connector_instance_id = 2; + * @param value The bytes for connectorInstanceId to set. + * @return This builder for chaining. + */ + public Builder setConnectorInstanceIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + connectorInstanceId_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + + private java.lang.Object endpointId_ = ""; + /** + * string endpoint_id = 3; + * @return The endpointId. + */ + public java.lang.String getEndpointId() { + java.lang.Object ref = endpointId_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + endpointId_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string endpoint_id = 3; + * @return The bytes for endpointId. + */ + public com.google.protobuf.ByteString + getEndpointIdBytes() { + java.lang.Object ref = endpointId_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + endpointId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string endpoint_id = 3; + * @param value The endpointId to set. + * @return This builder for chaining. + */ + public Builder setEndpointId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + endpointId_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + /** + * string endpoint_id = 3; + * @return This builder for chaining. + */ + public Builder clearEndpointId() { + endpointId_ = getDefaultInstance().getEndpointId(); + bitField0_ = (bitField0_ & ~0x00000004); + onChanged(); + return this; + } + /** + * string endpoint_id = 3; + * @param value The bytes for endpointId to set. + * @return This builder for chaining. + */ + public Builder setEndpointIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + endpointId_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + + private java.lang.Object paramValues_ = ""; + /** + * string param_values = 4; + * @return The paramValues. + */ + public java.lang.String getParamValues() { + java.lang.Object ref = paramValues_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + paramValues_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string param_values = 4; + * @return The bytes for paramValues. + */ + public com.google.protobuf.ByteString + getParamValuesBytes() { + java.lang.Object ref = paramValues_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + paramValues_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string param_values = 4; + * @param value The paramValues to set. + * @return This builder for chaining. + */ + public Builder setParamValues( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + paramValues_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + /** + * string param_values = 4; + * @return This builder for chaining. + */ + public Builder clearParamValues() { + paramValues_ = getDefaultInstance().getParamValues(); + bitField0_ = (bitField0_ & ~0x00000008); + onChanged(); + return this; + } + /** + * string param_values = 4; + * @param value The bytes for paramValues to set. + * @return This builder for chaining. + */ + public Builder setParamValuesBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + paramValues_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + + private int maxPaginationDepth_ ; + /** + * optional int32 max_pagination_depth = 5; + * @return Whether the maxPaginationDepth field is set. + */ + @java.lang.Override + public boolean hasMaxPaginationDepth() { + return ((bitField0_ & 0x00000010) != 0); + } + /** + * optional int32 max_pagination_depth = 5; + * @return The maxPaginationDepth. + */ + @java.lang.Override + public int getMaxPaginationDepth() { + return maxPaginationDepth_; + } + /** + * optional int32 max_pagination_depth = 5; + * @param value The maxPaginationDepth to set. + * @return This builder for chaining. + */ + public Builder setMaxPaginationDepth(int value) { + + maxPaginationDepth_ = value; + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + /** + * optional int32 max_pagination_depth = 5; + * @return This builder for chaining. + */ + public Builder clearMaxPaginationDepth() { + bitField0_ = (bitField0_ & ~0x00000010); + maxPaginationDepth_ = 0; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.InvokeEndpointRequest) + } + + // @@protoc_insertion_point(class_scope:grpc.InvokeEndpointRequest) + private static final io.trino.spi.grpc.Endpoints.InvokeEndpointRequest DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.InvokeEndpointRequest(); + } + + public static io.trino.spi.grpc.Endpoints.InvokeEndpointRequest getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public InvokeEndpointRequest parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.InvokeEndpointRequest getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface QueryEndpointsRequestOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.QueryEndpointsRequest) + com.google.protobuf.MessageOrBuilder { + + /** + * string tenant = 1; + * @return The tenant. + */ + java.lang.String getTenant(); + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + com.google.protobuf.ByteString + getTenantBytes(); + + /** + * string connector_instance_id = 2; + * @return The connectorInstanceId. + */ + java.lang.String getConnectorInstanceId(); + /** + * string connector_instance_id = 2; + * @return The bytes for connectorInstanceId. + */ + com.google.protobuf.ByteString + getConnectorInstanceIdBytes(); + } + /** + * Protobuf type {@code grpc.QueryEndpointsRequest} + */ + public static final class QueryEndpointsRequest extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.QueryEndpointsRequest) + QueryEndpointsRequestOrBuilder { + private static final long serialVersionUID = 0L; + // Use QueryEndpointsRequest.newBuilder() to construct. + private QueryEndpointsRequest(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private QueryEndpointsRequest() { + tenant_ = ""; + connectorInstanceId_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new QueryEndpointsRequest(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_QueryEndpointsRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_QueryEndpointsRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.QueryEndpointsRequest.class, io.trino.spi.grpc.Endpoints.QueryEndpointsRequest.Builder.class); + } + + public static final int TENANT_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + @java.lang.Override + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int CONNECTOR_INSTANCE_ID_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object connectorInstanceId_ = ""; + /** + * string connector_instance_id = 2; + * @return The connectorInstanceId. + */ + @java.lang.Override + public java.lang.String getConnectorInstanceId() { + java.lang.Object ref = connectorInstanceId_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + connectorInstanceId_ = s; + return s; + } + } + /** + * string connector_instance_id = 2; + * @return The bytes for connectorInstanceId. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getConnectorInstanceIdBytes() { + java.lang.Object ref = connectorInstanceId_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + connectorInstanceId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(connectorInstanceId_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, connectorInstanceId_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(connectorInstanceId_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, connectorInstanceId_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.QueryEndpointsRequest)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.QueryEndpointsRequest other = (io.trino.spi.grpc.Endpoints.QueryEndpointsRequest) obj; + + if (!getTenant() + .equals(other.getTenant())) return false; + if (!getConnectorInstanceId() + .equals(other.getConnectorInstanceId())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + TENANT_FIELD_NUMBER; + hash = (53 * hash) + getTenant().hashCode(); + hash = (37 * hash) + CONNECTOR_INSTANCE_ID_FIELD_NUMBER; + hash = (53 * hash) + getConnectorInstanceId().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.QueryEndpointsRequest parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.QueryEndpointsRequest parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.QueryEndpointsRequest parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.QueryEndpointsRequest parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.QueryEndpointsRequest parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.QueryEndpointsRequest parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.QueryEndpointsRequest parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.QueryEndpointsRequest parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.QueryEndpointsRequest parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.QueryEndpointsRequest parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.QueryEndpointsRequest parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.QueryEndpointsRequest parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.QueryEndpointsRequest prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.QueryEndpointsRequest} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.QueryEndpointsRequest) + io.trino.spi.grpc.Endpoints.QueryEndpointsRequestOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_QueryEndpointsRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_QueryEndpointsRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.QueryEndpointsRequest.class, io.trino.spi.grpc.Endpoints.QueryEndpointsRequest.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.QueryEndpointsRequest.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + tenant_ = ""; + connectorInstanceId_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_QueryEndpointsRequest_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.QueryEndpointsRequest getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.QueryEndpointsRequest.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.QueryEndpointsRequest build() { + io.trino.spi.grpc.Endpoints.QueryEndpointsRequest result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.QueryEndpointsRequest buildPartial() { + io.trino.spi.grpc.Endpoints.QueryEndpointsRequest result = new io.trino.spi.grpc.Endpoints.QueryEndpointsRequest(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.QueryEndpointsRequest result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.tenant_ = tenant_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.connectorInstanceId_ = connectorInstanceId_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.QueryEndpointsRequest) { + return mergeFrom((io.trino.spi.grpc.Endpoints.QueryEndpointsRequest)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.QueryEndpointsRequest other) { + if (other == io.trino.spi.grpc.Endpoints.QueryEndpointsRequest.getDefaultInstance()) return this; + if (!other.getTenant().isEmpty()) { + tenant_ = other.tenant_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getConnectorInstanceId().isEmpty()) { + connectorInstanceId_ = other.connectorInstanceId_; + bitField0_ |= 0x00000002; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + tenant_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + connectorInstanceId_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant = 1; + * @param value The tenant to set. + * @return This builder for chaining. + */ + public Builder setTenant( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string tenant = 1; + * @return This builder for chaining. + */ + public Builder clearTenant() { + tenant_ = getDefaultInstance().getTenant(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string tenant = 1; + * @param value The bytes for tenant to set. + * @return This builder for chaining. + */ + public Builder setTenantBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object connectorInstanceId_ = ""; + /** + * string connector_instance_id = 2; + * @return The connectorInstanceId. + */ + public java.lang.String getConnectorInstanceId() { + java.lang.Object ref = connectorInstanceId_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + connectorInstanceId_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string connector_instance_id = 2; + * @return The bytes for connectorInstanceId. + */ + public com.google.protobuf.ByteString + getConnectorInstanceIdBytes() { + java.lang.Object ref = connectorInstanceId_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + connectorInstanceId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string connector_instance_id = 2; + * @param value The connectorInstanceId to set. + * @return This builder for chaining. + */ + public Builder setConnectorInstanceId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + connectorInstanceId_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string connector_instance_id = 2; + * @return This builder for chaining. + */ + public Builder clearConnectorInstanceId() { + connectorInstanceId_ = getDefaultInstance().getConnectorInstanceId(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string connector_instance_id = 2; + * @param value The bytes for connectorInstanceId to set. + * @return This builder for chaining. + */ + public Builder setConnectorInstanceIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + connectorInstanceId_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.QueryEndpointsRequest) + } + + // @@protoc_insertion_point(class_scope:grpc.QueryEndpointsRequest) + private static final io.trino.spi.grpc.Endpoints.QueryEndpointsRequest DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.QueryEndpointsRequest(); + } + + public static io.trino.spi.grpc.Endpoints.QueryEndpointsRequest getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public QueryEndpointsRequest parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.QueryEndpointsRequest getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface InvokeEndpointReplyOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.InvokeEndpointReply) + com.google.protobuf.MessageOrBuilder { + + /** + * string result = 1; + * @return The result. + */ + java.lang.String getResult(); + /** + * string result = 1; + * @return The bytes for result. + */ + com.google.protobuf.ByteString + getResultBytes(); + } + /** + * Protobuf type {@code grpc.InvokeEndpointReply} + */ + public static final class InvokeEndpointReply extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.InvokeEndpointReply) + InvokeEndpointReplyOrBuilder { + private static final long serialVersionUID = 0L; + // Use InvokeEndpointReply.newBuilder() to construct. + private InvokeEndpointReply(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private InvokeEndpointReply() { + result_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new InvokeEndpointReply(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_InvokeEndpointReply_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_InvokeEndpointReply_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.InvokeEndpointReply.class, io.trino.spi.grpc.Endpoints.InvokeEndpointReply.Builder.class); + } + + public static final int RESULT_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object result_ = ""; + /** + * string result = 1; + * @return The result. + */ + @java.lang.Override + public java.lang.String getResult() { + java.lang.Object ref = result_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + result_ = s; + return s; + } + } + /** + * string result = 1; + * @return The bytes for result. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getResultBytes() { + java.lang.Object ref = result_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + result_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(result_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, result_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(result_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, result_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.InvokeEndpointReply)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.InvokeEndpointReply other = (io.trino.spi.grpc.Endpoints.InvokeEndpointReply) obj; + + if (!getResult() + .equals(other.getResult())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + RESULT_FIELD_NUMBER; + hash = (53 * hash) + getResult().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.InvokeEndpointReply parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.InvokeEndpointReply parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.InvokeEndpointReply parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.InvokeEndpointReply parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.InvokeEndpointReply parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.InvokeEndpointReply parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.InvokeEndpointReply parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.InvokeEndpointReply parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.InvokeEndpointReply parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.InvokeEndpointReply parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.InvokeEndpointReply parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.InvokeEndpointReply parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.InvokeEndpointReply prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.InvokeEndpointReply} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.InvokeEndpointReply) + io.trino.spi.grpc.Endpoints.InvokeEndpointReplyOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_InvokeEndpointReply_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_InvokeEndpointReply_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.InvokeEndpointReply.class, io.trino.spi.grpc.Endpoints.InvokeEndpointReply.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.InvokeEndpointReply.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + result_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_InvokeEndpointReply_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.InvokeEndpointReply getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.InvokeEndpointReply.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.InvokeEndpointReply build() { + io.trino.spi.grpc.Endpoints.InvokeEndpointReply result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.InvokeEndpointReply buildPartial() { + io.trino.spi.grpc.Endpoints.InvokeEndpointReply result = new io.trino.spi.grpc.Endpoints.InvokeEndpointReply(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.InvokeEndpointReply result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.result_ = result_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.InvokeEndpointReply) { + return mergeFrom((io.trino.spi.grpc.Endpoints.InvokeEndpointReply)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.InvokeEndpointReply other) { + if (other == io.trino.spi.grpc.Endpoints.InvokeEndpointReply.getDefaultInstance()) return this; + if (!other.getResult().isEmpty()) { + result_ = other.result_; + bitField0_ |= 0x00000001; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + result_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object result_ = ""; + /** + * string result = 1; + * @return The result. + */ + public java.lang.String getResult() { + java.lang.Object ref = result_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + result_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string result = 1; + * @return The bytes for result. + */ + public com.google.protobuf.ByteString + getResultBytes() { + java.lang.Object ref = result_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + result_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string result = 1; + * @param value The result to set. + * @return This builder for chaining. + */ + public Builder setResult( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + result_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string result = 1; + * @return This builder for chaining. + */ + public Builder clearResult() { + result_ = getDefaultInstance().getResult(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string result = 1; + * @param value The bytes for result to set. + * @return This builder for chaining. + */ + public Builder setResultBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + result_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.InvokeEndpointReply) + } + + // @@protoc_insertion_point(class_scope:grpc.InvokeEndpointReply) + private static final io.trino.spi.grpc.Endpoints.InvokeEndpointReply DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.InvokeEndpointReply(); + } + + public static io.trino.spi.grpc.Endpoints.InvokeEndpointReply getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public InvokeEndpointReply parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.InvokeEndpointReply getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface DataSourceDiscoveryMappingOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.DataSourceDiscoveryMapping) + com.google.protobuf.MessageOrBuilder { + + /** + * string tenant_name = 1; + * @return The tenantName. + */ + java.lang.String getTenantName(); + /** + * string tenant_name = 1; + * @return The bytes for tenantName. + */ + com.google.protobuf.ByteString + getTenantNameBytes(); + + /** + * string connector_id = 2; + * @return The connectorId. + */ + java.lang.String getConnectorId(); + /** + * string connector_id = 2; + * @return The bytes for connectorId. + */ + com.google.protobuf.ByteString + getConnectorIdBytes(); + + /** + * string data_source_id = 3; + * @return The dataSourceId. + */ + java.lang.String getDataSourceId(); + /** + * string data_source_id = 3; + * @return The bytes for dataSourceId. + */ + com.google.protobuf.ByteString + getDataSourceIdBytes(); + + /** + * string identifier = 4; + * @return The identifier. + */ + java.lang.String getIdentifier(); + /** + * string identifier = 4; + * @return The bytes for identifier. + */ + com.google.protobuf.ByteString + getIdentifierBytes(); + + /** + * optional string extra_filter = 5; + * @return Whether the extraFilter field is set. + */ + boolean hasExtraFilter(); + /** + * optional string extra_filter = 5; + * @return The extraFilter. + */ + java.lang.String getExtraFilter(); + /** + * optional string extra_filter = 5; + * @return The bytes for extraFilter. + */ + com.google.protobuf.ByteString + getExtraFilterBytes(); + } + /** + * Protobuf type {@code grpc.DataSourceDiscoveryMapping} + */ + public static final class DataSourceDiscoveryMapping extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.DataSourceDiscoveryMapping) + DataSourceDiscoveryMappingOrBuilder { + private static final long serialVersionUID = 0L; + // Use DataSourceDiscoveryMapping.newBuilder() to construct. + private DataSourceDiscoveryMapping(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private DataSourceDiscoveryMapping() { + tenantName_ = ""; + connectorId_ = ""; + dataSourceId_ = ""; + identifier_ = ""; + extraFilter_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new DataSourceDiscoveryMapping(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSourceDiscoveryMapping_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSourceDiscoveryMapping_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping.class, io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping.Builder.class); + } + + private int bitField0_; + public static final int TENANT_NAME_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object tenantName_ = ""; + /** + * string tenant_name = 1; + * @return The tenantName. + */ + @java.lang.Override + public java.lang.String getTenantName() { + java.lang.Object ref = tenantName_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenantName_ = s; + return s; + } + } + /** + * string tenant_name = 1; + * @return The bytes for tenantName. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantNameBytes() { + java.lang.Object ref = tenantName_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenantName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int CONNECTOR_ID_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object connectorId_ = ""; + /** + * string connector_id = 2; + * @return The connectorId. + */ + @java.lang.Override + public java.lang.String getConnectorId() { + java.lang.Object ref = connectorId_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + connectorId_ = s; + return s; + } + } + /** + * string connector_id = 2; + * @return The bytes for connectorId. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getConnectorIdBytes() { + java.lang.Object ref = connectorId_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + connectorId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int DATA_SOURCE_ID_FIELD_NUMBER = 3; + @SuppressWarnings("serial") + private volatile java.lang.Object dataSourceId_ = ""; + /** + * string data_source_id = 3; + * @return The dataSourceId. + */ + @java.lang.Override + public java.lang.String getDataSourceId() { + java.lang.Object ref = dataSourceId_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + dataSourceId_ = s; + return s; + } + } + /** + * string data_source_id = 3; + * @return The bytes for dataSourceId. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getDataSourceIdBytes() { + java.lang.Object ref = dataSourceId_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + dataSourceId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int IDENTIFIER_FIELD_NUMBER = 4; + @SuppressWarnings("serial") + private volatile java.lang.Object identifier_ = ""; + /** + * string identifier = 4; + * @return The identifier. + */ + @java.lang.Override + public java.lang.String getIdentifier() { + java.lang.Object ref = identifier_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + identifier_ = s; + return s; + } + } + /** + * string identifier = 4; + * @return The bytes for identifier. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getIdentifierBytes() { + java.lang.Object ref = identifier_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + identifier_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int EXTRA_FILTER_FIELD_NUMBER = 5; + @SuppressWarnings("serial") + private volatile java.lang.Object extraFilter_ = ""; + /** + * optional string extra_filter = 5; + * @return Whether the extraFilter field is set. + */ + @java.lang.Override + public boolean hasExtraFilter() { + return ((bitField0_ & 0x00000001) != 0); + } + /** + * optional string extra_filter = 5; + * @return The extraFilter. + */ + @java.lang.Override + public java.lang.String getExtraFilter() { + java.lang.Object ref = extraFilter_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + extraFilter_ = s; + return s; + } + } + /** + * optional string extra_filter = 5; + * @return The bytes for extraFilter. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getExtraFilterBytes() { + java.lang.Object ref = extraFilter_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + extraFilter_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenantName_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, tenantName_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(connectorId_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, connectorId_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(dataSourceId_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 3, dataSourceId_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(identifier_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 4, identifier_); + } + if (((bitField0_ & 0x00000001) != 0)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 5, extraFilter_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenantName_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, tenantName_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(connectorId_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, connectorId_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(dataSourceId_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(3, dataSourceId_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(identifier_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(4, identifier_); + } + if (((bitField0_ & 0x00000001) != 0)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(5, extraFilter_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping other = (io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping) obj; + + if (!getTenantName() + .equals(other.getTenantName())) return false; + if (!getConnectorId() + .equals(other.getConnectorId())) return false; + if (!getDataSourceId() + .equals(other.getDataSourceId())) return false; + if (!getIdentifier() + .equals(other.getIdentifier())) return false; + if (hasExtraFilter() != other.hasExtraFilter()) return false; + if (hasExtraFilter()) { + if (!getExtraFilter() + .equals(other.getExtraFilter())) return false; + } + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + TENANT_NAME_FIELD_NUMBER; + hash = (53 * hash) + getTenantName().hashCode(); + hash = (37 * hash) + CONNECTOR_ID_FIELD_NUMBER; + hash = (53 * hash) + getConnectorId().hashCode(); + hash = (37 * hash) + DATA_SOURCE_ID_FIELD_NUMBER; + hash = (53 * hash) + getDataSourceId().hashCode(); + hash = (37 * hash) + IDENTIFIER_FIELD_NUMBER; + hash = (53 * hash) + getIdentifier().hashCode(); + if (hasExtraFilter()) { + hash = (37 * hash) + EXTRA_FILTER_FIELD_NUMBER; + hash = (53 * hash) + getExtraFilter().hashCode(); + } + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.DataSourceDiscoveryMapping} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.DataSourceDiscoveryMapping) + io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSourceDiscoveryMapping_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSourceDiscoveryMapping_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping.class, io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + tenantName_ = ""; + connectorId_ = ""; + dataSourceId_ = ""; + identifier_ = ""; + extraFilter_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSourceDiscoveryMapping_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping build() { + io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping buildPartial() { + io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping result = new io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.tenantName_ = tenantName_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.connectorId_ = connectorId_; + } + if (((from_bitField0_ & 0x00000004) != 0)) { + result.dataSourceId_ = dataSourceId_; + } + if (((from_bitField0_ & 0x00000008) != 0)) { + result.identifier_ = identifier_; + } + int to_bitField0_ = 0; + if (((from_bitField0_ & 0x00000010) != 0)) { + result.extraFilter_ = extraFilter_; + to_bitField0_ |= 0x00000001; + } + result.bitField0_ |= to_bitField0_; + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping) { + return mergeFrom((io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping other) { + if (other == io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping.getDefaultInstance()) return this; + if (!other.getTenantName().isEmpty()) { + tenantName_ = other.tenantName_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getConnectorId().isEmpty()) { + connectorId_ = other.connectorId_; + bitField0_ |= 0x00000002; + onChanged(); + } + if (!other.getDataSourceId().isEmpty()) { + dataSourceId_ = other.dataSourceId_; + bitField0_ |= 0x00000004; + onChanged(); + } + if (!other.getIdentifier().isEmpty()) { + identifier_ = other.identifier_; + bitField0_ |= 0x00000008; + onChanged(); + } + if (other.hasExtraFilter()) { + extraFilter_ = other.extraFilter_; + bitField0_ |= 0x00000010; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + tenantName_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + connectorId_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + case 26: { + dataSourceId_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000004; + break; + } // case 26 + case 34: { + identifier_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000008; + break; + } // case 34 + case 42: { + extraFilter_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000010; + break; + } // case 42 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object tenantName_ = ""; + /** + * string tenant_name = 1; + * @return The tenantName. + */ + public java.lang.String getTenantName() { + java.lang.Object ref = tenantName_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenantName_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant_name = 1; + * @return The bytes for tenantName. + */ + public com.google.protobuf.ByteString + getTenantNameBytes() { + java.lang.Object ref = tenantName_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenantName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant_name = 1; + * @param value The tenantName to set. + * @return This builder for chaining. + */ + public Builder setTenantName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenantName_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string tenant_name = 1; + * @return This builder for chaining. + */ + public Builder clearTenantName() { + tenantName_ = getDefaultInstance().getTenantName(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string tenant_name = 1; + * @param value The bytes for tenantName to set. + * @return This builder for chaining. + */ + public Builder setTenantNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenantName_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object connectorId_ = ""; + /** + * string connector_id = 2; + * @return The connectorId. + */ + public java.lang.String getConnectorId() { + java.lang.Object ref = connectorId_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + connectorId_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string connector_id = 2; + * @return The bytes for connectorId. + */ + public com.google.protobuf.ByteString + getConnectorIdBytes() { + java.lang.Object ref = connectorId_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + connectorId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string connector_id = 2; + * @param value The connectorId to set. + * @return This builder for chaining. + */ + public Builder setConnectorId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + connectorId_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string connector_id = 2; + * @return This builder for chaining. + */ + public Builder clearConnectorId() { + connectorId_ = getDefaultInstance().getConnectorId(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string connector_id = 2; + * @param value The bytes for connectorId to set. + * @return This builder for chaining. + */ + public Builder setConnectorIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + connectorId_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + + private java.lang.Object dataSourceId_ = ""; + /** + * string data_source_id = 3; + * @return The dataSourceId. + */ + public java.lang.String getDataSourceId() { + java.lang.Object ref = dataSourceId_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + dataSourceId_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string data_source_id = 3; + * @return The bytes for dataSourceId. + */ + public com.google.protobuf.ByteString + getDataSourceIdBytes() { + java.lang.Object ref = dataSourceId_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + dataSourceId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string data_source_id = 3; + * @param value The dataSourceId to set. + * @return This builder for chaining. + */ + public Builder setDataSourceId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + dataSourceId_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + /** + * string data_source_id = 3; + * @return This builder for chaining. + */ + public Builder clearDataSourceId() { + dataSourceId_ = getDefaultInstance().getDataSourceId(); + bitField0_ = (bitField0_ & ~0x00000004); + onChanged(); + return this; + } + /** + * string data_source_id = 3; + * @param value The bytes for dataSourceId to set. + * @return This builder for chaining. + */ + public Builder setDataSourceIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + dataSourceId_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + + private java.lang.Object identifier_ = ""; + /** + * string identifier = 4; + * @return The identifier. + */ + public java.lang.String getIdentifier() { + java.lang.Object ref = identifier_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + identifier_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string identifier = 4; + * @return The bytes for identifier. + */ + public com.google.protobuf.ByteString + getIdentifierBytes() { + java.lang.Object ref = identifier_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + identifier_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string identifier = 4; + * @param value The identifier to set. + * @return This builder for chaining. + */ + public Builder setIdentifier( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + identifier_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + /** + * string identifier = 4; + * @return This builder for chaining. + */ + public Builder clearIdentifier() { + identifier_ = getDefaultInstance().getIdentifier(); + bitField0_ = (bitField0_ & ~0x00000008); + onChanged(); + return this; + } + /** + * string identifier = 4; + * @param value The bytes for identifier to set. + * @return This builder for chaining. + */ + public Builder setIdentifierBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + identifier_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + + private java.lang.Object extraFilter_ = ""; + /** + * optional string extra_filter = 5; + * @return Whether the extraFilter field is set. + */ + public boolean hasExtraFilter() { + return ((bitField0_ & 0x00000010) != 0); + } + /** + * optional string extra_filter = 5; + * @return The extraFilter. + */ + public java.lang.String getExtraFilter() { + java.lang.Object ref = extraFilter_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + extraFilter_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * optional string extra_filter = 5; + * @return The bytes for extraFilter. + */ + public com.google.protobuf.ByteString + getExtraFilterBytes() { + java.lang.Object ref = extraFilter_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + extraFilter_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * optional string extra_filter = 5; + * @param value The extraFilter to set. + * @return This builder for chaining. + */ + public Builder setExtraFilter( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + extraFilter_ = value; + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + /** + * optional string extra_filter = 5; + * @return This builder for chaining. + */ + public Builder clearExtraFilter() { + extraFilter_ = getDefaultInstance().getExtraFilter(); + bitField0_ = (bitField0_ & ~0x00000010); + onChanged(); + return this; + } + /** + * optional string extra_filter = 5; + * @param value The bytes for extraFilter to set. + * @return This builder for chaining. + */ + public Builder setExtraFilterBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + extraFilter_ = value; + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.DataSourceDiscoveryMapping) + } + + // @@protoc_insertion_point(class_scope:grpc.DataSourceDiscoveryMapping) + private static final io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping(); + } + + public static io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public DataSourceDiscoveryMapping parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface DataSourceDiscoveryMappingRequestOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.DataSourceDiscoveryMappingRequest) + com.google.protobuf.MessageOrBuilder { + + /** + * string tenant = 1; + * @return The tenant. + */ + java.lang.String getTenant(); + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + com.google.protobuf.ByteString + getTenantBytes(); + + /** + * string connector_id = 2; + * @return The connectorId. + */ + java.lang.String getConnectorId(); + /** + * string connector_id = 2; + * @return The bytes for connectorId. + */ + com.google.protobuf.ByteString + getConnectorIdBytes(); + } + /** + * Protobuf type {@code grpc.DataSourceDiscoveryMappingRequest} + */ + public static final class DataSourceDiscoveryMappingRequest extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.DataSourceDiscoveryMappingRequest) + DataSourceDiscoveryMappingRequestOrBuilder { + private static final long serialVersionUID = 0L; + // Use DataSourceDiscoveryMappingRequest.newBuilder() to construct. + private DataSourceDiscoveryMappingRequest(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private DataSourceDiscoveryMappingRequest() { + tenant_ = ""; + connectorId_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new DataSourceDiscoveryMappingRequest(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSourceDiscoveryMappingRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSourceDiscoveryMappingRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest.class, io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest.Builder.class); + } + + public static final int TENANT_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + @java.lang.Override + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int CONNECTOR_ID_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object connectorId_ = ""; + /** + * string connector_id = 2; + * @return The connectorId. + */ + @java.lang.Override + public java.lang.String getConnectorId() { + java.lang.Object ref = connectorId_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + connectorId_ = s; + return s; + } + } + /** + * string connector_id = 2; + * @return The bytes for connectorId. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getConnectorIdBytes() { + java.lang.Object ref = connectorId_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + connectorId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(connectorId_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, connectorId_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(connectorId_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, connectorId_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest other = (io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest) obj; + + if (!getTenant() + .equals(other.getTenant())) return false; + if (!getConnectorId() + .equals(other.getConnectorId())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + TENANT_FIELD_NUMBER; + hash = (53 * hash) + getTenant().hashCode(); + hash = (37 * hash) + CONNECTOR_ID_FIELD_NUMBER; + hash = (53 * hash) + getConnectorId().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.DataSourceDiscoveryMappingRequest} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.DataSourceDiscoveryMappingRequest) + io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequestOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSourceDiscoveryMappingRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSourceDiscoveryMappingRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest.class, io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + tenant_ = ""; + connectorId_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_DataSourceDiscoveryMappingRequest_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest build() { + io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest buildPartial() { + io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest result = new io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.tenant_ = tenant_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.connectorId_ = connectorId_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest) { + return mergeFrom((io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest other) { + if (other == io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest.getDefaultInstance()) return this; + if (!other.getTenant().isEmpty()) { + tenant_ = other.tenant_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getConnectorId().isEmpty()) { + connectorId_ = other.connectorId_; + bitField0_ |= 0x00000002; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + tenant_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + connectorId_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant = 1; + * @param value The tenant to set. + * @return This builder for chaining. + */ + public Builder setTenant( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string tenant = 1; + * @return This builder for chaining. + */ + public Builder clearTenant() { + tenant_ = getDefaultInstance().getTenant(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string tenant = 1; + * @param value The bytes for tenant to set. + * @return This builder for chaining. + */ + public Builder setTenantBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object connectorId_ = ""; + /** + * string connector_id = 2; + * @return The connectorId. + */ + public java.lang.String getConnectorId() { + java.lang.Object ref = connectorId_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + connectorId_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string connector_id = 2; + * @return The bytes for connectorId. + */ + public com.google.protobuf.ByteString + getConnectorIdBytes() { + java.lang.Object ref = connectorId_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + connectorId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string connector_id = 2; + * @param value The connectorId to set. + * @return This builder for chaining. + */ + public Builder setConnectorId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + connectorId_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string connector_id = 2; + * @return This builder for chaining. + */ + public Builder clearConnectorId() { + connectorId_ = getDefaultInstance().getConnectorId(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string connector_id = 2; + * @param value The bytes for connectorId to set. + * @return This builder for chaining. + */ + public Builder setConnectorIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + connectorId_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.DataSourceDiscoveryMappingRequest) + } + + // @@protoc_insertion_point(class_scope:grpc.DataSourceDiscoveryMappingRequest) + private static final io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest(); + } + + public static io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public DataSourceDiscoveryMappingRequest parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface GetTrinoConnectorInstancesRequestOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.GetTrinoConnectorInstancesRequest) + com.google.protobuf.MessageOrBuilder { + + /** + * bool include_test_instances = 1; + * @return The includeTestInstances. + */ + boolean getIncludeTestInstances(); + } + /** + * Protobuf type {@code grpc.GetTrinoConnectorInstancesRequest} + */ + public static final class GetTrinoConnectorInstancesRequest extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.GetTrinoConnectorInstancesRequest) + GetTrinoConnectorInstancesRequestOrBuilder { + private static final long serialVersionUID = 0L; + // Use GetTrinoConnectorInstancesRequest.newBuilder() to construct. + private GetTrinoConnectorInstancesRequest(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private GetTrinoConnectorInstancesRequest() { + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new GetTrinoConnectorInstancesRequest(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_GetTrinoConnectorInstancesRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_GetTrinoConnectorInstancesRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest.class, io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest.Builder.class); + } + + public static final int INCLUDE_TEST_INSTANCES_FIELD_NUMBER = 1; + private boolean includeTestInstances_ = false; + /** + * bool include_test_instances = 1; + * @return The includeTestInstances. + */ + @java.lang.Override + public boolean getIncludeTestInstances() { + return includeTestInstances_; + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (includeTestInstances_ != false) { + output.writeBool(1, includeTestInstances_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (includeTestInstances_ != false) { + size += com.google.protobuf.CodedOutputStream + .computeBoolSize(1, includeTestInstances_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest other = (io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest) obj; + + if (getIncludeTestInstances() + != other.getIncludeTestInstances()) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + INCLUDE_TEST_INSTANCES_FIELD_NUMBER; + hash = (53 * hash) + com.google.protobuf.Internal.hashBoolean( + getIncludeTestInstances()); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.GetTrinoConnectorInstancesRequest} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.GetTrinoConnectorInstancesRequest) + io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequestOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_GetTrinoConnectorInstancesRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_GetTrinoConnectorInstancesRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest.class, io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + includeTestInstances_ = false; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_GetTrinoConnectorInstancesRequest_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest build() { + io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest buildPartial() { + io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest result = new io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.includeTestInstances_ = includeTestInstances_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest) { + return mergeFrom((io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest other) { + if (other == io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest.getDefaultInstance()) return this; + if (other.getIncludeTestInstances() != false) { + setIncludeTestInstances(other.getIncludeTestInstances()); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 8: { + includeTestInstances_ = input.readBool(); + bitField0_ |= 0x00000001; + break; + } // case 8 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private boolean includeTestInstances_ ; + /** + * bool include_test_instances = 1; + * @return The includeTestInstances. + */ + @java.lang.Override + public boolean getIncludeTestInstances() { + return includeTestInstances_; + } + /** + * bool include_test_instances = 1; + * @param value The includeTestInstances to set. + * @return This builder for chaining. + */ + public Builder setIncludeTestInstances(boolean value) { + + includeTestInstances_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * bool include_test_instances = 1; + * @return This builder for chaining. + */ + public Builder clearIncludeTestInstances() { + bitField0_ = (bitField0_ & ~0x00000001); + includeTestInstances_ = false; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.GetTrinoConnectorInstancesRequest) + } + + // @@protoc_insertion_point(class_scope:grpc.GetTrinoConnectorInstancesRequest) + private static final io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest(); + } + + public static io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public GetTrinoConnectorInstancesRequest parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface ChecksumOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.Checksum) + com.google.protobuf.MessageOrBuilder { + + /** + * string checksum = 1; + * @return The checksum. + */ + java.lang.String getChecksum(); + /** + * string checksum = 1; + * @return The bytes for checksum. + */ + com.google.protobuf.ByteString + getChecksumBytes(); + } + /** + * Protobuf type {@code grpc.Checksum} + */ + public static final class Checksum extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.Checksum) + ChecksumOrBuilder { + private static final long serialVersionUID = 0L; + // Use Checksum.newBuilder() to construct. + private Checksum(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private Checksum() { + checksum_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new Checksum(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_Checksum_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_Checksum_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.Checksum.class, io.trino.spi.grpc.Endpoints.Checksum.Builder.class); + } + + public static final int CHECKSUM_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object checksum_ = ""; + /** + * string checksum = 1; + * @return The checksum. + */ + @java.lang.Override + public java.lang.String getChecksum() { + java.lang.Object ref = checksum_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + checksum_ = s; + return s; + } + } + /** + * string checksum = 1; + * @return The bytes for checksum. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getChecksumBytes() { + java.lang.Object ref = checksum_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + checksum_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(checksum_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, checksum_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(checksum_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, checksum_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.Checksum)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.Checksum other = (io.trino.spi.grpc.Endpoints.Checksum) obj; + + if (!getChecksum() + .equals(other.getChecksum())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + CHECKSUM_FIELD_NUMBER; + hash = (53 * hash) + getChecksum().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.Checksum parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.Checksum parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.Checksum parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.Checksum parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.Checksum parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.Checksum parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.Checksum parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.Checksum parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.Checksum parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.Checksum parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.Checksum parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.Checksum parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.Checksum prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.Checksum} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.Checksum) + io.trino.spi.grpc.Endpoints.ChecksumOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_Checksum_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_Checksum_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.Checksum.class, io.trino.spi.grpc.Endpoints.Checksum.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.Checksum.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + checksum_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_Checksum_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.Checksum getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.Checksum.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.Checksum build() { + io.trino.spi.grpc.Endpoints.Checksum result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.Checksum buildPartial() { + io.trino.spi.grpc.Endpoints.Checksum result = new io.trino.spi.grpc.Endpoints.Checksum(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.Checksum result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.checksum_ = checksum_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.Checksum) { + return mergeFrom((io.trino.spi.grpc.Endpoints.Checksum)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.Checksum other) { + if (other == io.trino.spi.grpc.Endpoints.Checksum.getDefaultInstance()) return this; + if (!other.getChecksum().isEmpty()) { + checksum_ = other.checksum_; + bitField0_ |= 0x00000001; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + checksum_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object checksum_ = ""; + /** + * string checksum = 1; + * @return The checksum. + */ + public java.lang.String getChecksum() { + java.lang.Object ref = checksum_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + checksum_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string checksum = 1; + * @return The bytes for checksum. + */ + public com.google.protobuf.ByteString + getChecksumBytes() { + java.lang.Object ref = checksum_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + checksum_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string checksum = 1; + * @param value The checksum to set. + * @return This builder for chaining. + */ + public Builder setChecksum( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + checksum_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string checksum = 1; + * @return This builder for chaining. + */ + public Builder clearChecksum() { + checksum_ = getDefaultInstance().getChecksum(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string checksum = 1; + * @param value The bytes for checksum to set. + * @return This builder for chaining. + */ + public Builder setChecksumBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + checksum_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.Checksum) + } + + // @@protoc_insertion_point(class_scope:grpc.Checksum) + private static final io.trino.spi.grpc.Endpoints.Checksum DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.Checksum(); + } + + public static io.trino.spi.grpc.Endpoints.Checksum getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public Checksum parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.Checksum getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface QueryDataSourceRequestOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.QueryDataSourceRequest) + com.google.protobuf.MessageOrBuilder { + + /** + * string name = 1; + * @return The name. + */ + java.lang.String getName(); + /** + * string name = 1; + * @return The bytes for name. + */ + com.google.protobuf.ByteString + getNameBytes(); + } + /** + * Protobuf type {@code grpc.QueryDataSourceRequest} + */ + public static final class QueryDataSourceRequest extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.QueryDataSourceRequest) + QueryDataSourceRequestOrBuilder { + private static final long serialVersionUID = 0L; + // Use QueryDataSourceRequest.newBuilder() to construct. + private QueryDataSourceRequest(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private QueryDataSourceRequest() { + name_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new QueryDataSourceRequest(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_QueryDataSourceRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_QueryDataSourceRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.QueryDataSourceRequest.class, io.trino.spi.grpc.Endpoints.QueryDataSourceRequest.Builder.class); + } + + public static final int NAME_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object name_ = ""; + /** + * string name = 1; + * @return The name. + */ + @java.lang.Override + public java.lang.String getName() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } + } + /** + * string name = 1; + * @return The bytes for name. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(name_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, name_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(name_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, name_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Endpoints.QueryDataSourceRequest)) { + return super.equals(obj); + } + io.trino.spi.grpc.Endpoints.QueryDataSourceRequest other = (io.trino.spi.grpc.Endpoints.QueryDataSourceRequest) obj; + + if (!getName() + .equals(other.getName())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + NAME_FIELD_NUMBER; + hash = (53 * hash) + getName().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Endpoints.QueryDataSourceRequest parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.QueryDataSourceRequest parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.QueryDataSourceRequest parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.QueryDataSourceRequest parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.QueryDataSourceRequest parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Endpoints.QueryDataSourceRequest parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.QueryDataSourceRequest parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.QueryDataSourceRequest parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Endpoints.QueryDataSourceRequest parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Endpoints.QueryDataSourceRequest parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Endpoints.QueryDataSourceRequest parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Endpoints.QueryDataSourceRequest parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Endpoints.QueryDataSourceRequest prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.QueryDataSourceRequest} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.QueryDataSourceRequest) + io.trino.spi.grpc.Endpoints.QueryDataSourceRequestOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_QueryDataSourceRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_QueryDataSourceRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Endpoints.QueryDataSourceRequest.class, io.trino.spi.grpc.Endpoints.QueryDataSourceRequest.Builder.class); + } + + // Construct using io.trino.spi.grpc.Endpoints.QueryDataSourceRequest.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + name_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Endpoints.internal_static_grpc_QueryDataSourceRequest_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.QueryDataSourceRequest getDefaultInstanceForType() { + return io.trino.spi.grpc.Endpoints.QueryDataSourceRequest.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.QueryDataSourceRequest build() { + io.trino.spi.grpc.Endpoints.QueryDataSourceRequest result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.QueryDataSourceRequest buildPartial() { + io.trino.spi.grpc.Endpoints.QueryDataSourceRequest result = new io.trino.spi.grpc.Endpoints.QueryDataSourceRequest(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Endpoints.QueryDataSourceRequest result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.name_ = name_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Endpoints.QueryDataSourceRequest) { + return mergeFrom((io.trino.spi.grpc.Endpoints.QueryDataSourceRequest)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Endpoints.QueryDataSourceRequest other) { + if (other == io.trino.spi.grpc.Endpoints.QueryDataSourceRequest.getDefaultInstance()) return this; + if (!other.getName().isEmpty()) { + name_ = other.name_; + bitField0_ |= 0x00000001; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + name_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object name_ = ""; + /** + * string name = 1; + * @return The name. + */ + public java.lang.String getName() { + java.lang.Object ref = name_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string name = 1; + * @return The bytes for name. + */ + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string name = 1; + * @param value The name to set. + * @return This builder for chaining. + */ + public Builder setName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + name_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string name = 1; + * @return This builder for chaining. + */ + public Builder clearName() { + name_ = getDefaultInstance().getName(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string name = 1; + * @param value The bytes for name to set. + * @return This builder for chaining. + */ + public Builder setNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + name_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.QueryDataSourceRequest) + } + + // @@protoc_insertion_point(class_scope:grpc.QueryDataSourceRequest) + private static final io.trino.spi.grpc.Endpoints.QueryDataSourceRequest DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Endpoints.QueryDataSourceRequest(); + } + + public static io.trino.spi.grpc.Endpoints.QueryDataSourceRequest getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public QueryDataSourceRequest parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Endpoints.QueryDataSourceRequest getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_Parameter_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_Parameter_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_Connector_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_Connector_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_DataSource_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_DataSource_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_DataSourceInstanceInput_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_DataSourceInstanceInput_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_DataSourceInstance_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_DataSourceInstance_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_DataSourceInstanceConnectorDetails_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_DataSourceInstanceConnectorDetails_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_ConnectorInstance_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_ConnectorInstance_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_HttpEndpoint_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_HttpEndpoint_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_BoolResponse_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_BoolResponse_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_BrokerPublicIP_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_BrokerPublicIP_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_BrokerProxyDetails_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_BrokerProxyDetails_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_BrokerClientDetails_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_BrokerClientDetails_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_TrinoConnectorInstance_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_TrinoConnectorInstance_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_TrinoConnectorInstance_ParamsEntry_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_TrinoConnectorInstance_ParamsEntry_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_BrokerHostnames_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_BrokerHostnames_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_EmptyRequest_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_EmptyRequest_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_TenantRequest_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_TenantRequest_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_ConnectorCapabilitiesRequest_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_ConnectorCapabilitiesRequest_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_EmptyReply_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_EmptyReply_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_SingleIDRequest_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_SingleIDRequest_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_SingleIDReply_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_SingleIDReply_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_MultipleIDsRequest_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_MultipleIDsRequest_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_BrokerRequest_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_BrokerRequest_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_Broker_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_Broker_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_Tenant_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_Tenant_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_ConnectorInstanceCreateRequest_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_ConnectorInstanceCreateRequest_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_DataSourceList_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_DataSourceList_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_ConnectorInstanceEditRequest_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_ConnectorInstanceEditRequest_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_BrokerAuth_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_BrokerAuth_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_ConnectorInstanceDetails_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_ConnectorInstanceDetails_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_InvokeEndpointRequest_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_InvokeEndpointRequest_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_QueryEndpointsRequest_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_QueryEndpointsRequest_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_InvokeEndpointReply_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_InvokeEndpointReply_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_DataSourceDiscoveryMapping_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_DataSourceDiscoveryMapping_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_DataSourceDiscoveryMappingRequest_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_DataSourceDiscoveryMappingRequest_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_GetTrinoConnectorInstancesRequest_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_GetTrinoConnectorInstancesRequest_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_Checksum_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_Checksum_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_QueryDataSourceRequest_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_QueryDataSourceRequest_fieldAccessorTable; + + public static com.google.protobuf.Descriptors.FileDescriptor + getDescriptor() { + return descriptor; + } + private static com.google.protobuf.Descriptors.FileDescriptor + descriptor; + static { + java.lang.String[] descriptorData = { + "\n\017endpoints.proto\022\004grpc\032\033google/protobuf" + + "/empty.proto\"\230\002\n\tParameter\022\n\n\002id\030\001 \001(\t\022\014" + + "\n\004name\030\002 \001(\t\022\024\n\014display_name\030\003 \001(\t\022\030\n\013co" + + "nst_value\030\004 \001(\tH\000\210\001\001\022\014\n\004type\030\005 \001(\005\022\020\n\010re" + + "quired\030\006 \001(\010\022\024\n\007default\030\007 \001(\tH\001\210\001\001\022\024\n\007ex" + + "ample\030\010 \001(\tH\002\210\001\001\022\020\n\010nullable\030\t \001(\010\022\023\n\013de" + + "scription\030\n \001(\t\022\027\n\ntrino_name\030\013 \001(\tH\003\210\001\001" + + "B\016\n\014_const_valueB\n\n\010_defaultB\n\n\010_example" + + "B\r\n\013_trino_name\"\354\001\n\tConnector\022\n\n\002id\030\001 \001(" + + "\t\022\014\n\004name\030\002 \001(\t\022\030\n\013description\030\003 \001(\tH\000\210\001" + + "\001\022\027\n\017base_url_format\030\004 \001(\t\022\027\n\017base_url_p" + + "arams\030\005 \001(\014\022\024\n\014capabilities\030\006 \001(\t\022\025\n\010cat" + + "egory\030\007 \001(\tH\001\210\001\001\022/\n\020connector_status\030\010 \001" + + "(\0162\025.grpc.ConnectorStatusB\016\n\014_descriptio" + + "nB\013\n\t_category\"|\n\nDataSource\022\n\n\002id\030\001 \001(\t" + + "\022\016\n\006vendor\030\002 \001(\t\022\024\n\007product\030\003 \001(\tH\000\210\001\001\022\014" + + "\n\004type\030\004 \001(\t\022\014\n\004name\030\005 \001(\t\022\024\n\014display_na" + + "me\030\006 \001(\tB\n\n\010_product\"p\n\027DataSourceInstan" + + "ceInput\022\026\n\016data_source_id\030\001 \001(\t\022\016\n\006schem" + + "e\030\002 \001(\t\022\r\n\005table\030\003 \001(\t\022\023\n\006filter\030\004 \001(\tH\000" + + "\210\001\001B\t\n\007_filter\"\275\001\n\022DataSourceInstance\022\n\n" + + "\002id\030\001 \001(\t\022\035\n\025connector_instance_id\030\002 \001(\t" + + "\022\026\n\016data_source_id\030\003 \001(\t\022%\n\013data_source\030" + + "\004 \001(\0132\020.grpc.DataSource\022\016\n\006scheme\030\005 \001(\t\022" + + "\r\n\005table\030\006 \001(\t\022\023\n\006filter\030\007 \001(\tH\000\210\001\001B\t\n\007_" + + "filter\"\210\001\n\"DataSourceInstanceConnectorDe" + + "tails\0224\n\022dataSourceInstance\030\001 \001(\0132\030.grpc" + + ".DataSourceInstance\022\026\n\016connector_name\030\002 " + + "\001(\t\022\024\n\014catalog_name\030\003 \001(\t\"\251\002\n\021ConnectorI" + + "nstance\022\n\n\002id\030\001 \001(\t\022\014\n\004name\030\002 \001(\t\022\021\n\tis_" + + "custom\030\003 \001(\010\022\024\n\014connector_id\030\004 \001(\t\022\037\n\022la" + + "st_activity_time\030\005 \001(\003H\000\210\001\001\022\"\n\tconnector" + + "\030\006 \001(\0132\017.grpc.Connector\022.\n\014data_sources\030" + + "\007 \003(\0132\030.grpc.DataSourceInstance\022\034\n\006broke" + + "r\030\010 \001(\0132\014.grpc.Broker\022\023\n\013tenant_name\030\t \001" + + "(\t\022\022\n\ncreated_at\030\n \001(\003B\025\n\023_last_activity" + + "_time\"\376\001\n\014HttpEndpoint\022\n\n\002id\030\001 \001(\t\022\024\n\014co" + + "nnector_id\030\002 \001(\t\022\014\n\004name\030\003 \001(\t\022\030\n\013descri" + + "ption\030\004 \001(\tH\000\210\001\001\022\023\n\013method_type\030\005 \001(\005\022\022\n" + + "\nurl_format\030\006 \001(\t\022+\n\022request_parameters\030" + + "\007 \003(\0132\017.grpc.Parameter\022\037\n\027connector_inst" + + "ance_name\030\010 \001(\t\022\035\n\025connector_instance_id" + + "\030\t \001(\tB\016\n\014_description\"\036\n\014BoolResponse\022\016" + + "\n\006istrue\030\001 \001(\010\"8\n\016BrokerPublicIP\022\023\n\013tena" + + "nt_name\030\001 \001(\t\022\021\n\tpublic_ip\030\002 \001(\t\"\211\002\n\022Bro" + + "kerProxyDetails\022\030\n\020broker_server_ip\030\001 \001(" + + "\t\022\032\n\022broker_server_port\030\002 \001(\005\022\033\n\023broker_" + + "server_token\030\003 \001(\t\022\022\n\nproxy_name\030\004 \001(\t\022\026" + + "\n\016proxy_password\030\005 \001(\t\022\034\n\024socks_proxy_us" + + "ername\030\006 \001(\t\022\034\n\024socks_proxy_password\030\007 \001" + + "(\t\022\016\n\006subnet\030\010 \001(\005\022\023\n\013VisitorPort\030\t \001(\005\022" + + "\023\n\013tenant_name\030\n \001(\t\"L\n\023BrokerClientDeta" + + "ils\022\016\n\006tenant\030\001 \001(\t\022\022\n\ndescope_id\030\002 \001(\t\022" + + "\021\n\tclient_ip\030\003 \001(\t\"\254\002\n\026TrinoConnectorIns" + + "tance\022\n\n\002id\030\001 \001(\t\022\014\n\004name\030\002 \001(\t\022\033\n\023vega_" + + "connector_name\030\003 \001(\t\022\034\n\024trino_connector_" + + "name\030\004 \001(\t\0228\n\006params\030\005 \003(\0132(.grpc.TrinoC" + + "onnectorInstance.ParamsEntry\022.\n\014data_sou" + + "rces\030\006 \003(\0132\030.grpc.DataSourceInstance\022\017\n\007" + + "is_test\030\007 \001(\010\022\023\n\013tenant_name\030\010 \001(\t\032-\n\013Pa" + + "ramsEntry\022\013\n\003key\030\001 \001(\t\022\r\n\005value\030\002 \001(\t:\0028" + + "\001\"H\n\017BrokerHostnames\022\016\n\006subnet\030\001 \001(\r\022%\n\035" + + "connector_instances_hostnames\030\002 \003(\t\"\016\n\014E" + + "mptyRequest\"\037\n\rTenantRequest\022\016\n\006tenant\030\001" + + " \001(\t\"=\n\034ConnectorCapabilitiesRequest\022\035\n\025" + + "connectorCapabilities\030\001 \001(\r\"\014\n\nEmptyRepl" + + "y\"-\n\017SingleIDRequest\022\016\n\006tenant\030\001 \001(\t\022\n\n\002" + + "id\030\002 \001(\t\"\033\n\rSingleIDReply\022\n\n\002id\030\001 \001(\t\"1\n" + + "\022MultipleIDsRequest\022\016\n\006tenant\030\001 \001(\t\022\013\n\003i" + + "ds\030\002 \003(\t\"2\n\rBrokerRequest\022\n\n\002id\030\001 \001(\t\022\025\n" + + "\rshould_create\030\002 \001(\010\";\n\006Broker\022\n\n\002id\030\001 \001" + + "(\t\022\022\n\nfirst_seen\030\002 \001(\003\022\021\n\tlast_seen\030\003 \001(" + + "\003\"\"\n\006Tenant\022\014\n\004name\030\001 \001(\t\022\n\n\002id\030\002 \001(\t\"\330\001" + + "\n\036ConnectorInstanceCreateRequest\022\034\n\006tena" + + "nt\030\001 \001(\0132\014.grpc.Tenant\022\n\n\002id\030\002 \001(\t\022\014\n\004na" + + "me\030\003 \001(\t\022\024\n\014param_values\030\004 \001(\t\0223\n\014data_s" + + "ources\030\005 \003(\0132\035.grpc.DataSourceInstanceIn" + + "put\022(\n\006broker\030\006 \001(\0132\023.grpc.BrokerRequest" + + "H\000\210\001\001B\t\n\007_broker\"@\n\016DataSourceList\022.\n\007so" + + "urces\030\001 \003(\0132\035.grpc.DataSourceInstanceInp" + + "ut\"\206\002\n\034ConnectorInstanceEditRequest\022\034\n\006t" + + "enant\030\001 \001(\0132\014.grpc.Tenant\022\n\n\002id\030\002 \001(\t\022\021\n" + + "\004name\030\003 \001(\tH\001\210\001\001\022\031\n\014param_values\030\004 \001(\tH\002" + + "\210\001\001\022-\n\017no_data_sources\030\005 \001(\0132\022.grpc.Empt" + + "yRequestH\000\0220\n\020data_source_list\030\006 \001(\0132\024.g" + + "rpc.DataSourceListH\000B\023\n\021data_sources_mod" + + "eB\007\n\005_nameB\017\n\r_param_values\",\n\nBrokerAut" + + "h\022\n\n\002id\030\001 \001(\t\022\022\n\naccess_key\030\002 \001(\t\"t\n\030Con" + + "nectorInstanceDetails\0222\n\021connectorInstan" + + "ce\030\001 \001(\0132\027.grpc.ConnectorInstance\022$\n\nbro" + + "kerAuth\030\002 \001(\0132\020.grpc.BrokerAuth\"\255\001\n\025Invo" + + "keEndpointRequest\022\016\n\006tenant\030\001 \001(\t\022\035\n\025con" + + "nector_instance_id\030\002 \001(\t\022\023\n\013endpoint_id\030" + + "\003 \001(\t\022\024\n\014param_values\030\004 \001(\t\022!\n\024max_pagin" + + "ation_depth\030\005 \001(\005H\000\210\001\001B\027\n\025_max_paginatio" + + "n_depth\"F\n\025QueryEndpointsRequest\022\016\n\006tena" + + "nt\030\001 \001(\t\022\035\n\025connector_instance_id\030\002 \001(\t\"" + + "%\n\023InvokeEndpointReply\022\016\n\006result\030\001 \001(\t\"\237" + + "\001\n\032DataSourceDiscoveryMapping\022\023\n\013tenant_" + + "name\030\001 \001(\t\022\024\n\014connector_id\030\002 \001(\t\022\026\n\016data" + + "_source_id\030\003 \001(\t\022\022\n\nidentifier\030\004 \001(\t\022\031\n\014" + + "extra_filter\030\005 \001(\tH\000\210\001\001B\017\n\r_extra_filter" + + "\"I\n!DataSourceDiscoveryMappingRequest\022\016\n" + + "\006tenant\030\001 \001(\t\022\024\n\014connector_id\030\002 \001(\t\"C\n!G" + + "etTrinoConnectorInstancesRequest\022\036\n\026incl" + + "ude_test_instances\030\001 \001(\010\"\034\n\010Checksum\022\020\n\010" + + "checksum\030\001 \001(\t\"&\n\026QueryDataSourceRequest" + + "\022\014\n\004name\030\001 \001(\t*H\n\017ConnectorStatus\022\013\n\007REG" + + "ULAR\020\000\022\013\n\007PREVIEW\020\001\022\017\n\013COMING_SOON\020\002\022\n\n\006" + + "HIDDEN\020\0032\236\025\n\020EndpointsService\022V\n&QueryCo" + + "nnectorTestConnectionEndpointID\022\025.grpc.S" + + "ingleIDRequest\032\023.grpc.SingleIDReply\"\000\022P\n" + + "\"QueryConnectorParametersToPopulate\022\025.gr" + + "pc.SingleIDRequest\032\017.grpc.Parameter\"\0000\001\022" + + "E\n\024QueryConnectorsByIDs\022\030.grpc.MultipleI" + + "DsRequest\032\017.grpc.Connector\"\0000\001\022:\n\017QueryC" + + "onnectors\022\022.grpc.EmptyRequest\032\017.grpc.Con" + + "nector\"\0000\001\022?\n\020IsTrinoConnector\022\025.grpc.Si" + + "ngleIDRequest\032\022.grpc.BoolResponse\"\000\022G\n\030I" + + "sTrinoConnectorInstance\022\025.grpc.SingleIDR" + + "equest\032\022.grpc.BoolResponse\"\000\022U\n\034QueryCon" + + "nectorInstancesByIDs\022\030.grpc.MultipleIDsR" + + "equest\032\027.grpc.ConnectorInstance\"\0000\001\022^\n%Q" + + "ueryConnectorInstancesByConnectorIDs\022\030.g" + + "rpc.MultipleIDsRequest\032\027.grpc.ConnectorI" + + "nstance\"\0000\001\022K\n\027QueryConnectorInstances\022\023" + + ".grpc.TenantRequest\032\027.grpc.ConnectorInst" + + "ance\"\0000\001\022d\n!QueryAllCapableConnectorInst" + + "ances\022\".grpc.ConnectorCapabilitiesReques" + + "t\032\027.grpc.ConnectorInstance\"\0000\001\022a\n\027Create" + + "ConnectorInstance\022$.grpc.ConnectorInstan" + + "ceCreateRequest\032\036.grpc.ConnectorInstance" + + "Details\"\000\022V\n\025EditConnectorInstance\022\".grp" + + "c.ConnectorInstanceEditRequest\032\027.grpc.Co" + + "nnectorInstance\"\000\022D\n\027DeleteConnectorInst" + + "ance\022\025.grpc.SingleIDRequest\032\020.grpc.Empty" + + "Reply\"\000\022`\n&QueryDataSourcesByConnectorIn" + + "stanceIDs\022\030.grpc.MultipleIDsRequest\032\030.gr" + + "pc.DataSourceInstance\"\0000\001\022E\n\016QueryEndpoi" + + "nts\022\033.grpc.QueryEndpointsRequest\032\022.grpc." + + "HttpEndpoint\"\0000\001\022g\n\032GetTrinoConnectorIns" + + "tances\022\'.grpc.GetTrinoConnectorInstances" + + "Request\032\034.grpc.TrinoConnectorInstance\"\0000" + + "\001\022C\n\022GetBrokerHostnames\022\022.grpc.EmptyRequ" + + "est\032\025.grpc.BrokerHostnames\"\0000\001\022R\n\031GetTri" + + "noConnectorInstance\022\025.grpc.SingleIDReque" + + "st\032\034.grpc.TrinoConnectorInstance\"\000\022L\n\016In" + + "vokeEndpoint\022\033.grpc.InvokeEndpointReques" + + "t\032\031.grpc.InvokeEndpointReply\"\0000\001\022G\n\016Regi" + + "sterBroker\022\031.grpc.BrokerClientDetails\032\030." + + "grpc.BrokerProxyDetails\"\000\022>\n\nGetBrokers\022" + + "\022.grpc.EmptyRequest\032\030.grpc.BrokerProxyDe" + + "tails\"\0000\001\022E\n\020GetTenantBrokers\022\023.grpc.Ten" + + "antRequest\032\030.grpc.BrokerProxyDetails\"\0000\001" + + "\022F\n\026GetAllBrokersPublicIPs\022\022.grpc.EmptyR" + + "equest\032\024.grpc.BrokerPublicIP\"\0000\001\022G\n\025Quer" + + "yDataSourcesByIDs\022\030.grpc.MultipleIDsRequ" + + "est\032\020.grpc.DataSource\"\0000\001\022R\n\030QueryDataSo" + + "urceInstances\022\030.grpc.MultipleIDsRequest\032" + + "\030.grpc.DataSourceInstance\"\0000\001\022=\n\020QueryDa" + + "taSources\022\023.grpc.TenantRequest\032\020.grpc.Da" + + "taSource\"\0000\001\022I\n\025QueryDataSourceByName\022\034." + + "grpc.QueryDataSourceRequest\032\020.grpc.DataS" + + "ource\"\000\022|\n+QueryDataSourceDiscoveryMappi" + + "ngForConnector\022\'.grpc.DataSourceDiscover" + + "yMappingRequest\032 .grpc.DataSourceDiscove" + + "ryMapping\"\0000\001\022^\n\"QueryAllDataSourceDisco" + + "veryMapping\022\022.grpc.EmptyRequest\032 .grpc.D" + + "ataSourceDiscoveryMapping\"\0000\001\022I\n\035GetConn" + + "ectorInstancesChecksum\022\026.google.protobuf" + + ".Empty\032\016.grpc.Checksum\"\000\022~\n4GetDataSourc" + + "eInstanceConnectorDetailsByDataSourceIDs" + + "\022\030.grpc.MultipleIDsRequest\032(.grpc.DataSo" + + "urceInstanceConnectorDetails\"\0000\001\022\206\001\n getQueryConnectorTestConnectionEndpointIDMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "QueryConnectorTestConnectionEndpointID", + requestType = io.trino.spi.grpc.Endpoints.SingleIDRequest.class, + responseType = io.trino.spi.grpc.Endpoints.SingleIDReply.class, + methodType = io.grpc.MethodDescriptor.MethodType.UNARY) + public static io.grpc.MethodDescriptor getQueryConnectorTestConnectionEndpointIDMethod() { + io.grpc.MethodDescriptor getQueryConnectorTestConnectionEndpointIDMethod; + if ((getQueryConnectorTestConnectionEndpointIDMethod = EndpointsServiceGrpc.getQueryConnectorTestConnectionEndpointIDMethod) == null) { + synchronized (EndpointsServiceGrpc.class) { + if ((getQueryConnectorTestConnectionEndpointIDMethod = EndpointsServiceGrpc.getQueryConnectorTestConnectionEndpointIDMethod) == null) { + EndpointsServiceGrpc.getQueryConnectorTestConnectionEndpointIDMethod = getQueryConnectorTestConnectionEndpointIDMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.UNARY) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "QueryConnectorTestConnectionEndpointID")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.SingleIDRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.SingleIDReply.getDefaultInstance())) + .setSchemaDescriptor(new EndpointsServiceMethodDescriptorSupplier("QueryConnectorTestConnectionEndpointID")) + .build(); + } + } + } + return getQueryConnectorTestConnectionEndpointIDMethod; + } + + private static volatile io.grpc.MethodDescriptor getQueryConnectorParametersToPopulateMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "QueryConnectorParametersToPopulate", + requestType = io.trino.spi.grpc.Endpoints.SingleIDRequest.class, + responseType = io.trino.spi.grpc.Endpoints.Parameter.class, + methodType = io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + public static io.grpc.MethodDescriptor getQueryConnectorParametersToPopulateMethod() { + io.grpc.MethodDescriptor getQueryConnectorParametersToPopulateMethod; + if ((getQueryConnectorParametersToPopulateMethod = EndpointsServiceGrpc.getQueryConnectorParametersToPopulateMethod) == null) { + synchronized (EndpointsServiceGrpc.class) { + if ((getQueryConnectorParametersToPopulateMethod = EndpointsServiceGrpc.getQueryConnectorParametersToPopulateMethod) == null) { + EndpointsServiceGrpc.getQueryConnectorParametersToPopulateMethod = getQueryConnectorParametersToPopulateMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "QueryConnectorParametersToPopulate")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.SingleIDRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.Parameter.getDefaultInstance())) + .setSchemaDescriptor(new EndpointsServiceMethodDescriptorSupplier("QueryConnectorParametersToPopulate")) + .build(); + } + } + } + return getQueryConnectorParametersToPopulateMethod; + } + + private static volatile io.grpc.MethodDescriptor getQueryConnectorsByIDsMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "QueryConnectorsByIDs", + requestType = io.trino.spi.grpc.Endpoints.MultipleIDsRequest.class, + responseType = io.trino.spi.grpc.Endpoints.Connector.class, + methodType = io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + public static io.grpc.MethodDescriptor getQueryConnectorsByIDsMethod() { + io.grpc.MethodDescriptor getQueryConnectorsByIDsMethod; + if ((getQueryConnectorsByIDsMethod = EndpointsServiceGrpc.getQueryConnectorsByIDsMethod) == null) { + synchronized (EndpointsServiceGrpc.class) { + if ((getQueryConnectorsByIDsMethod = EndpointsServiceGrpc.getQueryConnectorsByIDsMethod) == null) { + EndpointsServiceGrpc.getQueryConnectorsByIDsMethod = getQueryConnectorsByIDsMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "QueryConnectorsByIDs")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.MultipleIDsRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.Connector.getDefaultInstance())) + .setSchemaDescriptor(new EndpointsServiceMethodDescriptorSupplier("QueryConnectorsByIDs")) + .build(); + } + } + } + return getQueryConnectorsByIDsMethod; + } + + private static volatile io.grpc.MethodDescriptor getQueryConnectorsMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "QueryConnectors", + requestType = io.trino.spi.grpc.Endpoints.EmptyRequest.class, + responseType = io.trino.spi.grpc.Endpoints.Connector.class, + methodType = io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + public static io.grpc.MethodDescriptor getQueryConnectorsMethod() { + io.grpc.MethodDescriptor getQueryConnectorsMethod; + if ((getQueryConnectorsMethod = EndpointsServiceGrpc.getQueryConnectorsMethod) == null) { + synchronized (EndpointsServiceGrpc.class) { + if ((getQueryConnectorsMethod = EndpointsServiceGrpc.getQueryConnectorsMethod) == null) { + EndpointsServiceGrpc.getQueryConnectorsMethod = getQueryConnectorsMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "QueryConnectors")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.EmptyRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.Connector.getDefaultInstance())) + .setSchemaDescriptor(new EndpointsServiceMethodDescriptorSupplier("QueryConnectors")) + .build(); + } + } + } + return getQueryConnectorsMethod; + } + + private static volatile io.grpc.MethodDescriptor getIsTrinoConnectorMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "IsTrinoConnector", + requestType = io.trino.spi.grpc.Endpoints.SingleIDRequest.class, + responseType = io.trino.spi.grpc.Endpoints.BoolResponse.class, + methodType = io.grpc.MethodDescriptor.MethodType.UNARY) + public static io.grpc.MethodDescriptor getIsTrinoConnectorMethod() { + io.grpc.MethodDescriptor getIsTrinoConnectorMethod; + if ((getIsTrinoConnectorMethod = EndpointsServiceGrpc.getIsTrinoConnectorMethod) == null) { + synchronized (EndpointsServiceGrpc.class) { + if ((getIsTrinoConnectorMethod = EndpointsServiceGrpc.getIsTrinoConnectorMethod) == null) { + EndpointsServiceGrpc.getIsTrinoConnectorMethod = getIsTrinoConnectorMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.UNARY) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "IsTrinoConnector")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.SingleIDRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.BoolResponse.getDefaultInstance())) + .setSchemaDescriptor(new EndpointsServiceMethodDescriptorSupplier("IsTrinoConnector")) + .build(); + } + } + } + return getIsTrinoConnectorMethod; + } + + private static volatile io.grpc.MethodDescriptor getIsTrinoConnectorInstanceMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "IsTrinoConnectorInstance", + requestType = io.trino.spi.grpc.Endpoints.SingleIDRequest.class, + responseType = io.trino.spi.grpc.Endpoints.BoolResponse.class, + methodType = io.grpc.MethodDescriptor.MethodType.UNARY) + public static io.grpc.MethodDescriptor getIsTrinoConnectorInstanceMethod() { + io.grpc.MethodDescriptor getIsTrinoConnectorInstanceMethod; + if ((getIsTrinoConnectorInstanceMethod = EndpointsServiceGrpc.getIsTrinoConnectorInstanceMethod) == null) { + synchronized (EndpointsServiceGrpc.class) { + if ((getIsTrinoConnectorInstanceMethod = EndpointsServiceGrpc.getIsTrinoConnectorInstanceMethod) == null) { + EndpointsServiceGrpc.getIsTrinoConnectorInstanceMethod = getIsTrinoConnectorInstanceMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.UNARY) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "IsTrinoConnectorInstance")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.SingleIDRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.BoolResponse.getDefaultInstance())) + .setSchemaDescriptor(new EndpointsServiceMethodDescriptorSupplier("IsTrinoConnectorInstance")) + .build(); + } + } + } + return getIsTrinoConnectorInstanceMethod; + } + + private static volatile io.grpc.MethodDescriptor getQueryConnectorInstancesByIDsMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "QueryConnectorInstancesByIDs", + requestType = io.trino.spi.grpc.Endpoints.MultipleIDsRequest.class, + responseType = io.trino.spi.grpc.Endpoints.ConnectorInstance.class, + methodType = io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + public static io.grpc.MethodDescriptor getQueryConnectorInstancesByIDsMethod() { + io.grpc.MethodDescriptor getQueryConnectorInstancesByIDsMethod; + if ((getQueryConnectorInstancesByIDsMethod = EndpointsServiceGrpc.getQueryConnectorInstancesByIDsMethod) == null) { + synchronized (EndpointsServiceGrpc.class) { + if ((getQueryConnectorInstancesByIDsMethod = EndpointsServiceGrpc.getQueryConnectorInstancesByIDsMethod) == null) { + EndpointsServiceGrpc.getQueryConnectorInstancesByIDsMethod = getQueryConnectorInstancesByIDsMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "QueryConnectorInstancesByIDs")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.MultipleIDsRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.ConnectorInstance.getDefaultInstance())) + .setSchemaDescriptor(new EndpointsServiceMethodDescriptorSupplier("QueryConnectorInstancesByIDs")) + .build(); + } + } + } + return getQueryConnectorInstancesByIDsMethod; + } + + private static volatile io.grpc.MethodDescriptor getQueryConnectorInstancesByConnectorIDsMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "QueryConnectorInstancesByConnectorIDs", + requestType = io.trino.spi.grpc.Endpoints.MultipleIDsRequest.class, + responseType = io.trino.spi.grpc.Endpoints.ConnectorInstance.class, + methodType = io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + public static io.grpc.MethodDescriptor getQueryConnectorInstancesByConnectorIDsMethod() { + io.grpc.MethodDescriptor getQueryConnectorInstancesByConnectorIDsMethod; + if ((getQueryConnectorInstancesByConnectorIDsMethod = EndpointsServiceGrpc.getQueryConnectorInstancesByConnectorIDsMethod) == null) { + synchronized (EndpointsServiceGrpc.class) { + if ((getQueryConnectorInstancesByConnectorIDsMethod = EndpointsServiceGrpc.getQueryConnectorInstancesByConnectorIDsMethod) == null) { + EndpointsServiceGrpc.getQueryConnectorInstancesByConnectorIDsMethod = getQueryConnectorInstancesByConnectorIDsMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "QueryConnectorInstancesByConnectorIDs")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.MultipleIDsRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.ConnectorInstance.getDefaultInstance())) + .setSchemaDescriptor(new EndpointsServiceMethodDescriptorSupplier("QueryConnectorInstancesByConnectorIDs")) + .build(); + } + } + } + return getQueryConnectorInstancesByConnectorIDsMethod; + } + + private static volatile io.grpc.MethodDescriptor getQueryConnectorInstancesMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "QueryConnectorInstances", + requestType = io.trino.spi.grpc.Endpoints.TenantRequest.class, + responseType = io.trino.spi.grpc.Endpoints.ConnectorInstance.class, + methodType = io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + public static io.grpc.MethodDescriptor getQueryConnectorInstancesMethod() { + io.grpc.MethodDescriptor getQueryConnectorInstancesMethod; + if ((getQueryConnectorInstancesMethod = EndpointsServiceGrpc.getQueryConnectorInstancesMethod) == null) { + synchronized (EndpointsServiceGrpc.class) { + if ((getQueryConnectorInstancesMethod = EndpointsServiceGrpc.getQueryConnectorInstancesMethod) == null) { + EndpointsServiceGrpc.getQueryConnectorInstancesMethod = getQueryConnectorInstancesMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "QueryConnectorInstances")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.TenantRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.ConnectorInstance.getDefaultInstance())) + .setSchemaDescriptor(new EndpointsServiceMethodDescriptorSupplier("QueryConnectorInstances")) + .build(); + } + } + } + return getQueryConnectorInstancesMethod; + } + + private static volatile io.grpc.MethodDescriptor getQueryAllCapableConnectorInstancesMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "QueryAllCapableConnectorInstances", + requestType = io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest.class, + responseType = io.trino.spi.grpc.Endpoints.ConnectorInstance.class, + methodType = io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + public static io.grpc.MethodDescriptor getQueryAllCapableConnectorInstancesMethod() { + io.grpc.MethodDescriptor getQueryAllCapableConnectorInstancesMethod; + if ((getQueryAllCapableConnectorInstancesMethod = EndpointsServiceGrpc.getQueryAllCapableConnectorInstancesMethod) == null) { + synchronized (EndpointsServiceGrpc.class) { + if ((getQueryAllCapableConnectorInstancesMethod = EndpointsServiceGrpc.getQueryAllCapableConnectorInstancesMethod) == null) { + EndpointsServiceGrpc.getQueryAllCapableConnectorInstancesMethod = getQueryAllCapableConnectorInstancesMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "QueryAllCapableConnectorInstances")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.ConnectorInstance.getDefaultInstance())) + .setSchemaDescriptor(new EndpointsServiceMethodDescriptorSupplier("QueryAllCapableConnectorInstances")) + .build(); + } + } + } + return getQueryAllCapableConnectorInstancesMethod; + } + + private static volatile io.grpc.MethodDescriptor getCreateConnectorInstanceMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "CreateConnectorInstance", + requestType = io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest.class, + responseType = io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails.class, + methodType = io.grpc.MethodDescriptor.MethodType.UNARY) + public static io.grpc.MethodDescriptor getCreateConnectorInstanceMethod() { + io.grpc.MethodDescriptor getCreateConnectorInstanceMethod; + if ((getCreateConnectorInstanceMethod = EndpointsServiceGrpc.getCreateConnectorInstanceMethod) == null) { + synchronized (EndpointsServiceGrpc.class) { + if ((getCreateConnectorInstanceMethod = EndpointsServiceGrpc.getCreateConnectorInstanceMethod) == null) { + EndpointsServiceGrpc.getCreateConnectorInstanceMethod = getCreateConnectorInstanceMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.UNARY) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "CreateConnectorInstance")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails.getDefaultInstance())) + .setSchemaDescriptor(new EndpointsServiceMethodDescriptorSupplier("CreateConnectorInstance")) + .build(); + } + } + } + return getCreateConnectorInstanceMethod; + } + + private static volatile io.grpc.MethodDescriptor getEditConnectorInstanceMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "EditConnectorInstance", + requestType = io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest.class, + responseType = io.trino.spi.grpc.Endpoints.ConnectorInstance.class, + methodType = io.grpc.MethodDescriptor.MethodType.UNARY) + public static io.grpc.MethodDescriptor getEditConnectorInstanceMethod() { + io.grpc.MethodDescriptor getEditConnectorInstanceMethod; + if ((getEditConnectorInstanceMethod = EndpointsServiceGrpc.getEditConnectorInstanceMethod) == null) { + synchronized (EndpointsServiceGrpc.class) { + if ((getEditConnectorInstanceMethod = EndpointsServiceGrpc.getEditConnectorInstanceMethod) == null) { + EndpointsServiceGrpc.getEditConnectorInstanceMethod = getEditConnectorInstanceMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.UNARY) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "EditConnectorInstance")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.ConnectorInstance.getDefaultInstance())) + .setSchemaDescriptor(new EndpointsServiceMethodDescriptorSupplier("EditConnectorInstance")) + .build(); + } + } + } + return getEditConnectorInstanceMethod; + } + + private static volatile io.grpc.MethodDescriptor getDeleteConnectorInstanceMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "DeleteConnectorInstance", + requestType = io.trino.spi.grpc.Endpoints.SingleIDRequest.class, + responseType = io.trino.spi.grpc.Endpoints.EmptyReply.class, + methodType = io.grpc.MethodDescriptor.MethodType.UNARY) + public static io.grpc.MethodDescriptor getDeleteConnectorInstanceMethod() { + io.grpc.MethodDescriptor getDeleteConnectorInstanceMethod; + if ((getDeleteConnectorInstanceMethod = EndpointsServiceGrpc.getDeleteConnectorInstanceMethod) == null) { + synchronized (EndpointsServiceGrpc.class) { + if ((getDeleteConnectorInstanceMethod = EndpointsServiceGrpc.getDeleteConnectorInstanceMethod) == null) { + EndpointsServiceGrpc.getDeleteConnectorInstanceMethod = getDeleteConnectorInstanceMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.UNARY) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "DeleteConnectorInstance")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.SingleIDRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.EmptyReply.getDefaultInstance())) + .setSchemaDescriptor(new EndpointsServiceMethodDescriptorSupplier("DeleteConnectorInstance")) + .build(); + } + } + } + return getDeleteConnectorInstanceMethod; + } + + private static volatile io.grpc.MethodDescriptor getQueryDataSourcesByConnectorInstanceIDsMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "QueryDataSourcesByConnectorInstanceIDs", + requestType = io.trino.spi.grpc.Endpoints.MultipleIDsRequest.class, + responseType = io.trino.spi.grpc.Endpoints.DataSourceInstance.class, + methodType = io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + public static io.grpc.MethodDescriptor getQueryDataSourcesByConnectorInstanceIDsMethod() { + io.grpc.MethodDescriptor getQueryDataSourcesByConnectorInstanceIDsMethod; + if ((getQueryDataSourcesByConnectorInstanceIDsMethod = EndpointsServiceGrpc.getQueryDataSourcesByConnectorInstanceIDsMethod) == null) { + synchronized (EndpointsServiceGrpc.class) { + if ((getQueryDataSourcesByConnectorInstanceIDsMethod = EndpointsServiceGrpc.getQueryDataSourcesByConnectorInstanceIDsMethod) == null) { + EndpointsServiceGrpc.getQueryDataSourcesByConnectorInstanceIDsMethod = getQueryDataSourcesByConnectorInstanceIDsMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "QueryDataSourcesByConnectorInstanceIDs")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.MultipleIDsRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.DataSourceInstance.getDefaultInstance())) + .setSchemaDescriptor(new EndpointsServiceMethodDescriptorSupplier("QueryDataSourcesByConnectorInstanceIDs")) + .build(); + } + } + } + return getQueryDataSourcesByConnectorInstanceIDsMethod; + } + + private static volatile io.grpc.MethodDescriptor getQueryEndpointsMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "QueryEndpoints", + requestType = io.trino.spi.grpc.Endpoints.QueryEndpointsRequest.class, + responseType = io.trino.spi.grpc.Endpoints.HttpEndpoint.class, + methodType = io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + public static io.grpc.MethodDescriptor getQueryEndpointsMethod() { + io.grpc.MethodDescriptor getQueryEndpointsMethod; + if ((getQueryEndpointsMethod = EndpointsServiceGrpc.getQueryEndpointsMethod) == null) { + synchronized (EndpointsServiceGrpc.class) { + if ((getQueryEndpointsMethod = EndpointsServiceGrpc.getQueryEndpointsMethod) == null) { + EndpointsServiceGrpc.getQueryEndpointsMethod = getQueryEndpointsMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "QueryEndpoints")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.QueryEndpointsRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.HttpEndpoint.getDefaultInstance())) + .setSchemaDescriptor(new EndpointsServiceMethodDescriptorSupplier("QueryEndpoints")) + .build(); + } + } + } + return getQueryEndpointsMethod; + } + + private static volatile io.grpc.MethodDescriptor getGetTrinoConnectorInstancesMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "GetTrinoConnectorInstances", + requestType = io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest.class, + responseType = io.trino.spi.grpc.Endpoints.TrinoConnectorInstance.class, + methodType = io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + public static io.grpc.MethodDescriptor getGetTrinoConnectorInstancesMethod() { + io.grpc.MethodDescriptor getGetTrinoConnectorInstancesMethod; + if ((getGetTrinoConnectorInstancesMethod = EndpointsServiceGrpc.getGetTrinoConnectorInstancesMethod) == null) { + synchronized (EndpointsServiceGrpc.class) { + if ((getGetTrinoConnectorInstancesMethod = EndpointsServiceGrpc.getGetTrinoConnectorInstancesMethod) == null) { + EndpointsServiceGrpc.getGetTrinoConnectorInstancesMethod = getGetTrinoConnectorInstancesMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "GetTrinoConnectorInstances")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.TrinoConnectorInstance.getDefaultInstance())) + .setSchemaDescriptor(new EndpointsServiceMethodDescriptorSupplier("GetTrinoConnectorInstances")) + .build(); + } + } + } + return getGetTrinoConnectorInstancesMethod; + } + + private static volatile io.grpc.MethodDescriptor getGetBrokerHostnamesMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "GetBrokerHostnames", + requestType = io.trino.spi.grpc.Endpoints.EmptyRequest.class, + responseType = io.trino.spi.grpc.Endpoints.BrokerHostnames.class, + methodType = io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + public static io.grpc.MethodDescriptor getGetBrokerHostnamesMethod() { + io.grpc.MethodDescriptor getGetBrokerHostnamesMethod; + if ((getGetBrokerHostnamesMethod = EndpointsServiceGrpc.getGetBrokerHostnamesMethod) == null) { + synchronized (EndpointsServiceGrpc.class) { + if ((getGetBrokerHostnamesMethod = EndpointsServiceGrpc.getGetBrokerHostnamesMethod) == null) { + EndpointsServiceGrpc.getGetBrokerHostnamesMethod = getGetBrokerHostnamesMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "GetBrokerHostnames")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.EmptyRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.BrokerHostnames.getDefaultInstance())) + .setSchemaDescriptor(new EndpointsServiceMethodDescriptorSupplier("GetBrokerHostnames")) + .build(); + } + } + } + return getGetBrokerHostnamesMethod; + } + + private static volatile io.grpc.MethodDescriptor getGetTrinoConnectorInstanceMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "GetTrinoConnectorInstance", + requestType = io.trino.spi.grpc.Endpoints.SingleIDRequest.class, + responseType = io.trino.spi.grpc.Endpoints.TrinoConnectorInstance.class, + methodType = io.grpc.MethodDescriptor.MethodType.UNARY) + public static io.grpc.MethodDescriptor getGetTrinoConnectorInstanceMethod() { + io.grpc.MethodDescriptor getGetTrinoConnectorInstanceMethod; + if ((getGetTrinoConnectorInstanceMethod = EndpointsServiceGrpc.getGetTrinoConnectorInstanceMethod) == null) { + synchronized (EndpointsServiceGrpc.class) { + if ((getGetTrinoConnectorInstanceMethod = EndpointsServiceGrpc.getGetTrinoConnectorInstanceMethod) == null) { + EndpointsServiceGrpc.getGetTrinoConnectorInstanceMethod = getGetTrinoConnectorInstanceMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.UNARY) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "GetTrinoConnectorInstance")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.SingleIDRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.TrinoConnectorInstance.getDefaultInstance())) + .setSchemaDescriptor(new EndpointsServiceMethodDescriptorSupplier("GetTrinoConnectorInstance")) + .build(); + } + } + } + return getGetTrinoConnectorInstanceMethod; + } + + private static volatile io.grpc.MethodDescriptor getInvokeEndpointMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "InvokeEndpoint", + requestType = io.trino.spi.grpc.Endpoints.InvokeEndpointRequest.class, + responseType = io.trino.spi.grpc.Endpoints.InvokeEndpointReply.class, + methodType = io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + public static io.grpc.MethodDescriptor getInvokeEndpointMethod() { + io.grpc.MethodDescriptor getInvokeEndpointMethod; + if ((getInvokeEndpointMethod = EndpointsServiceGrpc.getInvokeEndpointMethod) == null) { + synchronized (EndpointsServiceGrpc.class) { + if ((getInvokeEndpointMethod = EndpointsServiceGrpc.getInvokeEndpointMethod) == null) { + EndpointsServiceGrpc.getInvokeEndpointMethod = getInvokeEndpointMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "InvokeEndpoint")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.InvokeEndpointRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.InvokeEndpointReply.getDefaultInstance())) + .setSchemaDescriptor(new EndpointsServiceMethodDescriptorSupplier("InvokeEndpoint")) + .build(); + } + } + } + return getInvokeEndpointMethod; + } + + private static volatile io.grpc.MethodDescriptor getRegisterBrokerMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "RegisterBroker", + requestType = io.trino.spi.grpc.Endpoints.BrokerClientDetails.class, + responseType = io.trino.spi.grpc.Endpoints.BrokerProxyDetails.class, + methodType = io.grpc.MethodDescriptor.MethodType.UNARY) + public static io.grpc.MethodDescriptor getRegisterBrokerMethod() { + io.grpc.MethodDescriptor getRegisterBrokerMethod; + if ((getRegisterBrokerMethod = EndpointsServiceGrpc.getRegisterBrokerMethod) == null) { + synchronized (EndpointsServiceGrpc.class) { + if ((getRegisterBrokerMethod = EndpointsServiceGrpc.getRegisterBrokerMethod) == null) { + EndpointsServiceGrpc.getRegisterBrokerMethod = getRegisterBrokerMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.UNARY) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "RegisterBroker")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.BrokerClientDetails.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.BrokerProxyDetails.getDefaultInstance())) + .setSchemaDescriptor(new EndpointsServiceMethodDescriptorSupplier("RegisterBroker")) + .build(); + } + } + } + return getRegisterBrokerMethod; + } + + private static volatile io.grpc.MethodDescriptor getGetBrokersMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "GetBrokers", + requestType = io.trino.spi.grpc.Endpoints.EmptyRequest.class, + responseType = io.trino.spi.grpc.Endpoints.BrokerProxyDetails.class, + methodType = io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + public static io.grpc.MethodDescriptor getGetBrokersMethod() { + io.grpc.MethodDescriptor getGetBrokersMethod; + if ((getGetBrokersMethod = EndpointsServiceGrpc.getGetBrokersMethod) == null) { + synchronized (EndpointsServiceGrpc.class) { + if ((getGetBrokersMethod = EndpointsServiceGrpc.getGetBrokersMethod) == null) { + EndpointsServiceGrpc.getGetBrokersMethod = getGetBrokersMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "GetBrokers")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.EmptyRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.BrokerProxyDetails.getDefaultInstance())) + .setSchemaDescriptor(new EndpointsServiceMethodDescriptorSupplier("GetBrokers")) + .build(); + } + } + } + return getGetBrokersMethod; + } + + private static volatile io.grpc.MethodDescriptor getGetTenantBrokersMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "GetTenantBrokers", + requestType = io.trino.spi.grpc.Endpoints.TenantRequest.class, + responseType = io.trino.spi.grpc.Endpoints.BrokerProxyDetails.class, + methodType = io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + public static io.grpc.MethodDescriptor getGetTenantBrokersMethod() { + io.grpc.MethodDescriptor getGetTenantBrokersMethod; + if ((getGetTenantBrokersMethod = EndpointsServiceGrpc.getGetTenantBrokersMethod) == null) { + synchronized (EndpointsServiceGrpc.class) { + if ((getGetTenantBrokersMethod = EndpointsServiceGrpc.getGetTenantBrokersMethod) == null) { + EndpointsServiceGrpc.getGetTenantBrokersMethod = getGetTenantBrokersMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "GetTenantBrokers")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.TenantRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.BrokerProxyDetails.getDefaultInstance())) + .setSchemaDescriptor(new EndpointsServiceMethodDescriptorSupplier("GetTenantBrokers")) + .build(); + } + } + } + return getGetTenantBrokersMethod; + } + + private static volatile io.grpc.MethodDescriptor getGetAllBrokersPublicIPsMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "GetAllBrokersPublicIPs", + requestType = io.trino.spi.grpc.Endpoints.EmptyRequest.class, + responseType = io.trino.spi.grpc.Endpoints.BrokerPublicIP.class, + methodType = io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + public static io.grpc.MethodDescriptor getGetAllBrokersPublicIPsMethod() { + io.grpc.MethodDescriptor getGetAllBrokersPublicIPsMethod; + if ((getGetAllBrokersPublicIPsMethod = EndpointsServiceGrpc.getGetAllBrokersPublicIPsMethod) == null) { + synchronized (EndpointsServiceGrpc.class) { + if ((getGetAllBrokersPublicIPsMethod = EndpointsServiceGrpc.getGetAllBrokersPublicIPsMethod) == null) { + EndpointsServiceGrpc.getGetAllBrokersPublicIPsMethod = getGetAllBrokersPublicIPsMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "GetAllBrokersPublicIPs")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.EmptyRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.BrokerPublicIP.getDefaultInstance())) + .setSchemaDescriptor(new EndpointsServiceMethodDescriptorSupplier("GetAllBrokersPublicIPs")) + .build(); + } + } + } + return getGetAllBrokersPublicIPsMethod; + } + + private static volatile io.grpc.MethodDescriptor getQueryDataSourcesByIDsMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "QueryDataSourcesByIDs", + requestType = io.trino.spi.grpc.Endpoints.MultipleIDsRequest.class, + responseType = io.trino.spi.grpc.Endpoints.DataSource.class, + methodType = io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + public static io.grpc.MethodDescriptor getQueryDataSourcesByIDsMethod() { + io.grpc.MethodDescriptor getQueryDataSourcesByIDsMethod; + if ((getQueryDataSourcesByIDsMethod = EndpointsServiceGrpc.getQueryDataSourcesByIDsMethod) == null) { + synchronized (EndpointsServiceGrpc.class) { + if ((getQueryDataSourcesByIDsMethod = EndpointsServiceGrpc.getQueryDataSourcesByIDsMethod) == null) { + EndpointsServiceGrpc.getQueryDataSourcesByIDsMethod = getQueryDataSourcesByIDsMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "QueryDataSourcesByIDs")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.MultipleIDsRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.DataSource.getDefaultInstance())) + .setSchemaDescriptor(new EndpointsServiceMethodDescriptorSupplier("QueryDataSourcesByIDs")) + .build(); + } + } + } + return getQueryDataSourcesByIDsMethod; + } + + private static volatile io.grpc.MethodDescriptor getQueryDataSourceInstancesMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "QueryDataSourceInstances", + requestType = io.trino.spi.grpc.Endpoints.MultipleIDsRequest.class, + responseType = io.trino.spi.grpc.Endpoints.DataSourceInstance.class, + methodType = io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + public static io.grpc.MethodDescriptor getQueryDataSourceInstancesMethod() { + io.grpc.MethodDescriptor getQueryDataSourceInstancesMethod; + if ((getQueryDataSourceInstancesMethod = EndpointsServiceGrpc.getQueryDataSourceInstancesMethod) == null) { + synchronized (EndpointsServiceGrpc.class) { + if ((getQueryDataSourceInstancesMethod = EndpointsServiceGrpc.getQueryDataSourceInstancesMethod) == null) { + EndpointsServiceGrpc.getQueryDataSourceInstancesMethod = getQueryDataSourceInstancesMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "QueryDataSourceInstances")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.MultipleIDsRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.DataSourceInstance.getDefaultInstance())) + .setSchemaDescriptor(new EndpointsServiceMethodDescriptorSupplier("QueryDataSourceInstances")) + .build(); + } + } + } + return getQueryDataSourceInstancesMethod; + } + + private static volatile io.grpc.MethodDescriptor getQueryDataSourcesMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "QueryDataSources", + requestType = io.trino.spi.grpc.Endpoints.TenantRequest.class, + responseType = io.trino.spi.grpc.Endpoints.DataSource.class, + methodType = io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + public static io.grpc.MethodDescriptor getQueryDataSourcesMethod() { + io.grpc.MethodDescriptor getQueryDataSourcesMethod; + if ((getQueryDataSourcesMethod = EndpointsServiceGrpc.getQueryDataSourcesMethod) == null) { + synchronized (EndpointsServiceGrpc.class) { + if ((getQueryDataSourcesMethod = EndpointsServiceGrpc.getQueryDataSourcesMethod) == null) { + EndpointsServiceGrpc.getQueryDataSourcesMethod = getQueryDataSourcesMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "QueryDataSources")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.TenantRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.DataSource.getDefaultInstance())) + .setSchemaDescriptor(new EndpointsServiceMethodDescriptorSupplier("QueryDataSources")) + .build(); + } + } + } + return getQueryDataSourcesMethod; + } + + private static volatile io.grpc.MethodDescriptor getQueryDataSourceByNameMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "QueryDataSourceByName", + requestType = io.trino.spi.grpc.Endpoints.QueryDataSourceRequest.class, + responseType = io.trino.spi.grpc.Endpoints.DataSource.class, + methodType = io.grpc.MethodDescriptor.MethodType.UNARY) + public static io.grpc.MethodDescriptor getQueryDataSourceByNameMethod() { + io.grpc.MethodDescriptor getQueryDataSourceByNameMethod; + if ((getQueryDataSourceByNameMethod = EndpointsServiceGrpc.getQueryDataSourceByNameMethod) == null) { + synchronized (EndpointsServiceGrpc.class) { + if ((getQueryDataSourceByNameMethod = EndpointsServiceGrpc.getQueryDataSourceByNameMethod) == null) { + EndpointsServiceGrpc.getQueryDataSourceByNameMethod = getQueryDataSourceByNameMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.UNARY) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "QueryDataSourceByName")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.QueryDataSourceRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.DataSource.getDefaultInstance())) + .setSchemaDescriptor(new EndpointsServiceMethodDescriptorSupplier("QueryDataSourceByName")) + .build(); + } + } + } + return getQueryDataSourceByNameMethod; + } + + private static volatile io.grpc.MethodDescriptor getQueryDataSourceDiscoveryMappingForConnectorMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "QueryDataSourceDiscoveryMappingForConnector", + requestType = io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest.class, + responseType = io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping.class, + methodType = io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + public static io.grpc.MethodDescriptor getQueryDataSourceDiscoveryMappingForConnectorMethod() { + io.grpc.MethodDescriptor getQueryDataSourceDiscoveryMappingForConnectorMethod; + if ((getQueryDataSourceDiscoveryMappingForConnectorMethod = EndpointsServiceGrpc.getQueryDataSourceDiscoveryMappingForConnectorMethod) == null) { + synchronized (EndpointsServiceGrpc.class) { + if ((getQueryDataSourceDiscoveryMappingForConnectorMethod = EndpointsServiceGrpc.getQueryDataSourceDiscoveryMappingForConnectorMethod) == null) { + EndpointsServiceGrpc.getQueryDataSourceDiscoveryMappingForConnectorMethod = getQueryDataSourceDiscoveryMappingForConnectorMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "QueryDataSourceDiscoveryMappingForConnector")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping.getDefaultInstance())) + .setSchemaDescriptor(new EndpointsServiceMethodDescriptorSupplier("QueryDataSourceDiscoveryMappingForConnector")) + .build(); + } + } + } + return getQueryDataSourceDiscoveryMappingForConnectorMethod; + } + + private static volatile io.grpc.MethodDescriptor getQueryAllDataSourceDiscoveryMappingMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "QueryAllDataSourceDiscoveryMapping", + requestType = io.trino.spi.grpc.Endpoints.EmptyRequest.class, + responseType = io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping.class, + methodType = io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + public static io.grpc.MethodDescriptor getQueryAllDataSourceDiscoveryMappingMethod() { + io.grpc.MethodDescriptor getQueryAllDataSourceDiscoveryMappingMethod; + if ((getQueryAllDataSourceDiscoveryMappingMethod = EndpointsServiceGrpc.getQueryAllDataSourceDiscoveryMappingMethod) == null) { + synchronized (EndpointsServiceGrpc.class) { + if ((getQueryAllDataSourceDiscoveryMappingMethod = EndpointsServiceGrpc.getQueryAllDataSourceDiscoveryMappingMethod) == null) { + EndpointsServiceGrpc.getQueryAllDataSourceDiscoveryMappingMethod = getQueryAllDataSourceDiscoveryMappingMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "QueryAllDataSourceDiscoveryMapping")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.EmptyRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping.getDefaultInstance())) + .setSchemaDescriptor(new EndpointsServiceMethodDescriptorSupplier("QueryAllDataSourceDiscoveryMapping")) + .build(); + } + } + } + return getQueryAllDataSourceDiscoveryMappingMethod; + } + + private static volatile io.grpc.MethodDescriptor getGetConnectorInstancesChecksumMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "GetConnectorInstancesChecksum", + requestType = com.google.protobuf.Empty.class, + responseType = io.trino.spi.grpc.Endpoints.Checksum.class, + methodType = io.grpc.MethodDescriptor.MethodType.UNARY) + public static io.grpc.MethodDescriptor getGetConnectorInstancesChecksumMethod() { + io.grpc.MethodDescriptor getGetConnectorInstancesChecksumMethod; + if ((getGetConnectorInstancesChecksumMethod = EndpointsServiceGrpc.getGetConnectorInstancesChecksumMethod) == null) { + synchronized (EndpointsServiceGrpc.class) { + if ((getGetConnectorInstancesChecksumMethod = EndpointsServiceGrpc.getGetConnectorInstancesChecksumMethod) == null) { + EndpointsServiceGrpc.getGetConnectorInstancesChecksumMethod = getGetConnectorInstancesChecksumMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.UNARY) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "GetConnectorInstancesChecksum")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + com.google.protobuf.Empty.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.Checksum.getDefaultInstance())) + .setSchemaDescriptor(new EndpointsServiceMethodDescriptorSupplier("GetConnectorInstancesChecksum")) + .build(); + } + } + } + return getGetConnectorInstancesChecksumMethod; + } + + private static volatile io.grpc.MethodDescriptor getGetDataSourceInstanceConnectorDetailsByDataSourceIDsMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "GetDataSourceInstanceConnectorDetailsByDataSourceIDs", + requestType = io.trino.spi.grpc.Endpoints.MultipleIDsRequest.class, + responseType = io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails.class, + methodType = io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + public static io.grpc.MethodDescriptor getGetDataSourceInstanceConnectorDetailsByDataSourceIDsMethod() { + io.grpc.MethodDescriptor getGetDataSourceInstanceConnectorDetailsByDataSourceIDsMethod; + if ((getGetDataSourceInstanceConnectorDetailsByDataSourceIDsMethod = EndpointsServiceGrpc.getGetDataSourceInstanceConnectorDetailsByDataSourceIDsMethod) == null) { + synchronized (EndpointsServiceGrpc.class) { + if ((getGetDataSourceInstanceConnectorDetailsByDataSourceIDsMethod = EndpointsServiceGrpc.getGetDataSourceInstanceConnectorDetailsByDataSourceIDsMethod) == null) { + EndpointsServiceGrpc.getGetDataSourceInstanceConnectorDetailsByDataSourceIDsMethod = getGetDataSourceInstanceConnectorDetailsByDataSourceIDsMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "GetDataSourceInstanceConnectorDetailsByDataSourceIDs")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.MultipleIDsRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails.getDefaultInstance())) + .setSchemaDescriptor(new EndpointsServiceMethodDescriptorSupplier("GetDataSourceInstanceConnectorDetailsByDataSourceIDs")) + .build(); + } + } + } + return getGetDataSourceInstanceConnectorDetailsByDataSourceIDsMethod; + } + + private static volatile io.grpc.MethodDescriptor getGetDataSourceInstanceConnectorDetailsByDataSourceInstanceIDsMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "GetDataSourceInstanceConnectorDetailsByDataSourceInstanceIDs", + requestType = io.trino.spi.grpc.Endpoints.MultipleIDsRequest.class, + responseType = io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails.class, + methodType = io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + public static io.grpc.MethodDescriptor getGetDataSourceInstanceConnectorDetailsByDataSourceInstanceIDsMethod() { + io.grpc.MethodDescriptor getGetDataSourceInstanceConnectorDetailsByDataSourceInstanceIDsMethod; + if ((getGetDataSourceInstanceConnectorDetailsByDataSourceInstanceIDsMethod = EndpointsServiceGrpc.getGetDataSourceInstanceConnectorDetailsByDataSourceInstanceIDsMethod) == null) { + synchronized (EndpointsServiceGrpc.class) { + if ((getGetDataSourceInstanceConnectorDetailsByDataSourceInstanceIDsMethod = EndpointsServiceGrpc.getGetDataSourceInstanceConnectorDetailsByDataSourceInstanceIDsMethod) == null) { + EndpointsServiceGrpc.getGetDataSourceInstanceConnectorDetailsByDataSourceInstanceIDsMethod = getGetDataSourceInstanceConnectorDetailsByDataSourceInstanceIDsMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "GetDataSourceInstanceConnectorDetailsByDataSourceInstanceIDs")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.MultipleIDsRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails.getDefaultInstance())) + .setSchemaDescriptor(new EndpointsServiceMethodDescriptorSupplier("GetDataSourceInstanceConnectorDetailsByDataSourceInstanceIDs")) + .build(); + } + } + } + return getGetDataSourceInstanceConnectorDetailsByDataSourceInstanceIDsMethod; + } + + /** + * Creates a new async stub that supports all call types for the service + */ + public static EndpointsServiceStub newStub(io.grpc.Channel channel) { + io.grpc.stub.AbstractStub.StubFactory factory = + new io.grpc.stub.AbstractStub.StubFactory() { + @java.lang.Override + public EndpointsServiceStub newStub(io.grpc.Channel channel, io.grpc.CallOptions callOptions) { + return new EndpointsServiceStub(channel, callOptions); + } + }; + return EndpointsServiceStub.newStub(factory, channel); + } + + /** + * Creates a new blocking-style stub that supports unary and streaming output calls on the service + */ + public static EndpointsServiceBlockingStub newBlockingStub( + io.grpc.Channel channel) { + io.grpc.stub.AbstractStub.StubFactory factory = + new io.grpc.stub.AbstractStub.StubFactory() { + @java.lang.Override + public EndpointsServiceBlockingStub newStub(io.grpc.Channel channel, io.grpc.CallOptions callOptions) { + return new EndpointsServiceBlockingStub(channel, callOptions); + } + }; + return EndpointsServiceBlockingStub.newStub(factory, channel); + } + + /** + * Creates a new ListenableFuture-style stub that supports unary calls on the service + */ + public static EndpointsServiceFutureStub newFutureStub( + io.grpc.Channel channel) { + io.grpc.stub.AbstractStub.StubFactory factory = + new io.grpc.stub.AbstractStub.StubFactory() { + @java.lang.Override + public EndpointsServiceFutureStub newStub(io.grpc.Channel channel, io.grpc.CallOptions callOptions) { + return new EndpointsServiceFutureStub(channel, callOptions); + } + }; + return EndpointsServiceFutureStub.newStub(factory, channel); + } + + /** + */ + public interface AsyncService { + + /** + */ + default void queryConnectorTestConnectionEndpointID(io.trino.spi.grpc.Endpoints.SingleIDRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getQueryConnectorTestConnectionEndpointIDMethod(), responseObserver); + } + + /** + */ + default void queryConnectorParametersToPopulate(io.trino.spi.grpc.Endpoints.SingleIDRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getQueryConnectorParametersToPopulateMethod(), responseObserver); + } + + /** + */ + default void queryConnectorsByIDs(io.trino.spi.grpc.Endpoints.MultipleIDsRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getQueryConnectorsByIDsMethod(), responseObserver); + } + + /** + */ + default void queryConnectors(io.trino.spi.grpc.Endpoints.EmptyRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getQueryConnectorsMethod(), responseObserver); + } + + /** + */ + default void isTrinoConnector(io.trino.spi.grpc.Endpoints.SingleIDRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getIsTrinoConnectorMethod(), responseObserver); + } + + /** + */ + default void isTrinoConnectorInstance(io.trino.spi.grpc.Endpoints.SingleIDRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getIsTrinoConnectorInstanceMethod(), responseObserver); + } + + /** + */ + default void queryConnectorInstancesByIDs(io.trino.spi.grpc.Endpoints.MultipleIDsRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getQueryConnectorInstancesByIDsMethod(), responseObserver); + } + + /** + */ + default void queryConnectorInstancesByConnectorIDs(io.trino.spi.grpc.Endpoints.MultipleIDsRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getQueryConnectorInstancesByConnectorIDsMethod(), responseObserver); + } + + /** + */ + default void queryConnectorInstances(io.trino.spi.grpc.Endpoints.TenantRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getQueryConnectorInstancesMethod(), responseObserver); + } + + /** + */ + default void queryAllCapableConnectorInstances(io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getQueryAllCapableConnectorInstancesMethod(), responseObserver); + } + + /** + */ + default void createConnectorInstance(io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getCreateConnectorInstanceMethod(), responseObserver); + } + + /** + */ + default void editConnectorInstance(io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getEditConnectorInstanceMethod(), responseObserver); + } + + /** + */ + default void deleteConnectorInstance(io.trino.spi.grpc.Endpoints.SingleIDRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getDeleteConnectorInstanceMethod(), responseObserver); + } + + /** + */ + default void queryDataSourcesByConnectorInstanceIDs(io.trino.spi.grpc.Endpoints.MultipleIDsRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getQueryDataSourcesByConnectorInstanceIDsMethod(), responseObserver); + } + + /** + */ + default void queryEndpoints(io.trino.spi.grpc.Endpoints.QueryEndpointsRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getQueryEndpointsMethod(), responseObserver); + } + + /** + */ + default void getTrinoConnectorInstances(io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getGetTrinoConnectorInstancesMethod(), responseObserver); + } + + /** + */ + default void getBrokerHostnames(io.trino.spi.grpc.Endpoints.EmptyRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getGetBrokerHostnamesMethod(), responseObserver); + } + + /** + */ + default void getTrinoConnectorInstance(io.trino.spi.grpc.Endpoints.SingleIDRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getGetTrinoConnectorInstanceMethod(), responseObserver); + } + + /** + */ + default void invokeEndpoint(io.trino.spi.grpc.Endpoints.InvokeEndpointRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getInvokeEndpointMethod(), responseObserver); + } + + /** + */ + default void registerBroker(io.trino.spi.grpc.Endpoints.BrokerClientDetails request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getRegisterBrokerMethod(), responseObserver); + } + + /** + */ + default void getBrokers(io.trino.spi.grpc.Endpoints.EmptyRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getGetBrokersMethod(), responseObserver); + } + + /** + */ + default void getTenantBrokers(io.trino.spi.grpc.Endpoints.TenantRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getGetTenantBrokersMethod(), responseObserver); + } + + /** + */ + default void getAllBrokersPublicIPs(io.trino.spi.grpc.Endpoints.EmptyRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getGetAllBrokersPublicIPsMethod(), responseObserver); + } + + /** + */ + default void queryDataSourcesByIDs(io.trino.spi.grpc.Endpoints.MultipleIDsRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getQueryDataSourcesByIDsMethod(), responseObserver); + } + + /** + */ + default void queryDataSourceInstances(io.trino.spi.grpc.Endpoints.MultipleIDsRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getQueryDataSourceInstancesMethod(), responseObserver); + } + + /** + */ + default void queryDataSources(io.trino.spi.grpc.Endpoints.TenantRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getQueryDataSourcesMethod(), responseObserver); + } + + /** + */ + default void queryDataSourceByName(io.trino.spi.grpc.Endpoints.QueryDataSourceRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getQueryDataSourceByNameMethod(), responseObserver); + } + + /** + */ + default void queryDataSourceDiscoveryMappingForConnector(io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getQueryDataSourceDiscoveryMappingForConnectorMethod(), responseObserver); + } + + /** + */ + default void queryAllDataSourceDiscoveryMapping(io.trino.spi.grpc.Endpoints.EmptyRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getQueryAllDataSourceDiscoveryMappingMethod(), responseObserver); + } + + /** + */ + default void getConnectorInstancesChecksum(com.google.protobuf.Empty request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getGetConnectorInstancesChecksumMethod(), responseObserver); + } + + /** + */ + default void getDataSourceInstanceConnectorDetailsByDataSourceIDs(io.trino.spi.grpc.Endpoints.MultipleIDsRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getGetDataSourceInstanceConnectorDetailsByDataSourceIDsMethod(), responseObserver); + } + + /** + */ + default void getDataSourceInstanceConnectorDetailsByDataSourceInstanceIDs(io.trino.spi.grpc.Endpoints.MultipleIDsRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getGetDataSourceInstanceConnectorDetailsByDataSourceInstanceIDsMethod(), responseObserver); + } + } + + /** + * Base class for the server implementation of the service EndpointsService. + */ + public static abstract class EndpointsServiceImplBase + implements io.grpc.BindableService, AsyncService { + + @java.lang.Override public final io.grpc.ServerServiceDefinition bindService() { + return EndpointsServiceGrpc.bindService(this); + } + } + + /** + * A stub to allow clients to do asynchronous rpc calls to service EndpointsService. + */ + public static final class EndpointsServiceStub + extends io.grpc.stub.AbstractAsyncStub { + private EndpointsServiceStub( + io.grpc.Channel channel, io.grpc.CallOptions callOptions) { + super(channel, callOptions); + } + + @java.lang.Override + protected EndpointsServiceStub build( + io.grpc.Channel channel, io.grpc.CallOptions callOptions) { + return new EndpointsServiceStub(channel, callOptions); + } + + /** + */ + public void queryConnectorTestConnectionEndpointID(io.trino.spi.grpc.Endpoints.SingleIDRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncUnaryCall( + getChannel().newCall(getQueryConnectorTestConnectionEndpointIDMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void queryConnectorParametersToPopulate(io.trino.spi.grpc.Endpoints.SingleIDRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncServerStreamingCall( + getChannel().newCall(getQueryConnectorParametersToPopulateMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void queryConnectorsByIDs(io.trino.spi.grpc.Endpoints.MultipleIDsRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncServerStreamingCall( + getChannel().newCall(getQueryConnectorsByIDsMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void queryConnectors(io.trino.spi.grpc.Endpoints.EmptyRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncServerStreamingCall( + getChannel().newCall(getQueryConnectorsMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void isTrinoConnector(io.trino.spi.grpc.Endpoints.SingleIDRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncUnaryCall( + getChannel().newCall(getIsTrinoConnectorMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void isTrinoConnectorInstance(io.trino.spi.grpc.Endpoints.SingleIDRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncUnaryCall( + getChannel().newCall(getIsTrinoConnectorInstanceMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void queryConnectorInstancesByIDs(io.trino.spi.grpc.Endpoints.MultipleIDsRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncServerStreamingCall( + getChannel().newCall(getQueryConnectorInstancesByIDsMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void queryConnectorInstancesByConnectorIDs(io.trino.spi.grpc.Endpoints.MultipleIDsRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncServerStreamingCall( + getChannel().newCall(getQueryConnectorInstancesByConnectorIDsMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void queryConnectorInstances(io.trino.spi.grpc.Endpoints.TenantRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncServerStreamingCall( + getChannel().newCall(getQueryConnectorInstancesMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void queryAllCapableConnectorInstances(io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncServerStreamingCall( + getChannel().newCall(getQueryAllCapableConnectorInstancesMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void createConnectorInstance(io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncUnaryCall( + getChannel().newCall(getCreateConnectorInstanceMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void editConnectorInstance(io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncUnaryCall( + getChannel().newCall(getEditConnectorInstanceMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void deleteConnectorInstance(io.trino.spi.grpc.Endpoints.SingleIDRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncUnaryCall( + getChannel().newCall(getDeleteConnectorInstanceMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void queryDataSourcesByConnectorInstanceIDs(io.trino.spi.grpc.Endpoints.MultipleIDsRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncServerStreamingCall( + getChannel().newCall(getQueryDataSourcesByConnectorInstanceIDsMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void queryEndpoints(io.trino.spi.grpc.Endpoints.QueryEndpointsRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncServerStreamingCall( + getChannel().newCall(getQueryEndpointsMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void getTrinoConnectorInstances(io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncServerStreamingCall( + getChannel().newCall(getGetTrinoConnectorInstancesMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void getBrokerHostnames(io.trino.spi.grpc.Endpoints.EmptyRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncServerStreamingCall( + getChannel().newCall(getGetBrokerHostnamesMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void getTrinoConnectorInstance(io.trino.spi.grpc.Endpoints.SingleIDRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncUnaryCall( + getChannel().newCall(getGetTrinoConnectorInstanceMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void invokeEndpoint(io.trino.spi.grpc.Endpoints.InvokeEndpointRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncServerStreamingCall( + getChannel().newCall(getInvokeEndpointMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void registerBroker(io.trino.spi.grpc.Endpoints.BrokerClientDetails request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncUnaryCall( + getChannel().newCall(getRegisterBrokerMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void getBrokers(io.trino.spi.grpc.Endpoints.EmptyRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncServerStreamingCall( + getChannel().newCall(getGetBrokersMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void getTenantBrokers(io.trino.spi.grpc.Endpoints.TenantRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncServerStreamingCall( + getChannel().newCall(getGetTenantBrokersMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void getAllBrokersPublicIPs(io.trino.spi.grpc.Endpoints.EmptyRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncServerStreamingCall( + getChannel().newCall(getGetAllBrokersPublicIPsMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void queryDataSourcesByIDs(io.trino.spi.grpc.Endpoints.MultipleIDsRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncServerStreamingCall( + getChannel().newCall(getQueryDataSourcesByIDsMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void queryDataSourceInstances(io.trino.spi.grpc.Endpoints.MultipleIDsRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncServerStreamingCall( + getChannel().newCall(getQueryDataSourceInstancesMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void queryDataSources(io.trino.spi.grpc.Endpoints.TenantRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncServerStreamingCall( + getChannel().newCall(getQueryDataSourcesMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void queryDataSourceByName(io.trino.spi.grpc.Endpoints.QueryDataSourceRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncUnaryCall( + getChannel().newCall(getQueryDataSourceByNameMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void queryDataSourceDiscoveryMappingForConnector(io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncServerStreamingCall( + getChannel().newCall(getQueryDataSourceDiscoveryMappingForConnectorMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void queryAllDataSourceDiscoveryMapping(io.trino.spi.grpc.Endpoints.EmptyRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncServerStreamingCall( + getChannel().newCall(getQueryAllDataSourceDiscoveryMappingMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void getConnectorInstancesChecksum(com.google.protobuf.Empty request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncUnaryCall( + getChannel().newCall(getGetConnectorInstancesChecksumMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void getDataSourceInstanceConnectorDetailsByDataSourceIDs(io.trino.spi.grpc.Endpoints.MultipleIDsRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncServerStreamingCall( + getChannel().newCall(getGetDataSourceInstanceConnectorDetailsByDataSourceIDsMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void getDataSourceInstanceConnectorDetailsByDataSourceInstanceIDs(io.trino.spi.grpc.Endpoints.MultipleIDsRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncServerStreamingCall( + getChannel().newCall(getGetDataSourceInstanceConnectorDetailsByDataSourceInstanceIDsMethod(), getCallOptions()), request, responseObserver); + } + } + + /** + * A stub to allow clients to do synchronous rpc calls to service EndpointsService. + */ + public static final class EndpointsServiceBlockingStub + extends io.grpc.stub.AbstractBlockingStub { + private EndpointsServiceBlockingStub( + io.grpc.Channel channel, io.grpc.CallOptions callOptions) { + super(channel, callOptions); + } + + @java.lang.Override + protected EndpointsServiceBlockingStub build( + io.grpc.Channel channel, io.grpc.CallOptions callOptions) { + return new EndpointsServiceBlockingStub(channel, callOptions); + } + + /** + */ + public io.trino.spi.grpc.Endpoints.SingleIDReply queryConnectorTestConnectionEndpointID(io.trino.spi.grpc.Endpoints.SingleIDRequest request) { + return io.grpc.stub.ClientCalls.blockingUnaryCall( + getChannel(), getQueryConnectorTestConnectionEndpointIDMethod(), getCallOptions(), request); + } + + /** + */ + public java.util.Iterator queryConnectorParametersToPopulate( + io.trino.spi.grpc.Endpoints.SingleIDRequest request) { + return io.grpc.stub.ClientCalls.blockingServerStreamingCall( + getChannel(), getQueryConnectorParametersToPopulateMethod(), getCallOptions(), request); + } + + /** + */ + public java.util.Iterator queryConnectorsByIDs( + io.trino.spi.grpc.Endpoints.MultipleIDsRequest request) { + return io.grpc.stub.ClientCalls.blockingServerStreamingCall( + getChannel(), getQueryConnectorsByIDsMethod(), getCallOptions(), request); + } + + /** + */ + public java.util.Iterator queryConnectors( + io.trino.spi.grpc.Endpoints.EmptyRequest request) { + return io.grpc.stub.ClientCalls.blockingServerStreamingCall( + getChannel(), getQueryConnectorsMethod(), getCallOptions(), request); + } + + /** + */ + public io.trino.spi.grpc.Endpoints.BoolResponse isTrinoConnector(io.trino.spi.grpc.Endpoints.SingleIDRequest request) { + return io.grpc.stub.ClientCalls.blockingUnaryCall( + getChannel(), getIsTrinoConnectorMethod(), getCallOptions(), request); + } + + /** + */ + public io.trino.spi.grpc.Endpoints.BoolResponse isTrinoConnectorInstance(io.trino.spi.grpc.Endpoints.SingleIDRequest request) { + return io.grpc.stub.ClientCalls.blockingUnaryCall( + getChannel(), getIsTrinoConnectorInstanceMethod(), getCallOptions(), request); + } + + /** + */ + public java.util.Iterator queryConnectorInstancesByIDs( + io.trino.spi.grpc.Endpoints.MultipleIDsRequest request) { + return io.grpc.stub.ClientCalls.blockingServerStreamingCall( + getChannel(), getQueryConnectorInstancesByIDsMethod(), getCallOptions(), request); + } + + /** + */ + public java.util.Iterator queryConnectorInstancesByConnectorIDs( + io.trino.spi.grpc.Endpoints.MultipleIDsRequest request) { + return io.grpc.stub.ClientCalls.blockingServerStreamingCall( + getChannel(), getQueryConnectorInstancesByConnectorIDsMethod(), getCallOptions(), request); + } + + /** + */ + public java.util.Iterator queryConnectorInstances( + io.trino.spi.grpc.Endpoints.TenantRequest request) { + return io.grpc.stub.ClientCalls.blockingServerStreamingCall( + getChannel(), getQueryConnectorInstancesMethod(), getCallOptions(), request); + } + + /** + */ + public java.util.Iterator queryAllCapableConnectorInstances( + io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest request) { + return io.grpc.stub.ClientCalls.blockingServerStreamingCall( + getChannel(), getQueryAllCapableConnectorInstancesMethod(), getCallOptions(), request); + } + + /** + */ + public io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails createConnectorInstance(io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest request) { + return io.grpc.stub.ClientCalls.blockingUnaryCall( + getChannel(), getCreateConnectorInstanceMethod(), getCallOptions(), request); + } + + /** + */ + public io.trino.spi.grpc.Endpoints.ConnectorInstance editConnectorInstance(io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest request) { + return io.grpc.stub.ClientCalls.blockingUnaryCall( + getChannel(), getEditConnectorInstanceMethod(), getCallOptions(), request); + } + + /** + */ + public io.trino.spi.grpc.Endpoints.EmptyReply deleteConnectorInstance(io.trino.spi.grpc.Endpoints.SingleIDRequest request) { + return io.grpc.stub.ClientCalls.blockingUnaryCall( + getChannel(), getDeleteConnectorInstanceMethod(), getCallOptions(), request); + } + + /** + */ + public java.util.Iterator queryDataSourcesByConnectorInstanceIDs( + io.trino.spi.grpc.Endpoints.MultipleIDsRequest request) { + return io.grpc.stub.ClientCalls.blockingServerStreamingCall( + getChannel(), getQueryDataSourcesByConnectorInstanceIDsMethod(), getCallOptions(), request); + } + + /** + */ + public java.util.Iterator queryEndpoints( + io.trino.spi.grpc.Endpoints.QueryEndpointsRequest request) { + return io.grpc.stub.ClientCalls.blockingServerStreamingCall( + getChannel(), getQueryEndpointsMethod(), getCallOptions(), request); + } + + /** + */ + public java.util.Iterator getTrinoConnectorInstances( + io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest request) { + return io.grpc.stub.ClientCalls.blockingServerStreamingCall( + getChannel(), getGetTrinoConnectorInstancesMethod(), getCallOptions(), request); + } + + /** + */ + public java.util.Iterator getBrokerHostnames( + io.trino.spi.grpc.Endpoints.EmptyRequest request) { + return io.grpc.stub.ClientCalls.blockingServerStreamingCall( + getChannel(), getGetBrokerHostnamesMethod(), getCallOptions(), request); + } + + /** + */ + public io.trino.spi.grpc.Endpoints.TrinoConnectorInstance getTrinoConnectorInstance(io.trino.spi.grpc.Endpoints.SingleIDRequest request) { + return io.grpc.stub.ClientCalls.blockingUnaryCall( + getChannel(), getGetTrinoConnectorInstanceMethod(), getCallOptions(), request); + } + + /** + */ + public java.util.Iterator invokeEndpoint( + io.trino.spi.grpc.Endpoints.InvokeEndpointRequest request) { + return io.grpc.stub.ClientCalls.blockingServerStreamingCall( + getChannel(), getInvokeEndpointMethod(), getCallOptions(), request); + } + + /** + */ + public io.trino.spi.grpc.Endpoints.BrokerProxyDetails registerBroker(io.trino.spi.grpc.Endpoints.BrokerClientDetails request) { + return io.grpc.stub.ClientCalls.blockingUnaryCall( + getChannel(), getRegisterBrokerMethod(), getCallOptions(), request); + } + + /** + */ + public java.util.Iterator getBrokers( + io.trino.spi.grpc.Endpoints.EmptyRequest request) { + return io.grpc.stub.ClientCalls.blockingServerStreamingCall( + getChannel(), getGetBrokersMethod(), getCallOptions(), request); + } + + /** + */ + public java.util.Iterator getTenantBrokers( + io.trino.spi.grpc.Endpoints.TenantRequest request) { + return io.grpc.stub.ClientCalls.blockingServerStreamingCall( + getChannel(), getGetTenantBrokersMethod(), getCallOptions(), request); + } + + /** + */ + public java.util.Iterator getAllBrokersPublicIPs( + io.trino.spi.grpc.Endpoints.EmptyRequest request) { + return io.grpc.stub.ClientCalls.blockingServerStreamingCall( + getChannel(), getGetAllBrokersPublicIPsMethod(), getCallOptions(), request); + } + + /** + */ + public java.util.Iterator queryDataSourcesByIDs( + io.trino.spi.grpc.Endpoints.MultipleIDsRequest request) { + return io.grpc.stub.ClientCalls.blockingServerStreamingCall( + getChannel(), getQueryDataSourcesByIDsMethod(), getCallOptions(), request); + } + + /** + */ + public java.util.Iterator queryDataSourceInstances( + io.trino.spi.grpc.Endpoints.MultipleIDsRequest request) { + return io.grpc.stub.ClientCalls.blockingServerStreamingCall( + getChannel(), getQueryDataSourceInstancesMethod(), getCallOptions(), request); + } + + /** + */ + public java.util.Iterator queryDataSources( + io.trino.spi.grpc.Endpoints.TenantRequest request) { + return io.grpc.stub.ClientCalls.blockingServerStreamingCall( + getChannel(), getQueryDataSourcesMethod(), getCallOptions(), request); + } + + /** + */ + public io.trino.spi.grpc.Endpoints.DataSource queryDataSourceByName(io.trino.spi.grpc.Endpoints.QueryDataSourceRequest request) { + return io.grpc.stub.ClientCalls.blockingUnaryCall( + getChannel(), getQueryDataSourceByNameMethod(), getCallOptions(), request); + } + + /** + */ + public java.util.Iterator queryDataSourceDiscoveryMappingForConnector( + io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest request) { + return io.grpc.stub.ClientCalls.blockingServerStreamingCall( + getChannel(), getQueryDataSourceDiscoveryMappingForConnectorMethod(), getCallOptions(), request); + } + + /** + */ + public java.util.Iterator queryAllDataSourceDiscoveryMapping( + io.trino.spi.grpc.Endpoints.EmptyRequest request) { + return io.grpc.stub.ClientCalls.blockingServerStreamingCall( + getChannel(), getQueryAllDataSourceDiscoveryMappingMethod(), getCallOptions(), request); + } + + /** + */ + public io.trino.spi.grpc.Endpoints.Checksum getConnectorInstancesChecksum(com.google.protobuf.Empty request) { + return io.grpc.stub.ClientCalls.blockingUnaryCall( + getChannel(), getGetConnectorInstancesChecksumMethod(), getCallOptions(), request); + } + + /** + */ + public java.util.Iterator getDataSourceInstanceConnectorDetailsByDataSourceIDs( + io.trino.spi.grpc.Endpoints.MultipleIDsRequest request) { + return io.grpc.stub.ClientCalls.blockingServerStreamingCall( + getChannel(), getGetDataSourceInstanceConnectorDetailsByDataSourceIDsMethod(), getCallOptions(), request); + } + + /** + */ + public java.util.Iterator getDataSourceInstanceConnectorDetailsByDataSourceInstanceIDs( + io.trino.spi.grpc.Endpoints.MultipleIDsRequest request) { + return io.grpc.stub.ClientCalls.blockingServerStreamingCall( + getChannel(), getGetDataSourceInstanceConnectorDetailsByDataSourceInstanceIDsMethod(), getCallOptions(), request); + } + } + + /** + * A stub to allow clients to do ListenableFuture-style rpc calls to service EndpointsService. + */ + public static final class EndpointsServiceFutureStub + extends io.grpc.stub.AbstractFutureStub { + private EndpointsServiceFutureStub( + io.grpc.Channel channel, io.grpc.CallOptions callOptions) { + super(channel, callOptions); + } + + @java.lang.Override + protected EndpointsServiceFutureStub build( + io.grpc.Channel channel, io.grpc.CallOptions callOptions) { + return new EndpointsServiceFutureStub(channel, callOptions); + } + + /** + */ + public com.google.common.util.concurrent.ListenableFuture queryConnectorTestConnectionEndpointID( + io.trino.spi.grpc.Endpoints.SingleIDRequest request) { + return io.grpc.stub.ClientCalls.futureUnaryCall( + getChannel().newCall(getQueryConnectorTestConnectionEndpointIDMethod(), getCallOptions()), request); + } + + /** + */ + public com.google.common.util.concurrent.ListenableFuture isTrinoConnector( + io.trino.spi.grpc.Endpoints.SingleIDRequest request) { + return io.grpc.stub.ClientCalls.futureUnaryCall( + getChannel().newCall(getIsTrinoConnectorMethod(), getCallOptions()), request); + } + + /** + */ + public com.google.common.util.concurrent.ListenableFuture isTrinoConnectorInstance( + io.trino.spi.grpc.Endpoints.SingleIDRequest request) { + return io.grpc.stub.ClientCalls.futureUnaryCall( + getChannel().newCall(getIsTrinoConnectorInstanceMethod(), getCallOptions()), request); + } + + /** + */ + public com.google.common.util.concurrent.ListenableFuture createConnectorInstance( + io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest request) { + return io.grpc.stub.ClientCalls.futureUnaryCall( + getChannel().newCall(getCreateConnectorInstanceMethod(), getCallOptions()), request); + } + + /** + */ + public com.google.common.util.concurrent.ListenableFuture editConnectorInstance( + io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest request) { + return io.grpc.stub.ClientCalls.futureUnaryCall( + getChannel().newCall(getEditConnectorInstanceMethod(), getCallOptions()), request); + } + + /** + */ + public com.google.common.util.concurrent.ListenableFuture deleteConnectorInstance( + io.trino.spi.grpc.Endpoints.SingleIDRequest request) { + return io.grpc.stub.ClientCalls.futureUnaryCall( + getChannel().newCall(getDeleteConnectorInstanceMethod(), getCallOptions()), request); + } + + /** + */ + public com.google.common.util.concurrent.ListenableFuture getTrinoConnectorInstance( + io.trino.spi.grpc.Endpoints.SingleIDRequest request) { + return io.grpc.stub.ClientCalls.futureUnaryCall( + getChannel().newCall(getGetTrinoConnectorInstanceMethod(), getCallOptions()), request); + } + + /** + */ + public com.google.common.util.concurrent.ListenableFuture registerBroker( + io.trino.spi.grpc.Endpoints.BrokerClientDetails request) { + return io.grpc.stub.ClientCalls.futureUnaryCall( + getChannel().newCall(getRegisterBrokerMethod(), getCallOptions()), request); + } + + /** + */ + public com.google.common.util.concurrent.ListenableFuture queryDataSourceByName( + io.trino.spi.grpc.Endpoints.QueryDataSourceRequest request) { + return io.grpc.stub.ClientCalls.futureUnaryCall( + getChannel().newCall(getQueryDataSourceByNameMethod(), getCallOptions()), request); + } + + /** + */ + public com.google.common.util.concurrent.ListenableFuture getConnectorInstancesChecksum( + com.google.protobuf.Empty request) { + return io.grpc.stub.ClientCalls.futureUnaryCall( + getChannel().newCall(getGetConnectorInstancesChecksumMethod(), getCallOptions()), request); + } + } + + private static final int METHODID_QUERY_CONNECTOR_TEST_CONNECTION_ENDPOINT_ID = 0; + private static final int METHODID_QUERY_CONNECTOR_PARAMETERS_TO_POPULATE = 1; + private static final int METHODID_QUERY_CONNECTORS_BY_IDS = 2; + private static final int METHODID_QUERY_CONNECTORS = 3; + private static final int METHODID_IS_TRINO_CONNECTOR = 4; + private static final int METHODID_IS_TRINO_CONNECTOR_INSTANCE = 5; + private static final int METHODID_QUERY_CONNECTOR_INSTANCES_BY_IDS = 6; + private static final int METHODID_QUERY_CONNECTOR_INSTANCES_BY_CONNECTOR_IDS = 7; + private static final int METHODID_QUERY_CONNECTOR_INSTANCES = 8; + private static final int METHODID_QUERY_ALL_CAPABLE_CONNECTOR_INSTANCES = 9; + private static final int METHODID_CREATE_CONNECTOR_INSTANCE = 10; + private static final int METHODID_EDIT_CONNECTOR_INSTANCE = 11; + private static final int METHODID_DELETE_CONNECTOR_INSTANCE = 12; + private static final int METHODID_QUERY_DATA_SOURCES_BY_CONNECTOR_INSTANCE_IDS = 13; + private static final int METHODID_QUERY_ENDPOINTS = 14; + private static final int METHODID_GET_TRINO_CONNECTOR_INSTANCES = 15; + private static final int METHODID_GET_BROKER_HOSTNAMES = 16; + private static final int METHODID_GET_TRINO_CONNECTOR_INSTANCE = 17; + private static final int METHODID_INVOKE_ENDPOINT = 18; + private static final int METHODID_REGISTER_BROKER = 19; + private static final int METHODID_GET_BROKERS = 20; + private static final int METHODID_GET_TENANT_BROKERS = 21; + private static final int METHODID_GET_ALL_BROKERS_PUBLIC_IPS = 22; + private static final int METHODID_QUERY_DATA_SOURCES_BY_IDS = 23; + private static final int METHODID_QUERY_DATA_SOURCE_INSTANCES = 24; + private static final int METHODID_QUERY_DATA_SOURCES = 25; + private static final int METHODID_QUERY_DATA_SOURCE_BY_NAME = 26; + private static final int METHODID_QUERY_DATA_SOURCE_DISCOVERY_MAPPING_FOR_CONNECTOR = 27; + private static final int METHODID_QUERY_ALL_DATA_SOURCE_DISCOVERY_MAPPING = 28; + private static final int METHODID_GET_CONNECTOR_INSTANCES_CHECKSUM = 29; + private static final int METHODID_GET_DATA_SOURCE_INSTANCE_CONNECTOR_DETAILS_BY_DATA_SOURCE_IDS = 30; + private static final int METHODID_GET_DATA_SOURCE_INSTANCE_CONNECTOR_DETAILS_BY_DATA_SOURCE_INSTANCE_IDS = 31; + + private static final class MethodHandlers implements + io.grpc.stub.ServerCalls.UnaryMethod, + io.grpc.stub.ServerCalls.ServerStreamingMethod, + io.grpc.stub.ServerCalls.ClientStreamingMethod, + io.grpc.stub.ServerCalls.BidiStreamingMethod { + private final AsyncService serviceImpl; + private final int methodId; + + MethodHandlers(AsyncService serviceImpl, int methodId) { + this.serviceImpl = serviceImpl; + this.methodId = methodId; + } + + @java.lang.Override + @java.lang.SuppressWarnings("unchecked") + public void invoke(Req request, io.grpc.stub.StreamObserver responseObserver) { + switch (methodId) { + case METHODID_QUERY_CONNECTOR_TEST_CONNECTION_ENDPOINT_ID: + serviceImpl.queryConnectorTestConnectionEndpointID((io.trino.spi.grpc.Endpoints.SingleIDRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_QUERY_CONNECTOR_PARAMETERS_TO_POPULATE: + serviceImpl.queryConnectorParametersToPopulate((io.trino.spi.grpc.Endpoints.SingleIDRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_QUERY_CONNECTORS_BY_IDS: + serviceImpl.queryConnectorsByIDs((io.trino.spi.grpc.Endpoints.MultipleIDsRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_QUERY_CONNECTORS: + serviceImpl.queryConnectors((io.trino.spi.grpc.Endpoints.EmptyRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_IS_TRINO_CONNECTOR: + serviceImpl.isTrinoConnector((io.trino.spi.grpc.Endpoints.SingleIDRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_IS_TRINO_CONNECTOR_INSTANCE: + serviceImpl.isTrinoConnectorInstance((io.trino.spi.grpc.Endpoints.SingleIDRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_QUERY_CONNECTOR_INSTANCES_BY_IDS: + serviceImpl.queryConnectorInstancesByIDs((io.trino.spi.grpc.Endpoints.MultipleIDsRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_QUERY_CONNECTOR_INSTANCES_BY_CONNECTOR_IDS: + serviceImpl.queryConnectorInstancesByConnectorIDs((io.trino.spi.grpc.Endpoints.MultipleIDsRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_QUERY_CONNECTOR_INSTANCES: + serviceImpl.queryConnectorInstances((io.trino.spi.grpc.Endpoints.TenantRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_QUERY_ALL_CAPABLE_CONNECTOR_INSTANCES: + serviceImpl.queryAllCapableConnectorInstances((io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_CREATE_CONNECTOR_INSTANCE: + serviceImpl.createConnectorInstance((io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_EDIT_CONNECTOR_INSTANCE: + serviceImpl.editConnectorInstance((io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_DELETE_CONNECTOR_INSTANCE: + serviceImpl.deleteConnectorInstance((io.trino.spi.grpc.Endpoints.SingleIDRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_QUERY_DATA_SOURCES_BY_CONNECTOR_INSTANCE_IDS: + serviceImpl.queryDataSourcesByConnectorInstanceIDs((io.trino.spi.grpc.Endpoints.MultipleIDsRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_QUERY_ENDPOINTS: + serviceImpl.queryEndpoints((io.trino.spi.grpc.Endpoints.QueryEndpointsRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_GET_TRINO_CONNECTOR_INSTANCES: + serviceImpl.getTrinoConnectorInstances((io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_GET_BROKER_HOSTNAMES: + serviceImpl.getBrokerHostnames((io.trino.spi.grpc.Endpoints.EmptyRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_GET_TRINO_CONNECTOR_INSTANCE: + serviceImpl.getTrinoConnectorInstance((io.trino.spi.grpc.Endpoints.SingleIDRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_INVOKE_ENDPOINT: + serviceImpl.invokeEndpoint((io.trino.spi.grpc.Endpoints.InvokeEndpointRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_REGISTER_BROKER: + serviceImpl.registerBroker((io.trino.spi.grpc.Endpoints.BrokerClientDetails) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_GET_BROKERS: + serviceImpl.getBrokers((io.trino.spi.grpc.Endpoints.EmptyRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_GET_TENANT_BROKERS: + serviceImpl.getTenantBrokers((io.trino.spi.grpc.Endpoints.TenantRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_GET_ALL_BROKERS_PUBLIC_IPS: + serviceImpl.getAllBrokersPublicIPs((io.trino.spi.grpc.Endpoints.EmptyRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_QUERY_DATA_SOURCES_BY_IDS: + serviceImpl.queryDataSourcesByIDs((io.trino.spi.grpc.Endpoints.MultipleIDsRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_QUERY_DATA_SOURCE_INSTANCES: + serviceImpl.queryDataSourceInstances((io.trino.spi.grpc.Endpoints.MultipleIDsRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_QUERY_DATA_SOURCES: + serviceImpl.queryDataSources((io.trino.spi.grpc.Endpoints.TenantRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_QUERY_DATA_SOURCE_BY_NAME: + serviceImpl.queryDataSourceByName((io.trino.spi.grpc.Endpoints.QueryDataSourceRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_QUERY_DATA_SOURCE_DISCOVERY_MAPPING_FOR_CONNECTOR: + serviceImpl.queryDataSourceDiscoveryMappingForConnector((io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_QUERY_ALL_DATA_SOURCE_DISCOVERY_MAPPING: + serviceImpl.queryAllDataSourceDiscoveryMapping((io.trino.spi.grpc.Endpoints.EmptyRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_GET_CONNECTOR_INSTANCES_CHECKSUM: + serviceImpl.getConnectorInstancesChecksum((com.google.protobuf.Empty) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_GET_DATA_SOURCE_INSTANCE_CONNECTOR_DETAILS_BY_DATA_SOURCE_IDS: + serviceImpl.getDataSourceInstanceConnectorDetailsByDataSourceIDs((io.trino.spi.grpc.Endpoints.MultipleIDsRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_GET_DATA_SOURCE_INSTANCE_CONNECTOR_DETAILS_BY_DATA_SOURCE_INSTANCE_IDS: + serviceImpl.getDataSourceInstanceConnectorDetailsByDataSourceInstanceIDs((io.trino.spi.grpc.Endpoints.MultipleIDsRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + default: + throw new AssertionError(); + } + } + + @java.lang.Override + @java.lang.SuppressWarnings("unchecked") + public io.grpc.stub.StreamObserver invoke( + io.grpc.stub.StreamObserver responseObserver) { + switch (methodId) { + default: + throw new AssertionError(); + } + } + } + + public static final io.grpc.ServerServiceDefinition bindService(AsyncService service) { + return io.grpc.ServerServiceDefinition.builder(getServiceDescriptor()) + .addMethod( + getQueryConnectorTestConnectionEndpointIDMethod(), + io.grpc.stub.ServerCalls.asyncUnaryCall( + new MethodHandlers< + io.trino.spi.grpc.Endpoints.SingleIDRequest, + io.trino.spi.grpc.Endpoints.SingleIDReply>( + service, METHODID_QUERY_CONNECTOR_TEST_CONNECTION_ENDPOINT_ID))) + .addMethod( + getQueryConnectorParametersToPopulateMethod(), + io.grpc.stub.ServerCalls.asyncServerStreamingCall( + new MethodHandlers< + io.trino.spi.grpc.Endpoints.SingleIDRequest, + io.trino.spi.grpc.Endpoints.Parameter>( + service, METHODID_QUERY_CONNECTOR_PARAMETERS_TO_POPULATE))) + .addMethod( + getQueryConnectorsByIDsMethod(), + io.grpc.stub.ServerCalls.asyncServerStreamingCall( + new MethodHandlers< + io.trino.spi.grpc.Endpoints.MultipleIDsRequest, + io.trino.spi.grpc.Endpoints.Connector>( + service, METHODID_QUERY_CONNECTORS_BY_IDS))) + .addMethod( + getQueryConnectorsMethod(), + io.grpc.stub.ServerCalls.asyncServerStreamingCall( + new MethodHandlers< + io.trino.spi.grpc.Endpoints.EmptyRequest, + io.trino.spi.grpc.Endpoints.Connector>( + service, METHODID_QUERY_CONNECTORS))) + .addMethod( + getIsTrinoConnectorMethod(), + io.grpc.stub.ServerCalls.asyncUnaryCall( + new MethodHandlers< + io.trino.spi.grpc.Endpoints.SingleIDRequest, + io.trino.spi.grpc.Endpoints.BoolResponse>( + service, METHODID_IS_TRINO_CONNECTOR))) + .addMethod( + getIsTrinoConnectorInstanceMethod(), + io.grpc.stub.ServerCalls.asyncUnaryCall( + new MethodHandlers< + io.trino.spi.grpc.Endpoints.SingleIDRequest, + io.trino.spi.grpc.Endpoints.BoolResponse>( + service, METHODID_IS_TRINO_CONNECTOR_INSTANCE))) + .addMethod( + getQueryConnectorInstancesByIDsMethod(), + io.grpc.stub.ServerCalls.asyncServerStreamingCall( + new MethodHandlers< + io.trino.spi.grpc.Endpoints.MultipleIDsRequest, + io.trino.spi.grpc.Endpoints.ConnectorInstance>( + service, METHODID_QUERY_CONNECTOR_INSTANCES_BY_IDS))) + .addMethod( + getQueryConnectorInstancesByConnectorIDsMethod(), + io.grpc.stub.ServerCalls.asyncServerStreamingCall( + new MethodHandlers< + io.trino.spi.grpc.Endpoints.MultipleIDsRequest, + io.trino.spi.grpc.Endpoints.ConnectorInstance>( + service, METHODID_QUERY_CONNECTOR_INSTANCES_BY_CONNECTOR_IDS))) + .addMethod( + getQueryConnectorInstancesMethod(), + io.grpc.stub.ServerCalls.asyncServerStreamingCall( + new MethodHandlers< + io.trino.spi.grpc.Endpoints.TenantRequest, + io.trino.spi.grpc.Endpoints.ConnectorInstance>( + service, METHODID_QUERY_CONNECTOR_INSTANCES))) + .addMethod( + getQueryAllCapableConnectorInstancesMethod(), + io.grpc.stub.ServerCalls.asyncServerStreamingCall( + new MethodHandlers< + io.trino.spi.grpc.Endpoints.ConnectorCapabilitiesRequest, + io.trino.spi.grpc.Endpoints.ConnectorInstance>( + service, METHODID_QUERY_ALL_CAPABLE_CONNECTOR_INSTANCES))) + .addMethod( + getCreateConnectorInstanceMethod(), + io.grpc.stub.ServerCalls.asyncUnaryCall( + new MethodHandlers< + io.trino.spi.grpc.Endpoints.ConnectorInstanceCreateRequest, + io.trino.spi.grpc.Endpoints.ConnectorInstanceDetails>( + service, METHODID_CREATE_CONNECTOR_INSTANCE))) + .addMethod( + getEditConnectorInstanceMethod(), + io.grpc.stub.ServerCalls.asyncUnaryCall( + new MethodHandlers< + io.trino.spi.grpc.Endpoints.ConnectorInstanceEditRequest, + io.trino.spi.grpc.Endpoints.ConnectorInstance>( + service, METHODID_EDIT_CONNECTOR_INSTANCE))) + .addMethod( + getDeleteConnectorInstanceMethod(), + io.grpc.stub.ServerCalls.asyncUnaryCall( + new MethodHandlers< + io.trino.spi.grpc.Endpoints.SingleIDRequest, + io.trino.spi.grpc.Endpoints.EmptyReply>( + service, METHODID_DELETE_CONNECTOR_INSTANCE))) + .addMethod( + getQueryDataSourcesByConnectorInstanceIDsMethod(), + io.grpc.stub.ServerCalls.asyncServerStreamingCall( + new MethodHandlers< + io.trino.spi.grpc.Endpoints.MultipleIDsRequest, + io.trino.spi.grpc.Endpoints.DataSourceInstance>( + service, METHODID_QUERY_DATA_SOURCES_BY_CONNECTOR_INSTANCE_IDS))) + .addMethod( + getQueryEndpointsMethod(), + io.grpc.stub.ServerCalls.asyncServerStreamingCall( + new MethodHandlers< + io.trino.spi.grpc.Endpoints.QueryEndpointsRequest, + io.trino.spi.grpc.Endpoints.HttpEndpoint>( + service, METHODID_QUERY_ENDPOINTS))) + .addMethod( + getGetTrinoConnectorInstancesMethod(), + io.grpc.stub.ServerCalls.asyncServerStreamingCall( + new MethodHandlers< + io.trino.spi.grpc.Endpoints.GetTrinoConnectorInstancesRequest, + io.trino.spi.grpc.Endpoints.TrinoConnectorInstance>( + service, METHODID_GET_TRINO_CONNECTOR_INSTANCES))) + .addMethod( + getGetBrokerHostnamesMethod(), + io.grpc.stub.ServerCalls.asyncServerStreamingCall( + new MethodHandlers< + io.trino.spi.grpc.Endpoints.EmptyRequest, + io.trino.spi.grpc.Endpoints.BrokerHostnames>( + service, METHODID_GET_BROKER_HOSTNAMES))) + .addMethod( + getGetTrinoConnectorInstanceMethod(), + io.grpc.stub.ServerCalls.asyncUnaryCall( + new MethodHandlers< + io.trino.spi.grpc.Endpoints.SingleIDRequest, + io.trino.spi.grpc.Endpoints.TrinoConnectorInstance>( + service, METHODID_GET_TRINO_CONNECTOR_INSTANCE))) + .addMethod( + getInvokeEndpointMethod(), + io.grpc.stub.ServerCalls.asyncServerStreamingCall( + new MethodHandlers< + io.trino.spi.grpc.Endpoints.InvokeEndpointRequest, + io.trino.spi.grpc.Endpoints.InvokeEndpointReply>( + service, METHODID_INVOKE_ENDPOINT))) + .addMethod( + getRegisterBrokerMethod(), + io.grpc.stub.ServerCalls.asyncUnaryCall( + new MethodHandlers< + io.trino.spi.grpc.Endpoints.BrokerClientDetails, + io.trino.spi.grpc.Endpoints.BrokerProxyDetails>( + service, METHODID_REGISTER_BROKER))) + .addMethod( + getGetBrokersMethod(), + io.grpc.stub.ServerCalls.asyncServerStreamingCall( + new MethodHandlers< + io.trino.spi.grpc.Endpoints.EmptyRequest, + io.trino.spi.grpc.Endpoints.BrokerProxyDetails>( + service, METHODID_GET_BROKERS))) + .addMethod( + getGetTenantBrokersMethod(), + io.grpc.stub.ServerCalls.asyncServerStreamingCall( + new MethodHandlers< + io.trino.spi.grpc.Endpoints.TenantRequest, + io.trino.spi.grpc.Endpoints.BrokerProxyDetails>( + service, METHODID_GET_TENANT_BROKERS))) + .addMethod( + getGetAllBrokersPublicIPsMethod(), + io.grpc.stub.ServerCalls.asyncServerStreamingCall( + new MethodHandlers< + io.trino.spi.grpc.Endpoints.EmptyRequest, + io.trino.spi.grpc.Endpoints.BrokerPublicIP>( + service, METHODID_GET_ALL_BROKERS_PUBLIC_IPS))) + .addMethod( + getQueryDataSourcesByIDsMethod(), + io.grpc.stub.ServerCalls.asyncServerStreamingCall( + new MethodHandlers< + io.trino.spi.grpc.Endpoints.MultipleIDsRequest, + io.trino.spi.grpc.Endpoints.DataSource>( + service, METHODID_QUERY_DATA_SOURCES_BY_IDS))) + .addMethod( + getQueryDataSourceInstancesMethod(), + io.grpc.stub.ServerCalls.asyncServerStreamingCall( + new MethodHandlers< + io.trino.spi.grpc.Endpoints.MultipleIDsRequest, + io.trino.spi.grpc.Endpoints.DataSourceInstance>( + service, METHODID_QUERY_DATA_SOURCE_INSTANCES))) + .addMethod( + getQueryDataSourcesMethod(), + io.grpc.stub.ServerCalls.asyncServerStreamingCall( + new MethodHandlers< + io.trino.spi.grpc.Endpoints.TenantRequest, + io.trino.spi.grpc.Endpoints.DataSource>( + service, METHODID_QUERY_DATA_SOURCES))) + .addMethod( + getQueryDataSourceByNameMethod(), + io.grpc.stub.ServerCalls.asyncUnaryCall( + new MethodHandlers< + io.trino.spi.grpc.Endpoints.QueryDataSourceRequest, + io.trino.spi.grpc.Endpoints.DataSource>( + service, METHODID_QUERY_DATA_SOURCE_BY_NAME))) + .addMethod( + getQueryDataSourceDiscoveryMappingForConnectorMethod(), + io.grpc.stub.ServerCalls.asyncServerStreamingCall( + new MethodHandlers< + io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMappingRequest, + io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping>( + service, METHODID_QUERY_DATA_SOURCE_DISCOVERY_MAPPING_FOR_CONNECTOR))) + .addMethod( + getQueryAllDataSourceDiscoveryMappingMethod(), + io.grpc.stub.ServerCalls.asyncServerStreamingCall( + new MethodHandlers< + io.trino.spi.grpc.Endpoints.EmptyRequest, + io.trino.spi.grpc.Endpoints.DataSourceDiscoveryMapping>( + service, METHODID_QUERY_ALL_DATA_SOURCE_DISCOVERY_MAPPING))) + .addMethod( + getGetConnectorInstancesChecksumMethod(), + io.grpc.stub.ServerCalls.asyncUnaryCall( + new MethodHandlers< + com.google.protobuf.Empty, + io.trino.spi.grpc.Endpoints.Checksum>( + service, METHODID_GET_CONNECTOR_INSTANCES_CHECKSUM))) + .addMethod( + getGetDataSourceInstanceConnectorDetailsByDataSourceIDsMethod(), + io.grpc.stub.ServerCalls.asyncServerStreamingCall( + new MethodHandlers< + io.trino.spi.grpc.Endpoints.MultipleIDsRequest, + io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails>( + service, METHODID_GET_DATA_SOURCE_INSTANCE_CONNECTOR_DETAILS_BY_DATA_SOURCE_IDS))) + .addMethod( + getGetDataSourceInstanceConnectorDetailsByDataSourceInstanceIDsMethod(), + io.grpc.stub.ServerCalls.asyncServerStreamingCall( + new MethodHandlers< + io.trino.spi.grpc.Endpoints.MultipleIDsRequest, + io.trino.spi.grpc.Endpoints.DataSourceInstanceConnectorDetails>( + service, METHODID_GET_DATA_SOURCE_INSTANCE_CONNECTOR_DETAILS_BY_DATA_SOURCE_INSTANCE_IDS))) + .build(); + } + + private static abstract class EndpointsServiceBaseDescriptorSupplier + implements io.grpc.protobuf.ProtoFileDescriptorSupplier, io.grpc.protobuf.ProtoServiceDescriptorSupplier { + EndpointsServiceBaseDescriptorSupplier() {} + + @java.lang.Override + public com.google.protobuf.Descriptors.FileDescriptor getFileDescriptor() { + return io.trino.spi.grpc.Endpoints.getDescriptor(); + } + + @java.lang.Override + public com.google.protobuf.Descriptors.ServiceDescriptor getServiceDescriptor() { + return getFileDescriptor().findServiceByName("EndpointsService"); + } + } + + private static final class EndpointsServiceFileDescriptorSupplier + extends EndpointsServiceBaseDescriptorSupplier { + EndpointsServiceFileDescriptorSupplier() {} + } + + private static final class EndpointsServiceMethodDescriptorSupplier + extends EndpointsServiceBaseDescriptorSupplier + implements io.grpc.protobuf.ProtoMethodDescriptorSupplier { + private final java.lang.String methodName; + + EndpointsServiceMethodDescriptorSupplier(java.lang.String methodName) { + this.methodName = methodName; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.MethodDescriptor getMethodDescriptor() { + return getServiceDescriptor().findMethodByName(methodName); + } + } + + private static volatile io.grpc.ServiceDescriptor serviceDescriptor; + + public static io.grpc.ServiceDescriptor getServiceDescriptor() { + io.grpc.ServiceDescriptor result = serviceDescriptor; + if (result == null) { + synchronized (EndpointsServiceGrpc.class) { + result = serviceDescriptor; + if (result == null) { + serviceDescriptor = result = io.grpc.ServiceDescriptor.newBuilder(SERVICE_NAME) + .setSchemaDescriptor(new EndpointsServiceFileDescriptorSupplier()) + .addMethod(getQueryConnectorTestConnectionEndpointIDMethod()) + .addMethod(getQueryConnectorParametersToPopulateMethod()) + .addMethod(getQueryConnectorsByIDsMethod()) + .addMethod(getQueryConnectorsMethod()) + .addMethod(getIsTrinoConnectorMethod()) + .addMethod(getIsTrinoConnectorInstanceMethod()) + .addMethod(getQueryConnectorInstancesByIDsMethod()) + .addMethod(getQueryConnectorInstancesByConnectorIDsMethod()) + .addMethod(getQueryConnectorInstancesMethod()) + .addMethod(getQueryAllCapableConnectorInstancesMethod()) + .addMethod(getCreateConnectorInstanceMethod()) + .addMethod(getEditConnectorInstanceMethod()) + .addMethod(getDeleteConnectorInstanceMethod()) + .addMethod(getQueryDataSourcesByConnectorInstanceIDsMethod()) + .addMethod(getQueryEndpointsMethod()) + .addMethod(getGetTrinoConnectorInstancesMethod()) + .addMethod(getGetBrokerHostnamesMethod()) + .addMethod(getGetTrinoConnectorInstanceMethod()) + .addMethod(getInvokeEndpointMethod()) + .addMethod(getRegisterBrokerMethod()) + .addMethod(getGetBrokersMethod()) + .addMethod(getGetTenantBrokersMethod()) + .addMethod(getGetAllBrokersPublicIPsMethod()) + .addMethod(getQueryDataSourcesByIDsMethod()) + .addMethod(getQueryDataSourceInstancesMethod()) + .addMethod(getQueryDataSourcesMethod()) + .addMethod(getQueryDataSourceByNameMethod()) + .addMethod(getQueryDataSourceDiscoveryMappingForConnectorMethod()) + .addMethod(getQueryAllDataSourceDiscoveryMappingMethod()) + .addMethod(getGetConnectorInstancesChecksumMethod()) + .addMethod(getGetDataSourceInstanceConnectorDetailsByDataSourceIDsMethod()) + .addMethod(getGetDataSourceInstanceConnectorDetailsByDataSourceInstanceIDsMethod()) + .build(); + } + } + } + return result; + } +} diff --git a/core/trino-spi/src/main/java/io/trino/spi/grpc/TrinoManagerServiceGrpc.java b/core/trino-spi/src/main/java/io/trino/spi/grpc/TrinoManagerServiceGrpc.java new file mode 100644 index 000000000000..8ebad4248d65 --- /dev/null +++ b/core/trino-spi/src/main/java/io/trino/spi/grpc/TrinoManagerServiceGrpc.java @@ -0,0 +1,1442 @@ +package io.trino.spi.grpc; + +import static io.grpc.MethodDescriptor.generateFullMethodName; + +/** + */ +@javax.annotation.Generated( + value = "by gRPC proto compiler (version 1.62.2)", + comments = "Source: trinomanager.proto") +@io.grpc.stub.annotations.GrpcGenerated +public final class TrinoManagerServiceGrpc { + + private TrinoManagerServiceGrpc() {} + + public static final java.lang.String SERVICE_NAME = "grpc.TrinoManagerService"; + + // Static method descriptors that strictly reflect the proto. + private static volatile io.grpc.MethodDescriptor getQueryInfoMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "QueryInfo", + requestType = io.trino.spi.grpc.Trinomanager.QueryDetailsRequest.class, + responseType = io.trino.spi.grpc.Trinomanager.QueryDetailsReply.class, + methodType = io.grpc.MethodDescriptor.MethodType.UNARY) + public static io.grpc.MethodDescriptor getQueryInfoMethod() { + io.grpc.MethodDescriptor getQueryInfoMethod; + if ((getQueryInfoMethod = TrinoManagerServiceGrpc.getQueryInfoMethod) == null) { + synchronized (TrinoManagerServiceGrpc.class) { + if ((getQueryInfoMethod = TrinoManagerServiceGrpc.getQueryInfoMethod) == null) { + TrinoManagerServiceGrpc.getQueryInfoMethod = getQueryInfoMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.UNARY) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "QueryInfo")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Trinomanager.QueryDetailsRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Trinomanager.QueryDetailsReply.getDefaultInstance())) + .setSchemaDescriptor(new TrinoManagerServiceMethodDescriptorSupplier("QueryInfo")) + .build(); + } + } + } + return getQueryInfoMethod; + } + + private static volatile io.grpc.MethodDescriptor getSyncQueryMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "SyncQuery", + requestType = io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest.class, + responseType = io.trino.spi.grpc.Trinomanager.ExecuteQueryReply.class, + methodType = io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + public static io.grpc.MethodDescriptor getSyncQueryMethod() { + io.grpc.MethodDescriptor getSyncQueryMethod; + if ((getSyncQueryMethod = TrinoManagerServiceGrpc.getSyncQueryMethod) == null) { + synchronized (TrinoManagerServiceGrpc.class) { + if ((getSyncQueryMethod = TrinoManagerServiceGrpc.getSyncQueryMethod) == null) { + TrinoManagerServiceGrpc.getSyncQueryMethod = getSyncQueryMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "SyncQuery")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Trinomanager.ExecuteQueryReply.getDefaultInstance())) + .setSchemaDescriptor(new TrinoManagerServiceMethodDescriptorSupplier("SyncQuery")) + .build(); + } + } + } + return getSyncQueryMethod; + } + + private static volatile io.grpc.MethodDescriptor getGetCatalogsMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "GetCatalogs", + requestType = com.google.protobuf.Empty.class, + responseType = io.trino.spi.grpc.Trinomanager.Catalog.class, + methodType = io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + public static io.grpc.MethodDescriptor getGetCatalogsMethod() { + io.grpc.MethodDescriptor getGetCatalogsMethod; + if ((getGetCatalogsMethod = TrinoManagerServiceGrpc.getGetCatalogsMethod) == null) { + synchronized (TrinoManagerServiceGrpc.class) { + if ((getGetCatalogsMethod = TrinoManagerServiceGrpc.getGetCatalogsMethod) == null) { + TrinoManagerServiceGrpc.getGetCatalogsMethod = getGetCatalogsMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "GetCatalogs")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + com.google.protobuf.Empty.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Trinomanager.Catalog.getDefaultInstance())) + .setSchemaDescriptor(new TrinoManagerServiceMethodDescriptorSupplier("GetCatalogs")) + .build(); + } + } + } + return getGetCatalogsMethod; + } + + private static volatile io.grpc.MethodDescriptor getGetViewsMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "GetViews", + requestType = com.google.protobuf.Empty.class, + responseType = io.trino.spi.grpc.Trinomanager.View.class, + methodType = io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + public static io.grpc.MethodDescriptor getGetViewsMethod() { + io.grpc.MethodDescriptor getGetViewsMethod; + if ((getGetViewsMethod = TrinoManagerServiceGrpc.getGetViewsMethod) == null) { + synchronized (TrinoManagerServiceGrpc.class) { + if ((getGetViewsMethod = TrinoManagerServiceGrpc.getGetViewsMethod) == null) { + TrinoManagerServiceGrpc.getGetViewsMethod = getGetViewsMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "GetViews")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + com.google.protobuf.Empty.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Trinomanager.View.getDefaultInstance())) + .setSchemaDescriptor(new TrinoManagerServiceMethodDescriptorSupplier("GetViews")) + .build(); + } + } + } + return getGetViewsMethod; + } + + private static volatile io.grpc.MethodDescriptor getCreateNotebookCellMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "CreateNotebookCell", + requestType = io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest.class, + responseType = io.trino.spi.grpc.Trinomanager.NotebookCell.class, + methodType = io.grpc.MethodDescriptor.MethodType.UNARY) + public static io.grpc.MethodDescriptor getCreateNotebookCellMethod() { + io.grpc.MethodDescriptor getCreateNotebookCellMethod; + if ((getCreateNotebookCellMethod = TrinoManagerServiceGrpc.getCreateNotebookCellMethod) == null) { + synchronized (TrinoManagerServiceGrpc.class) { + if ((getCreateNotebookCellMethod = TrinoManagerServiceGrpc.getCreateNotebookCellMethod) == null) { + TrinoManagerServiceGrpc.getCreateNotebookCellMethod = getCreateNotebookCellMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.UNARY) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "CreateNotebookCell")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Trinomanager.NotebookCell.getDefaultInstance())) + .setSchemaDescriptor(new TrinoManagerServiceMethodDescriptorSupplier("CreateNotebookCell")) + .build(); + } + } + } + return getCreateNotebookCellMethod; + } + + private static volatile io.grpc.MethodDescriptor getDeleteNotebookCellMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "DeleteNotebookCell", + requestType = io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest.class, + responseType = io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply.class, + methodType = io.grpc.MethodDescriptor.MethodType.UNARY) + public static io.grpc.MethodDescriptor getDeleteNotebookCellMethod() { + io.grpc.MethodDescriptor getDeleteNotebookCellMethod; + if ((getDeleteNotebookCellMethod = TrinoManagerServiceGrpc.getDeleteNotebookCellMethod) == null) { + synchronized (TrinoManagerServiceGrpc.class) { + if ((getDeleteNotebookCellMethod = TrinoManagerServiceGrpc.getDeleteNotebookCellMethod) == null) { + TrinoManagerServiceGrpc.getDeleteNotebookCellMethod = getDeleteNotebookCellMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.UNARY) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "DeleteNotebookCell")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply.getDefaultInstance())) + .setSchemaDescriptor(new TrinoManagerServiceMethodDescriptorSupplier("DeleteNotebookCell")) + .build(); + } + } + } + return getDeleteNotebookCellMethod; + } + + private static volatile io.grpc.MethodDescriptor getEditNotebookCellMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "EditNotebookCell", + requestType = io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest.class, + responseType = io.trino.spi.grpc.Trinomanager.NotebookCell.class, + methodType = io.grpc.MethodDescriptor.MethodType.UNARY) + public static io.grpc.MethodDescriptor getEditNotebookCellMethod() { + io.grpc.MethodDescriptor getEditNotebookCellMethod; + if ((getEditNotebookCellMethod = TrinoManagerServiceGrpc.getEditNotebookCellMethod) == null) { + synchronized (TrinoManagerServiceGrpc.class) { + if ((getEditNotebookCellMethod = TrinoManagerServiceGrpc.getEditNotebookCellMethod) == null) { + TrinoManagerServiceGrpc.getEditNotebookCellMethod = getEditNotebookCellMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.UNARY) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "EditNotebookCell")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Trinomanager.NotebookCell.getDefaultInstance())) + .setSchemaDescriptor(new TrinoManagerServiceMethodDescriptorSupplier("EditNotebookCell")) + .build(); + } + } + } + return getEditNotebookCellMethod; + } + + private static volatile io.grpc.MethodDescriptor getGetNotebookCellsMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "GetNotebookCells", + requestType = io.trino.spi.grpc.Trinomanager.TenantDataRequest.class, + responseType = io.trino.spi.grpc.Trinomanager.NotebookCell.class, + methodType = io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + public static io.grpc.MethodDescriptor getGetNotebookCellsMethod() { + io.grpc.MethodDescriptor getGetNotebookCellsMethod; + if ((getGetNotebookCellsMethod = TrinoManagerServiceGrpc.getGetNotebookCellsMethod) == null) { + synchronized (TrinoManagerServiceGrpc.class) { + if ((getGetNotebookCellsMethod = TrinoManagerServiceGrpc.getGetNotebookCellsMethod) == null) { + TrinoManagerServiceGrpc.getGetNotebookCellsMethod = getGetNotebookCellsMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "GetNotebookCells")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Trinomanager.TenantDataRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Trinomanager.NotebookCell.getDefaultInstance())) + .setSchemaDescriptor(new TrinoManagerServiceMethodDescriptorSupplier("GetNotebookCells")) + .build(); + } + } + } + return getGetNotebookCellsMethod; + } + + private static volatile io.grpc.MethodDescriptor getGetNotebookCellMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "GetNotebookCell", + requestType = io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest.class, + responseType = io.trino.spi.grpc.Trinomanager.NotebookCell.class, + methodType = io.grpc.MethodDescriptor.MethodType.UNARY) + public static io.grpc.MethodDescriptor getGetNotebookCellMethod() { + io.grpc.MethodDescriptor getGetNotebookCellMethod; + if ((getGetNotebookCellMethod = TrinoManagerServiceGrpc.getGetNotebookCellMethod) == null) { + synchronized (TrinoManagerServiceGrpc.class) { + if ((getGetNotebookCellMethod = TrinoManagerServiceGrpc.getGetNotebookCellMethod) == null) { + TrinoManagerServiceGrpc.getGetNotebookCellMethod = getGetNotebookCellMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.UNARY) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "GetNotebookCell")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Trinomanager.NotebookCell.getDefaultInstance())) + .setSchemaDescriptor(new TrinoManagerServiceMethodDescriptorSupplier("GetNotebookCell")) + .build(); + } + } + } + return getGetNotebookCellMethod; + } + + private static volatile io.grpc.MethodDescriptor getGetNotebooksMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "GetNotebooks", + requestType = io.trino.spi.grpc.Trinomanager.TenantDataRequest.class, + responseType = io.trino.spi.grpc.Trinomanager.Notebook.class, + methodType = io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + public static io.grpc.MethodDescriptor getGetNotebooksMethod() { + io.grpc.MethodDescriptor getGetNotebooksMethod; + if ((getGetNotebooksMethod = TrinoManagerServiceGrpc.getGetNotebooksMethod) == null) { + synchronized (TrinoManagerServiceGrpc.class) { + if ((getGetNotebooksMethod = TrinoManagerServiceGrpc.getGetNotebooksMethod) == null) { + TrinoManagerServiceGrpc.getGetNotebooksMethod = getGetNotebooksMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.SERVER_STREAMING) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "GetNotebooks")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Trinomanager.TenantDataRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Trinomanager.Notebook.getDefaultInstance())) + .setSchemaDescriptor(new TrinoManagerServiceMethodDescriptorSupplier("GetNotebooks")) + .build(); + } + } + } + return getGetNotebooksMethod; + } + + private static volatile io.grpc.MethodDescriptor getGetNotebookMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "GetNotebook", + requestType = io.trino.spi.grpc.Trinomanager.GetNotebookRequest.class, + responseType = io.trino.spi.grpc.Trinomanager.Notebook.class, + methodType = io.grpc.MethodDescriptor.MethodType.UNARY) + public static io.grpc.MethodDescriptor getGetNotebookMethod() { + io.grpc.MethodDescriptor getGetNotebookMethod; + if ((getGetNotebookMethod = TrinoManagerServiceGrpc.getGetNotebookMethod) == null) { + synchronized (TrinoManagerServiceGrpc.class) { + if ((getGetNotebookMethod = TrinoManagerServiceGrpc.getGetNotebookMethod) == null) { + TrinoManagerServiceGrpc.getGetNotebookMethod = getGetNotebookMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.UNARY) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "GetNotebook")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Trinomanager.GetNotebookRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Trinomanager.Notebook.getDefaultInstance())) + .setSchemaDescriptor(new TrinoManagerServiceMethodDescriptorSupplier("GetNotebook")) + .build(); + } + } + } + return getGetNotebookMethod; + } + + private static volatile io.grpc.MethodDescriptor getCreateNotebookMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "CreateNotebook", + requestType = io.trino.spi.grpc.Trinomanager.CreateNotebookRequest.class, + responseType = io.trino.spi.grpc.Trinomanager.Notebook.class, + methodType = io.grpc.MethodDescriptor.MethodType.UNARY) + public static io.grpc.MethodDescriptor getCreateNotebookMethod() { + io.grpc.MethodDescriptor getCreateNotebookMethod; + if ((getCreateNotebookMethod = TrinoManagerServiceGrpc.getCreateNotebookMethod) == null) { + synchronized (TrinoManagerServiceGrpc.class) { + if ((getCreateNotebookMethod = TrinoManagerServiceGrpc.getCreateNotebookMethod) == null) { + TrinoManagerServiceGrpc.getCreateNotebookMethod = getCreateNotebookMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.UNARY) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "CreateNotebook")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Trinomanager.CreateNotebookRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Trinomanager.Notebook.getDefaultInstance())) + .setSchemaDescriptor(new TrinoManagerServiceMethodDescriptorSupplier("CreateNotebook")) + .build(); + } + } + } + return getCreateNotebookMethod; + } + + private static volatile io.grpc.MethodDescriptor getDeleteNotebookMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "DeleteNotebook", + requestType = io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest.class, + responseType = com.google.protobuf.Empty.class, + methodType = io.grpc.MethodDescriptor.MethodType.UNARY) + public static io.grpc.MethodDescriptor getDeleteNotebookMethod() { + io.grpc.MethodDescriptor getDeleteNotebookMethod; + if ((getDeleteNotebookMethod = TrinoManagerServiceGrpc.getDeleteNotebookMethod) == null) { + synchronized (TrinoManagerServiceGrpc.class) { + if ((getDeleteNotebookMethod = TrinoManagerServiceGrpc.getDeleteNotebookMethod) == null) { + TrinoManagerServiceGrpc.getDeleteNotebookMethod = getDeleteNotebookMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.UNARY) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "DeleteNotebook")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + com.google.protobuf.Empty.getDefaultInstance())) + .setSchemaDescriptor(new TrinoManagerServiceMethodDescriptorSupplier("DeleteNotebook")) + .build(); + } + } + } + return getDeleteNotebookMethod; + } + + private static volatile io.grpc.MethodDescriptor getEditNotebookMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "EditNotebook", + requestType = io.trino.spi.grpc.Trinomanager.EditNotebookRequest.class, + responseType = io.trino.spi.grpc.Trinomanager.Notebook.class, + methodType = io.grpc.MethodDescriptor.MethodType.UNARY) + public static io.grpc.MethodDescriptor getEditNotebookMethod() { + io.grpc.MethodDescriptor getEditNotebookMethod; + if ((getEditNotebookMethod = TrinoManagerServiceGrpc.getEditNotebookMethod) == null) { + synchronized (TrinoManagerServiceGrpc.class) { + if ((getEditNotebookMethod = TrinoManagerServiceGrpc.getEditNotebookMethod) == null) { + TrinoManagerServiceGrpc.getEditNotebookMethod = getEditNotebookMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.UNARY) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "EditNotebook")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Trinomanager.EditNotebookRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Trinomanager.Notebook.getDefaultInstance())) + .setSchemaDescriptor(new TrinoManagerServiceMethodDescriptorSupplier("EditNotebook")) + .build(); + } + } + } + return getEditNotebookMethod; + } + + private static volatile io.grpc.MethodDescriptor getTestConnectionMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "TestConnection", + requestType = io.trino.spi.grpc.Trinomanager.TestConnectionRequest.class, + responseType = com.google.protobuf.Empty.class, + methodType = io.grpc.MethodDescriptor.MethodType.UNARY) + public static io.grpc.MethodDescriptor getTestConnectionMethod() { + io.grpc.MethodDescriptor getTestConnectionMethod; + if ((getTestConnectionMethod = TrinoManagerServiceGrpc.getTestConnectionMethod) == null) { + synchronized (TrinoManagerServiceGrpc.class) { + if ((getTestConnectionMethod = TrinoManagerServiceGrpc.getTestConnectionMethod) == null) { + TrinoManagerServiceGrpc.getTestConnectionMethod = getTestConnectionMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.UNARY) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "TestConnection")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Trinomanager.TestConnectionRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + com.google.protobuf.Empty.getDefaultInstance())) + .setSchemaDescriptor(new TrinoManagerServiceMethodDescriptorSupplier("TestConnection")) + .build(); + } + } + } + return getTestConnectionMethod; + } + + private static volatile io.grpc.MethodDescriptor getExpandQueryByDataSourceIDsMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "ExpandQueryByDataSourceIDs", + requestType = io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest.class, + responseType = io.trino.spi.grpc.Trinomanager.ExpandedQueryReply.class, + methodType = io.grpc.MethodDescriptor.MethodType.UNARY) + public static io.grpc.MethodDescriptor getExpandQueryByDataSourceIDsMethod() { + io.grpc.MethodDescriptor getExpandQueryByDataSourceIDsMethod; + if ((getExpandQueryByDataSourceIDsMethod = TrinoManagerServiceGrpc.getExpandQueryByDataSourceIDsMethod) == null) { + synchronized (TrinoManagerServiceGrpc.class) { + if ((getExpandQueryByDataSourceIDsMethod = TrinoManagerServiceGrpc.getExpandQueryByDataSourceIDsMethod) == null) { + TrinoManagerServiceGrpc.getExpandQueryByDataSourceIDsMethod = getExpandQueryByDataSourceIDsMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.UNARY) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "ExpandQueryByDataSourceIDs")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Trinomanager.ExpandedQueryReply.getDefaultInstance())) + .setSchemaDescriptor(new TrinoManagerServiceMethodDescriptorSupplier("ExpandQueryByDataSourceIDs")) + .build(); + } + } + } + return getExpandQueryByDataSourceIDsMethod; + } + + private static volatile io.grpc.MethodDescriptor getExpandQueryByDataSourceInstanceIDsMethod; + + @io.grpc.stub.annotations.RpcMethod( + fullMethodName = SERVICE_NAME + '/' + "ExpandQueryByDataSourceInstanceIDs", + requestType = io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest.class, + responseType = io.trino.spi.grpc.Trinomanager.ExpandedQueryReply.class, + methodType = io.grpc.MethodDescriptor.MethodType.UNARY) + public static io.grpc.MethodDescriptor getExpandQueryByDataSourceInstanceIDsMethod() { + io.grpc.MethodDescriptor getExpandQueryByDataSourceInstanceIDsMethod; + if ((getExpandQueryByDataSourceInstanceIDsMethod = TrinoManagerServiceGrpc.getExpandQueryByDataSourceInstanceIDsMethod) == null) { + synchronized (TrinoManagerServiceGrpc.class) { + if ((getExpandQueryByDataSourceInstanceIDsMethod = TrinoManagerServiceGrpc.getExpandQueryByDataSourceInstanceIDsMethod) == null) { + TrinoManagerServiceGrpc.getExpandQueryByDataSourceInstanceIDsMethod = getExpandQueryByDataSourceInstanceIDsMethod = + io.grpc.MethodDescriptor.newBuilder() + .setType(io.grpc.MethodDescriptor.MethodType.UNARY) + .setFullMethodName(generateFullMethodName(SERVICE_NAME, "ExpandQueryByDataSourceInstanceIDs")) + .setSampledToLocalTracing(true) + .setRequestMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest.getDefaultInstance())) + .setResponseMarshaller(io.grpc.protobuf.ProtoUtils.marshaller( + io.trino.spi.grpc.Trinomanager.ExpandedQueryReply.getDefaultInstance())) + .setSchemaDescriptor(new TrinoManagerServiceMethodDescriptorSupplier("ExpandQueryByDataSourceInstanceIDs")) + .build(); + } + } + } + return getExpandQueryByDataSourceInstanceIDsMethod; + } + + /** + * Creates a new async stub that supports all call types for the service + */ + public static TrinoManagerServiceStub newStub(io.grpc.Channel channel) { + io.grpc.stub.AbstractStub.StubFactory factory = + new io.grpc.stub.AbstractStub.StubFactory() { + @java.lang.Override + public TrinoManagerServiceStub newStub(io.grpc.Channel channel, io.grpc.CallOptions callOptions) { + return new TrinoManagerServiceStub(channel, callOptions); + } + }; + return TrinoManagerServiceStub.newStub(factory, channel); + } + + /** + * Creates a new blocking-style stub that supports unary and streaming output calls on the service + */ + public static TrinoManagerServiceBlockingStub newBlockingStub( + io.grpc.Channel channel) { + io.grpc.stub.AbstractStub.StubFactory factory = + new io.grpc.stub.AbstractStub.StubFactory() { + @java.lang.Override + public TrinoManagerServiceBlockingStub newStub(io.grpc.Channel channel, io.grpc.CallOptions callOptions) { + return new TrinoManagerServiceBlockingStub(channel, callOptions); + } + }; + return TrinoManagerServiceBlockingStub.newStub(factory, channel); + } + + /** + * Creates a new ListenableFuture-style stub that supports unary calls on the service + */ + public static TrinoManagerServiceFutureStub newFutureStub( + io.grpc.Channel channel) { + io.grpc.stub.AbstractStub.StubFactory factory = + new io.grpc.stub.AbstractStub.StubFactory() { + @java.lang.Override + public TrinoManagerServiceFutureStub newStub(io.grpc.Channel channel, io.grpc.CallOptions callOptions) { + return new TrinoManagerServiceFutureStub(channel, callOptions); + } + }; + return TrinoManagerServiceFutureStub.newStub(factory, channel); + } + + /** + */ + public interface AsyncService { + + /** + */ + default void queryInfo(io.trino.spi.grpc.Trinomanager.QueryDetailsRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getQueryInfoMethod(), responseObserver); + } + + /** + */ + default void syncQuery(io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getSyncQueryMethod(), responseObserver); + } + + /** + */ + default void getCatalogs(com.google.protobuf.Empty request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getGetCatalogsMethod(), responseObserver); + } + + /** + */ + default void getViews(com.google.protobuf.Empty request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getGetViewsMethod(), responseObserver); + } + + /** + */ + default void createNotebookCell(io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getCreateNotebookCellMethod(), responseObserver); + } + + /** + */ + default void deleteNotebookCell(io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getDeleteNotebookCellMethod(), responseObserver); + } + + /** + */ + default void editNotebookCell(io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getEditNotebookCellMethod(), responseObserver); + } + + /** + */ + default void getNotebookCells(io.trino.spi.grpc.Trinomanager.TenantDataRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getGetNotebookCellsMethod(), responseObserver); + } + + /** + */ + default void getNotebookCell(io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getGetNotebookCellMethod(), responseObserver); + } + + /** + */ + default void getNotebooks(io.trino.spi.grpc.Trinomanager.TenantDataRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getGetNotebooksMethod(), responseObserver); + } + + /** + */ + default void getNotebook(io.trino.spi.grpc.Trinomanager.GetNotebookRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getGetNotebookMethod(), responseObserver); + } + + /** + */ + default void createNotebook(io.trino.spi.grpc.Trinomanager.CreateNotebookRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getCreateNotebookMethod(), responseObserver); + } + + /** + */ + default void deleteNotebook(io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getDeleteNotebookMethod(), responseObserver); + } + + /** + */ + default void editNotebook(io.trino.spi.grpc.Trinomanager.EditNotebookRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getEditNotebookMethod(), responseObserver); + } + + /** + */ + default void testConnection(io.trino.spi.grpc.Trinomanager.TestConnectionRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getTestConnectionMethod(), responseObserver); + } + + /** + */ + default void expandQueryByDataSourceIDs(io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getExpandQueryByDataSourceIDsMethod(), responseObserver); + } + + /** + */ + default void expandQueryByDataSourceInstanceIDs(io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ServerCalls.asyncUnimplementedUnaryCall(getExpandQueryByDataSourceInstanceIDsMethod(), responseObserver); + } + } + + /** + * Base class for the server implementation of the service TrinoManagerService. + */ + public static abstract class TrinoManagerServiceImplBase + implements io.grpc.BindableService, AsyncService { + + @java.lang.Override public final io.grpc.ServerServiceDefinition bindService() { + return TrinoManagerServiceGrpc.bindService(this); + } + } + + /** + * A stub to allow clients to do asynchronous rpc calls to service TrinoManagerService. + */ + public static final class TrinoManagerServiceStub + extends io.grpc.stub.AbstractAsyncStub { + private TrinoManagerServiceStub( + io.grpc.Channel channel, io.grpc.CallOptions callOptions) { + super(channel, callOptions); + } + + @java.lang.Override + protected TrinoManagerServiceStub build( + io.grpc.Channel channel, io.grpc.CallOptions callOptions) { + return new TrinoManagerServiceStub(channel, callOptions); + } + + /** + */ + public void queryInfo(io.trino.spi.grpc.Trinomanager.QueryDetailsRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncUnaryCall( + getChannel().newCall(getQueryInfoMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void syncQuery(io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncServerStreamingCall( + getChannel().newCall(getSyncQueryMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void getCatalogs(com.google.protobuf.Empty request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncServerStreamingCall( + getChannel().newCall(getGetCatalogsMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void getViews(com.google.protobuf.Empty request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncServerStreamingCall( + getChannel().newCall(getGetViewsMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void createNotebookCell(io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncUnaryCall( + getChannel().newCall(getCreateNotebookCellMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void deleteNotebookCell(io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncUnaryCall( + getChannel().newCall(getDeleteNotebookCellMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void editNotebookCell(io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncUnaryCall( + getChannel().newCall(getEditNotebookCellMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void getNotebookCells(io.trino.spi.grpc.Trinomanager.TenantDataRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncServerStreamingCall( + getChannel().newCall(getGetNotebookCellsMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void getNotebookCell(io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncUnaryCall( + getChannel().newCall(getGetNotebookCellMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void getNotebooks(io.trino.spi.grpc.Trinomanager.TenantDataRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncServerStreamingCall( + getChannel().newCall(getGetNotebooksMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void getNotebook(io.trino.spi.grpc.Trinomanager.GetNotebookRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncUnaryCall( + getChannel().newCall(getGetNotebookMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void createNotebook(io.trino.spi.grpc.Trinomanager.CreateNotebookRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncUnaryCall( + getChannel().newCall(getCreateNotebookMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void deleteNotebook(io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncUnaryCall( + getChannel().newCall(getDeleteNotebookMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void editNotebook(io.trino.spi.grpc.Trinomanager.EditNotebookRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncUnaryCall( + getChannel().newCall(getEditNotebookMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void testConnection(io.trino.spi.grpc.Trinomanager.TestConnectionRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncUnaryCall( + getChannel().newCall(getTestConnectionMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void expandQueryByDataSourceIDs(io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncUnaryCall( + getChannel().newCall(getExpandQueryByDataSourceIDsMethod(), getCallOptions()), request, responseObserver); + } + + /** + */ + public void expandQueryByDataSourceInstanceIDs(io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest request, + io.grpc.stub.StreamObserver responseObserver) { + io.grpc.stub.ClientCalls.asyncUnaryCall( + getChannel().newCall(getExpandQueryByDataSourceInstanceIDsMethod(), getCallOptions()), request, responseObserver); + } + } + + /** + * A stub to allow clients to do synchronous rpc calls to service TrinoManagerService. + */ + public static final class TrinoManagerServiceBlockingStub + extends io.grpc.stub.AbstractBlockingStub { + private TrinoManagerServiceBlockingStub( + io.grpc.Channel channel, io.grpc.CallOptions callOptions) { + super(channel, callOptions); + } + + @java.lang.Override + protected TrinoManagerServiceBlockingStub build( + io.grpc.Channel channel, io.grpc.CallOptions callOptions) { + return new TrinoManagerServiceBlockingStub(channel, callOptions); + } + + /** + */ + public io.trino.spi.grpc.Trinomanager.QueryDetailsReply queryInfo(io.trino.spi.grpc.Trinomanager.QueryDetailsRequest request) { + return io.grpc.stub.ClientCalls.blockingUnaryCall( + getChannel(), getQueryInfoMethod(), getCallOptions(), request); + } + + /** + */ + public java.util.Iterator syncQuery( + io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest request) { + return io.grpc.stub.ClientCalls.blockingServerStreamingCall( + getChannel(), getSyncQueryMethod(), getCallOptions(), request); + } + + /** + */ + public java.util.Iterator getCatalogs( + com.google.protobuf.Empty request) { + return io.grpc.stub.ClientCalls.blockingServerStreamingCall( + getChannel(), getGetCatalogsMethod(), getCallOptions(), request); + } + + /** + */ + public java.util.Iterator getViews( + com.google.protobuf.Empty request) { + return io.grpc.stub.ClientCalls.blockingServerStreamingCall( + getChannel(), getGetViewsMethod(), getCallOptions(), request); + } + + /** + */ + public io.trino.spi.grpc.Trinomanager.NotebookCell createNotebookCell(io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest request) { + return io.grpc.stub.ClientCalls.blockingUnaryCall( + getChannel(), getCreateNotebookCellMethod(), getCallOptions(), request); + } + + /** + */ + public io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply deleteNotebookCell(io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest request) { + return io.grpc.stub.ClientCalls.blockingUnaryCall( + getChannel(), getDeleteNotebookCellMethod(), getCallOptions(), request); + } + + /** + */ + public io.trino.spi.grpc.Trinomanager.NotebookCell editNotebookCell(io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest request) { + return io.grpc.stub.ClientCalls.blockingUnaryCall( + getChannel(), getEditNotebookCellMethod(), getCallOptions(), request); + } + + /** + */ + public java.util.Iterator getNotebookCells( + io.trino.spi.grpc.Trinomanager.TenantDataRequest request) { + return io.grpc.stub.ClientCalls.blockingServerStreamingCall( + getChannel(), getGetNotebookCellsMethod(), getCallOptions(), request); + } + + /** + */ + public io.trino.spi.grpc.Trinomanager.NotebookCell getNotebookCell(io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest request) { + return io.grpc.stub.ClientCalls.blockingUnaryCall( + getChannel(), getGetNotebookCellMethod(), getCallOptions(), request); + } + + /** + */ + public java.util.Iterator getNotebooks( + io.trino.spi.grpc.Trinomanager.TenantDataRequest request) { + return io.grpc.stub.ClientCalls.blockingServerStreamingCall( + getChannel(), getGetNotebooksMethod(), getCallOptions(), request); + } + + /** + */ + public io.trino.spi.grpc.Trinomanager.Notebook getNotebook(io.trino.spi.grpc.Trinomanager.GetNotebookRequest request) { + return io.grpc.stub.ClientCalls.blockingUnaryCall( + getChannel(), getGetNotebookMethod(), getCallOptions(), request); + } + + /** + */ + public io.trino.spi.grpc.Trinomanager.Notebook createNotebook(io.trino.spi.grpc.Trinomanager.CreateNotebookRequest request) { + return io.grpc.stub.ClientCalls.blockingUnaryCall( + getChannel(), getCreateNotebookMethod(), getCallOptions(), request); + } + + /** + */ + public com.google.protobuf.Empty deleteNotebook(io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest request) { + return io.grpc.stub.ClientCalls.blockingUnaryCall( + getChannel(), getDeleteNotebookMethod(), getCallOptions(), request); + } + + /** + */ + public io.trino.spi.grpc.Trinomanager.Notebook editNotebook(io.trino.spi.grpc.Trinomanager.EditNotebookRequest request) { + return io.grpc.stub.ClientCalls.blockingUnaryCall( + getChannel(), getEditNotebookMethod(), getCallOptions(), request); + } + + /** + */ + public com.google.protobuf.Empty testConnection(io.trino.spi.grpc.Trinomanager.TestConnectionRequest request) { + return io.grpc.stub.ClientCalls.blockingUnaryCall( + getChannel(), getTestConnectionMethod(), getCallOptions(), request); + } + + /** + */ + public io.trino.spi.grpc.Trinomanager.ExpandedQueryReply expandQueryByDataSourceIDs(io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest request) { + return io.grpc.stub.ClientCalls.blockingUnaryCall( + getChannel(), getExpandQueryByDataSourceIDsMethod(), getCallOptions(), request); + } + + /** + */ + public io.trino.spi.grpc.Trinomanager.ExpandedQueryReply expandQueryByDataSourceInstanceIDs(io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest request) { + return io.grpc.stub.ClientCalls.blockingUnaryCall( + getChannel(), getExpandQueryByDataSourceInstanceIDsMethod(), getCallOptions(), request); + } + } + + /** + * A stub to allow clients to do ListenableFuture-style rpc calls to service TrinoManagerService. + */ + public static final class TrinoManagerServiceFutureStub + extends io.grpc.stub.AbstractFutureStub { + private TrinoManagerServiceFutureStub( + io.grpc.Channel channel, io.grpc.CallOptions callOptions) { + super(channel, callOptions); + } + + @java.lang.Override + protected TrinoManagerServiceFutureStub build( + io.grpc.Channel channel, io.grpc.CallOptions callOptions) { + return new TrinoManagerServiceFutureStub(channel, callOptions); + } + + /** + */ + public com.google.common.util.concurrent.ListenableFuture queryInfo( + io.trino.spi.grpc.Trinomanager.QueryDetailsRequest request) { + return io.grpc.stub.ClientCalls.futureUnaryCall( + getChannel().newCall(getQueryInfoMethod(), getCallOptions()), request); + } + + /** + */ + public com.google.common.util.concurrent.ListenableFuture createNotebookCell( + io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest request) { + return io.grpc.stub.ClientCalls.futureUnaryCall( + getChannel().newCall(getCreateNotebookCellMethod(), getCallOptions()), request); + } + + /** + */ + public com.google.common.util.concurrent.ListenableFuture deleteNotebookCell( + io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest request) { + return io.grpc.stub.ClientCalls.futureUnaryCall( + getChannel().newCall(getDeleteNotebookCellMethod(), getCallOptions()), request); + } + + /** + */ + public com.google.common.util.concurrent.ListenableFuture editNotebookCell( + io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest request) { + return io.grpc.stub.ClientCalls.futureUnaryCall( + getChannel().newCall(getEditNotebookCellMethod(), getCallOptions()), request); + } + + /** + */ + public com.google.common.util.concurrent.ListenableFuture getNotebookCell( + io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest request) { + return io.grpc.stub.ClientCalls.futureUnaryCall( + getChannel().newCall(getGetNotebookCellMethod(), getCallOptions()), request); + } + + /** + */ + public com.google.common.util.concurrent.ListenableFuture getNotebook( + io.trino.spi.grpc.Trinomanager.GetNotebookRequest request) { + return io.grpc.stub.ClientCalls.futureUnaryCall( + getChannel().newCall(getGetNotebookMethod(), getCallOptions()), request); + } + + /** + */ + public com.google.common.util.concurrent.ListenableFuture createNotebook( + io.trino.spi.grpc.Trinomanager.CreateNotebookRequest request) { + return io.grpc.stub.ClientCalls.futureUnaryCall( + getChannel().newCall(getCreateNotebookMethod(), getCallOptions()), request); + } + + /** + */ + public com.google.common.util.concurrent.ListenableFuture deleteNotebook( + io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest request) { + return io.grpc.stub.ClientCalls.futureUnaryCall( + getChannel().newCall(getDeleteNotebookMethod(), getCallOptions()), request); + } + + /** + */ + public com.google.common.util.concurrent.ListenableFuture editNotebook( + io.trino.spi.grpc.Trinomanager.EditNotebookRequest request) { + return io.grpc.stub.ClientCalls.futureUnaryCall( + getChannel().newCall(getEditNotebookMethod(), getCallOptions()), request); + } + + /** + */ + public com.google.common.util.concurrent.ListenableFuture testConnection( + io.trino.spi.grpc.Trinomanager.TestConnectionRequest request) { + return io.grpc.stub.ClientCalls.futureUnaryCall( + getChannel().newCall(getTestConnectionMethod(), getCallOptions()), request); + } + + /** + */ + public com.google.common.util.concurrent.ListenableFuture expandQueryByDataSourceIDs( + io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest request) { + return io.grpc.stub.ClientCalls.futureUnaryCall( + getChannel().newCall(getExpandQueryByDataSourceIDsMethod(), getCallOptions()), request); + } + + /** + */ + public com.google.common.util.concurrent.ListenableFuture expandQueryByDataSourceInstanceIDs( + io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest request) { + return io.grpc.stub.ClientCalls.futureUnaryCall( + getChannel().newCall(getExpandQueryByDataSourceInstanceIDsMethod(), getCallOptions()), request); + } + } + + private static final int METHODID_QUERY_INFO = 0; + private static final int METHODID_SYNC_QUERY = 1; + private static final int METHODID_GET_CATALOGS = 2; + private static final int METHODID_GET_VIEWS = 3; + private static final int METHODID_CREATE_NOTEBOOK_CELL = 4; + private static final int METHODID_DELETE_NOTEBOOK_CELL = 5; + private static final int METHODID_EDIT_NOTEBOOK_CELL = 6; + private static final int METHODID_GET_NOTEBOOK_CELLS = 7; + private static final int METHODID_GET_NOTEBOOK_CELL = 8; + private static final int METHODID_GET_NOTEBOOKS = 9; + private static final int METHODID_GET_NOTEBOOK = 10; + private static final int METHODID_CREATE_NOTEBOOK = 11; + private static final int METHODID_DELETE_NOTEBOOK = 12; + private static final int METHODID_EDIT_NOTEBOOK = 13; + private static final int METHODID_TEST_CONNECTION = 14; + private static final int METHODID_EXPAND_QUERY_BY_DATA_SOURCE_IDS = 15; + private static final int METHODID_EXPAND_QUERY_BY_DATA_SOURCE_INSTANCE_IDS = 16; + + private static final class MethodHandlers implements + io.grpc.stub.ServerCalls.UnaryMethod, + io.grpc.stub.ServerCalls.ServerStreamingMethod, + io.grpc.stub.ServerCalls.ClientStreamingMethod, + io.grpc.stub.ServerCalls.BidiStreamingMethod { + private final AsyncService serviceImpl; + private final int methodId; + + MethodHandlers(AsyncService serviceImpl, int methodId) { + this.serviceImpl = serviceImpl; + this.methodId = methodId; + } + + @java.lang.Override + @java.lang.SuppressWarnings("unchecked") + public void invoke(Req request, io.grpc.stub.StreamObserver responseObserver) { + switch (methodId) { + case METHODID_QUERY_INFO: + serviceImpl.queryInfo((io.trino.spi.grpc.Trinomanager.QueryDetailsRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_SYNC_QUERY: + serviceImpl.syncQuery((io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_GET_CATALOGS: + serviceImpl.getCatalogs((com.google.protobuf.Empty) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_GET_VIEWS: + serviceImpl.getViews((com.google.protobuf.Empty) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_CREATE_NOTEBOOK_CELL: + serviceImpl.createNotebookCell((io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_DELETE_NOTEBOOK_CELL: + serviceImpl.deleteNotebookCell((io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_EDIT_NOTEBOOK_CELL: + serviceImpl.editNotebookCell((io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_GET_NOTEBOOK_CELLS: + serviceImpl.getNotebookCells((io.trino.spi.grpc.Trinomanager.TenantDataRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_GET_NOTEBOOK_CELL: + serviceImpl.getNotebookCell((io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_GET_NOTEBOOKS: + serviceImpl.getNotebooks((io.trino.spi.grpc.Trinomanager.TenantDataRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_GET_NOTEBOOK: + serviceImpl.getNotebook((io.trino.spi.grpc.Trinomanager.GetNotebookRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_CREATE_NOTEBOOK: + serviceImpl.createNotebook((io.trino.spi.grpc.Trinomanager.CreateNotebookRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_DELETE_NOTEBOOK: + serviceImpl.deleteNotebook((io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_EDIT_NOTEBOOK: + serviceImpl.editNotebook((io.trino.spi.grpc.Trinomanager.EditNotebookRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_TEST_CONNECTION: + serviceImpl.testConnection((io.trino.spi.grpc.Trinomanager.TestConnectionRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_EXPAND_QUERY_BY_DATA_SOURCE_IDS: + serviceImpl.expandQueryByDataSourceIDs((io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + case METHODID_EXPAND_QUERY_BY_DATA_SOURCE_INSTANCE_IDS: + serviceImpl.expandQueryByDataSourceInstanceIDs((io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest) request, + (io.grpc.stub.StreamObserver) responseObserver); + break; + default: + throw new AssertionError(); + } + } + + @java.lang.Override + @java.lang.SuppressWarnings("unchecked") + public io.grpc.stub.StreamObserver invoke( + io.grpc.stub.StreamObserver responseObserver) { + switch (methodId) { + default: + throw new AssertionError(); + } + } + } + + public static final io.grpc.ServerServiceDefinition bindService(AsyncService service) { + return io.grpc.ServerServiceDefinition.builder(getServiceDescriptor()) + .addMethod( + getQueryInfoMethod(), + io.grpc.stub.ServerCalls.asyncUnaryCall( + new MethodHandlers< + io.trino.spi.grpc.Trinomanager.QueryDetailsRequest, + io.trino.spi.grpc.Trinomanager.QueryDetailsReply>( + service, METHODID_QUERY_INFO))) + .addMethod( + getSyncQueryMethod(), + io.grpc.stub.ServerCalls.asyncServerStreamingCall( + new MethodHandlers< + io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest, + io.trino.spi.grpc.Trinomanager.ExecuteQueryReply>( + service, METHODID_SYNC_QUERY))) + .addMethod( + getGetCatalogsMethod(), + io.grpc.stub.ServerCalls.asyncServerStreamingCall( + new MethodHandlers< + com.google.protobuf.Empty, + io.trino.spi.grpc.Trinomanager.Catalog>( + service, METHODID_GET_CATALOGS))) + .addMethod( + getGetViewsMethod(), + io.grpc.stub.ServerCalls.asyncServerStreamingCall( + new MethodHandlers< + com.google.protobuf.Empty, + io.trino.spi.grpc.Trinomanager.View>( + service, METHODID_GET_VIEWS))) + .addMethod( + getCreateNotebookCellMethod(), + io.grpc.stub.ServerCalls.asyncUnaryCall( + new MethodHandlers< + io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest, + io.trino.spi.grpc.Trinomanager.NotebookCell>( + service, METHODID_CREATE_NOTEBOOK_CELL))) + .addMethod( + getDeleteNotebookCellMethod(), + io.grpc.stub.ServerCalls.asyncUnaryCall( + new MethodHandlers< + io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest, + io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply>( + service, METHODID_DELETE_NOTEBOOK_CELL))) + .addMethod( + getEditNotebookCellMethod(), + io.grpc.stub.ServerCalls.asyncUnaryCall( + new MethodHandlers< + io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest, + io.trino.spi.grpc.Trinomanager.NotebookCell>( + service, METHODID_EDIT_NOTEBOOK_CELL))) + .addMethod( + getGetNotebookCellsMethod(), + io.grpc.stub.ServerCalls.asyncServerStreamingCall( + new MethodHandlers< + io.trino.spi.grpc.Trinomanager.TenantDataRequest, + io.trino.spi.grpc.Trinomanager.NotebookCell>( + service, METHODID_GET_NOTEBOOK_CELLS))) + .addMethod( + getGetNotebookCellMethod(), + io.grpc.stub.ServerCalls.asyncUnaryCall( + new MethodHandlers< + io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest, + io.trino.spi.grpc.Trinomanager.NotebookCell>( + service, METHODID_GET_NOTEBOOK_CELL))) + .addMethod( + getGetNotebooksMethod(), + io.grpc.stub.ServerCalls.asyncServerStreamingCall( + new MethodHandlers< + io.trino.spi.grpc.Trinomanager.TenantDataRequest, + io.trino.spi.grpc.Trinomanager.Notebook>( + service, METHODID_GET_NOTEBOOKS))) + .addMethod( + getGetNotebookMethod(), + io.grpc.stub.ServerCalls.asyncUnaryCall( + new MethodHandlers< + io.trino.spi.grpc.Trinomanager.GetNotebookRequest, + io.trino.spi.grpc.Trinomanager.Notebook>( + service, METHODID_GET_NOTEBOOK))) + .addMethod( + getCreateNotebookMethod(), + io.grpc.stub.ServerCalls.asyncUnaryCall( + new MethodHandlers< + io.trino.spi.grpc.Trinomanager.CreateNotebookRequest, + io.trino.spi.grpc.Trinomanager.Notebook>( + service, METHODID_CREATE_NOTEBOOK))) + .addMethod( + getDeleteNotebookMethod(), + io.grpc.stub.ServerCalls.asyncUnaryCall( + new MethodHandlers< + io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest, + com.google.protobuf.Empty>( + service, METHODID_DELETE_NOTEBOOK))) + .addMethod( + getEditNotebookMethod(), + io.grpc.stub.ServerCalls.asyncUnaryCall( + new MethodHandlers< + io.trino.spi.grpc.Trinomanager.EditNotebookRequest, + io.trino.spi.grpc.Trinomanager.Notebook>( + service, METHODID_EDIT_NOTEBOOK))) + .addMethod( + getTestConnectionMethod(), + io.grpc.stub.ServerCalls.asyncUnaryCall( + new MethodHandlers< + io.trino.spi.grpc.Trinomanager.TestConnectionRequest, + com.google.protobuf.Empty>( + service, METHODID_TEST_CONNECTION))) + .addMethod( + getExpandQueryByDataSourceIDsMethod(), + io.grpc.stub.ServerCalls.asyncUnaryCall( + new MethodHandlers< + io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest, + io.trino.spi.grpc.Trinomanager.ExpandedQueryReply>( + service, METHODID_EXPAND_QUERY_BY_DATA_SOURCE_IDS))) + .addMethod( + getExpandQueryByDataSourceInstanceIDsMethod(), + io.grpc.stub.ServerCalls.asyncUnaryCall( + new MethodHandlers< + io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest, + io.trino.spi.grpc.Trinomanager.ExpandedQueryReply>( + service, METHODID_EXPAND_QUERY_BY_DATA_SOURCE_INSTANCE_IDS))) + .build(); + } + + private static abstract class TrinoManagerServiceBaseDescriptorSupplier + implements io.grpc.protobuf.ProtoFileDescriptorSupplier, io.grpc.protobuf.ProtoServiceDescriptorSupplier { + TrinoManagerServiceBaseDescriptorSupplier() {} + + @java.lang.Override + public com.google.protobuf.Descriptors.FileDescriptor getFileDescriptor() { + return io.trino.spi.grpc.Trinomanager.getDescriptor(); + } + + @java.lang.Override + public com.google.protobuf.Descriptors.ServiceDescriptor getServiceDescriptor() { + return getFileDescriptor().findServiceByName("TrinoManagerService"); + } + } + + private static final class TrinoManagerServiceFileDescriptorSupplier + extends TrinoManagerServiceBaseDescriptorSupplier { + TrinoManagerServiceFileDescriptorSupplier() {} + } + + private static final class TrinoManagerServiceMethodDescriptorSupplier + extends TrinoManagerServiceBaseDescriptorSupplier + implements io.grpc.protobuf.ProtoMethodDescriptorSupplier { + private final java.lang.String methodName; + + TrinoManagerServiceMethodDescriptorSupplier(java.lang.String methodName) { + this.methodName = methodName; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.MethodDescriptor getMethodDescriptor() { + return getServiceDescriptor().findMethodByName(methodName); + } + } + + private static volatile io.grpc.ServiceDescriptor serviceDescriptor; + + public static io.grpc.ServiceDescriptor getServiceDescriptor() { + io.grpc.ServiceDescriptor result = serviceDescriptor; + if (result == null) { + synchronized (TrinoManagerServiceGrpc.class) { + result = serviceDescriptor; + if (result == null) { + serviceDescriptor = result = io.grpc.ServiceDescriptor.newBuilder(SERVICE_NAME) + .setSchemaDescriptor(new TrinoManagerServiceFileDescriptorSupplier()) + .addMethod(getQueryInfoMethod()) + .addMethod(getSyncQueryMethod()) + .addMethod(getGetCatalogsMethod()) + .addMethod(getGetViewsMethod()) + .addMethod(getCreateNotebookCellMethod()) + .addMethod(getDeleteNotebookCellMethod()) + .addMethod(getEditNotebookCellMethod()) + .addMethod(getGetNotebookCellsMethod()) + .addMethod(getGetNotebookCellMethod()) + .addMethod(getGetNotebooksMethod()) + .addMethod(getGetNotebookMethod()) + .addMethod(getCreateNotebookMethod()) + .addMethod(getDeleteNotebookMethod()) + .addMethod(getEditNotebookMethod()) + .addMethod(getTestConnectionMethod()) + .addMethod(getExpandQueryByDataSourceIDsMethod()) + .addMethod(getExpandQueryByDataSourceInstanceIDsMethod()) + .build(); + } + } + } + return result; + } +} diff --git a/core/trino-spi/src/main/java/io/trino/spi/grpc/Trinomanager.java b/core/trino-spi/src/main/java/io/trino/spi/grpc/Trinomanager.java new file mode 100644 index 000000000000..de594a9324f2 --- /dev/null +++ b/core/trino-spi/src/main/java/io/trino/spi/grpc/Trinomanager.java @@ -0,0 +1,30745 @@ +// Generated by the protocol buffer compiler. DO NOT EDIT! +// source: trinomanager.proto + +package io.trino.spi.grpc; + +public final class Trinomanager { + private Trinomanager() {} + public static void registerAllExtensions( + com.google.protobuf.ExtensionRegistryLite registry) { + } + + public static void registerAllExtensions( + com.google.protobuf.ExtensionRegistry registry) { + registerAllExtensions( + (com.google.protobuf.ExtensionRegistryLite) registry); + } + public interface CatalogOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.Catalog) + com.google.protobuf.MessageOrBuilder { + + /** + * string name = 1; + * @return The name. + */ + java.lang.String getName(); + /** + * string name = 1; + * @return The bytes for name. + */ + com.google.protobuf.ByteString + getNameBytes(); + + /** + * string connector = 2; + * @return The connector. + */ + java.lang.String getConnector(); + /** + * string connector = 2; + * @return The bytes for connector. + */ + com.google.protobuf.ByteString + getConnectorBytes(); + + /** + * map<string, string> params = 3; + */ + int getParamsCount(); + /** + * map<string, string> params = 3; + */ + boolean containsParams( + java.lang.String key); + /** + * Use {@link #getParamsMap()} instead. + */ + @java.lang.Deprecated + java.util.Map + getParams(); + /** + * map<string, string> params = 3; + */ + java.util.Map + getParamsMap(); + /** + * map<string, string> params = 3; + */ + /* nullable */ +java.lang.String getParamsOrDefault( + java.lang.String key, + /* nullable */ +java.lang.String defaultValue); + /** + * map<string, string> params = 3; + */ + java.lang.String getParamsOrThrow( + java.lang.String key); + + /** + * string tenant_name = 4; + * @return The tenantName. + */ + java.lang.String getTenantName(); + /** + * string tenant_name = 4; + * @return The bytes for tenantName. + */ + com.google.protobuf.ByteString + getTenantNameBytes(); + } + /** + * Protobuf type {@code grpc.Catalog} + */ + public static final class Catalog extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.Catalog) + CatalogOrBuilder { + private static final long serialVersionUID = 0L; + // Use Catalog.newBuilder() to construct. + private Catalog(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private Catalog() { + name_ = ""; + connector_ = ""; + tenantName_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new Catalog(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_Catalog_descriptor; + } + + @SuppressWarnings({"rawtypes"}) + @java.lang.Override + protected com.google.protobuf.MapField internalGetMapField( + int number) { + switch (number) { + case 3: + return internalGetParams(); + default: + throw new RuntimeException( + "Invalid map field number: " + number); + } + } + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_Catalog_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.Catalog.class, io.trino.spi.grpc.Trinomanager.Catalog.Builder.class); + } + + public static final int NAME_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object name_ = ""; + /** + * string name = 1; + * @return The name. + */ + @java.lang.Override + public java.lang.String getName() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } + } + /** + * string name = 1; + * @return The bytes for name. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int CONNECTOR_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object connector_ = ""; + /** + * string connector = 2; + * @return The connector. + */ + @java.lang.Override + public java.lang.String getConnector() { + java.lang.Object ref = connector_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + connector_ = s; + return s; + } + } + /** + * string connector = 2; + * @return The bytes for connector. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getConnectorBytes() { + java.lang.Object ref = connector_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + connector_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int PARAMS_FIELD_NUMBER = 3; + private static final class ParamsDefaultEntryHolder { + static final com.google.protobuf.MapEntry< + java.lang.String, java.lang.String> defaultEntry = + com.google.protobuf.MapEntry + .newDefaultInstance( + io.trino.spi.grpc.Trinomanager.internal_static_grpc_Catalog_ParamsEntry_descriptor, + com.google.protobuf.WireFormat.FieldType.STRING, + "", + com.google.protobuf.WireFormat.FieldType.STRING, + ""); + } + @SuppressWarnings("serial") + private com.google.protobuf.MapField< + java.lang.String, java.lang.String> params_; + private com.google.protobuf.MapField + internalGetParams() { + if (params_ == null) { + return com.google.protobuf.MapField.emptyMapField( + ParamsDefaultEntryHolder.defaultEntry); + } + return params_; + } + public int getParamsCount() { + return internalGetParams().getMap().size(); + } + /** + * map<string, string> params = 3; + */ + @java.lang.Override + public boolean containsParams( + java.lang.String key) { + if (key == null) { throw new NullPointerException("map key"); } + return internalGetParams().getMap().containsKey(key); + } + /** + * Use {@link #getParamsMap()} instead. + */ + @java.lang.Override + @java.lang.Deprecated + public java.util.Map getParams() { + return getParamsMap(); + } + /** + * map<string, string> params = 3; + */ + @java.lang.Override + public java.util.Map getParamsMap() { + return internalGetParams().getMap(); + } + /** + * map<string, string> params = 3; + */ + @java.lang.Override + public /* nullable */ +java.lang.String getParamsOrDefault( + java.lang.String key, + /* nullable */ +java.lang.String defaultValue) { + if (key == null) { throw new NullPointerException("map key"); } + java.util.Map map = + internalGetParams().getMap(); + return map.containsKey(key) ? map.get(key) : defaultValue; + } + /** + * map<string, string> params = 3; + */ + @java.lang.Override + public java.lang.String getParamsOrThrow( + java.lang.String key) { + if (key == null) { throw new NullPointerException("map key"); } + java.util.Map map = + internalGetParams().getMap(); + if (!map.containsKey(key)) { + throw new java.lang.IllegalArgumentException(); + } + return map.get(key); + } + + public static final int TENANT_NAME_FIELD_NUMBER = 4; + @SuppressWarnings("serial") + private volatile java.lang.Object tenantName_ = ""; + /** + * string tenant_name = 4; + * @return The tenantName. + */ + @java.lang.Override + public java.lang.String getTenantName() { + java.lang.Object ref = tenantName_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenantName_ = s; + return s; + } + } + /** + * string tenant_name = 4; + * @return The bytes for tenantName. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantNameBytes() { + java.lang.Object ref = tenantName_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenantName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(name_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, name_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(connector_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, connector_); + } + com.google.protobuf.GeneratedMessageV3 + .serializeStringMapTo( + output, + internalGetParams(), + ParamsDefaultEntryHolder.defaultEntry, + 3); + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenantName_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 4, tenantName_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(name_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, name_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(connector_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, connector_); + } + for (java.util.Map.Entry entry + : internalGetParams().getMap().entrySet()) { + com.google.protobuf.MapEntry + params__ = ParamsDefaultEntryHolder.defaultEntry.newBuilderForType() + .setKey(entry.getKey()) + .setValue(entry.getValue()) + .build(); + size += com.google.protobuf.CodedOutputStream + .computeMessageSize(3, params__); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenantName_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(4, tenantName_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Trinomanager.Catalog)) { + return super.equals(obj); + } + io.trino.spi.grpc.Trinomanager.Catalog other = (io.trino.spi.grpc.Trinomanager.Catalog) obj; + + if (!getName() + .equals(other.getName())) return false; + if (!getConnector() + .equals(other.getConnector())) return false; + if (!internalGetParams().equals( + other.internalGetParams())) return false; + if (!getTenantName() + .equals(other.getTenantName())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + NAME_FIELD_NUMBER; + hash = (53 * hash) + getName().hashCode(); + hash = (37 * hash) + CONNECTOR_FIELD_NUMBER; + hash = (53 * hash) + getConnector().hashCode(); + if (!internalGetParams().getMap().isEmpty()) { + hash = (37 * hash) + PARAMS_FIELD_NUMBER; + hash = (53 * hash) + internalGetParams().hashCode(); + } + hash = (37 * hash) + TENANT_NAME_FIELD_NUMBER; + hash = (53 * hash) + getTenantName().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Trinomanager.Catalog parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.Catalog parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.Catalog parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.Catalog parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.Catalog parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.Catalog parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.Catalog parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.Catalog parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Trinomanager.Catalog parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Trinomanager.Catalog parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.Catalog parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.Catalog parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Trinomanager.Catalog prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.Catalog} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.Catalog) + io.trino.spi.grpc.Trinomanager.CatalogOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_Catalog_descriptor; + } + + @SuppressWarnings({"rawtypes"}) + protected com.google.protobuf.MapField internalGetMapField( + int number) { + switch (number) { + case 3: + return internalGetParams(); + default: + throw new RuntimeException( + "Invalid map field number: " + number); + } + } + @SuppressWarnings({"rawtypes"}) + protected com.google.protobuf.MapField internalGetMutableMapField( + int number) { + switch (number) { + case 3: + return internalGetMutableParams(); + default: + throw new RuntimeException( + "Invalid map field number: " + number); + } + } + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_Catalog_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.Catalog.class, io.trino.spi.grpc.Trinomanager.Catalog.Builder.class); + } + + // Construct using io.trino.spi.grpc.Trinomanager.Catalog.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + name_ = ""; + connector_ = ""; + internalGetMutableParams().clear(); + tenantName_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_Catalog_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.Catalog getDefaultInstanceForType() { + return io.trino.spi.grpc.Trinomanager.Catalog.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.Catalog build() { + io.trino.spi.grpc.Trinomanager.Catalog result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.Catalog buildPartial() { + io.trino.spi.grpc.Trinomanager.Catalog result = new io.trino.spi.grpc.Trinomanager.Catalog(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Trinomanager.Catalog result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.name_ = name_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.connector_ = connector_; + } + if (((from_bitField0_ & 0x00000004) != 0)) { + result.params_ = internalGetParams(); + result.params_.makeImmutable(); + } + if (((from_bitField0_ & 0x00000008) != 0)) { + result.tenantName_ = tenantName_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Trinomanager.Catalog) { + return mergeFrom((io.trino.spi.grpc.Trinomanager.Catalog)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Trinomanager.Catalog other) { + if (other == io.trino.spi.grpc.Trinomanager.Catalog.getDefaultInstance()) return this; + if (!other.getName().isEmpty()) { + name_ = other.name_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getConnector().isEmpty()) { + connector_ = other.connector_; + bitField0_ |= 0x00000002; + onChanged(); + } + internalGetMutableParams().mergeFrom( + other.internalGetParams()); + bitField0_ |= 0x00000004; + if (!other.getTenantName().isEmpty()) { + tenantName_ = other.tenantName_; + bitField0_ |= 0x00000008; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + name_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + connector_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + case 26: { + com.google.protobuf.MapEntry + params__ = input.readMessage( + ParamsDefaultEntryHolder.defaultEntry.getParserForType(), extensionRegistry); + internalGetMutableParams().getMutableMap().put( + params__.getKey(), params__.getValue()); + bitField0_ |= 0x00000004; + break; + } // case 26 + case 34: { + tenantName_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000008; + break; + } // case 34 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object name_ = ""; + /** + * string name = 1; + * @return The name. + */ + public java.lang.String getName() { + java.lang.Object ref = name_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string name = 1; + * @return The bytes for name. + */ + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string name = 1; + * @param value The name to set. + * @return This builder for chaining. + */ + public Builder setName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + name_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string name = 1; + * @return This builder for chaining. + */ + public Builder clearName() { + name_ = getDefaultInstance().getName(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string name = 1; + * @param value The bytes for name to set. + * @return This builder for chaining. + */ + public Builder setNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + name_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object connector_ = ""; + /** + * string connector = 2; + * @return The connector. + */ + public java.lang.String getConnector() { + java.lang.Object ref = connector_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + connector_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string connector = 2; + * @return The bytes for connector. + */ + public com.google.protobuf.ByteString + getConnectorBytes() { + java.lang.Object ref = connector_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + connector_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string connector = 2; + * @param value The connector to set. + * @return This builder for chaining. + */ + public Builder setConnector( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + connector_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string connector = 2; + * @return This builder for chaining. + */ + public Builder clearConnector() { + connector_ = getDefaultInstance().getConnector(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string connector = 2; + * @param value The bytes for connector to set. + * @return This builder for chaining. + */ + public Builder setConnectorBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + connector_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + + private com.google.protobuf.MapField< + java.lang.String, java.lang.String> params_; + private com.google.protobuf.MapField + internalGetParams() { + if (params_ == null) { + return com.google.protobuf.MapField.emptyMapField( + ParamsDefaultEntryHolder.defaultEntry); + } + return params_; + } + private com.google.protobuf.MapField + internalGetMutableParams() { + if (params_ == null) { + params_ = com.google.protobuf.MapField.newMapField( + ParamsDefaultEntryHolder.defaultEntry); + } + if (!params_.isMutable()) { + params_ = params_.copy(); + } + bitField0_ |= 0x00000004; + onChanged(); + return params_; + } + public int getParamsCount() { + return internalGetParams().getMap().size(); + } + /** + * map<string, string> params = 3; + */ + @java.lang.Override + public boolean containsParams( + java.lang.String key) { + if (key == null) { throw new NullPointerException("map key"); } + return internalGetParams().getMap().containsKey(key); + } + /** + * Use {@link #getParamsMap()} instead. + */ + @java.lang.Override + @java.lang.Deprecated + public java.util.Map getParams() { + return getParamsMap(); + } + /** + * map<string, string> params = 3; + */ + @java.lang.Override + public java.util.Map getParamsMap() { + return internalGetParams().getMap(); + } + /** + * map<string, string> params = 3; + */ + @java.lang.Override + public /* nullable */ +java.lang.String getParamsOrDefault( + java.lang.String key, + /* nullable */ +java.lang.String defaultValue) { + if (key == null) { throw new NullPointerException("map key"); } + java.util.Map map = + internalGetParams().getMap(); + return map.containsKey(key) ? map.get(key) : defaultValue; + } + /** + * map<string, string> params = 3; + */ + @java.lang.Override + public java.lang.String getParamsOrThrow( + java.lang.String key) { + if (key == null) { throw new NullPointerException("map key"); } + java.util.Map map = + internalGetParams().getMap(); + if (!map.containsKey(key)) { + throw new java.lang.IllegalArgumentException(); + } + return map.get(key); + } + public Builder clearParams() { + bitField0_ = (bitField0_ & ~0x00000004); + internalGetMutableParams().getMutableMap() + .clear(); + return this; + } + /** + * map<string, string> params = 3; + */ + public Builder removeParams( + java.lang.String key) { + if (key == null) { throw new NullPointerException("map key"); } + internalGetMutableParams().getMutableMap() + .remove(key); + return this; + } + /** + * Use alternate mutation accessors instead. + */ + @java.lang.Deprecated + public java.util.Map + getMutableParams() { + bitField0_ |= 0x00000004; + return internalGetMutableParams().getMutableMap(); + } + /** + * map<string, string> params = 3; + */ + public Builder putParams( + java.lang.String key, + java.lang.String value) { + if (key == null) { throw new NullPointerException("map key"); } + if (value == null) { throw new NullPointerException("map value"); } + internalGetMutableParams().getMutableMap() + .put(key, value); + bitField0_ |= 0x00000004; + return this; + } + /** + * map<string, string> params = 3; + */ + public Builder putAllParams( + java.util.Map values) { + internalGetMutableParams().getMutableMap() + .putAll(values); + bitField0_ |= 0x00000004; + return this; + } + + private java.lang.Object tenantName_ = ""; + /** + * string tenant_name = 4; + * @return The tenantName. + */ + public java.lang.String getTenantName() { + java.lang.Object ref = tenantName_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenantName_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant_name = 4; + * @return The bytes for tenantName. + */ + public com.google.protobuf.ByteString + getTenantNameBytes() { + java.lang.Object ref = tenantName_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenantName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant_name = 4; + * @param value The tenantName to set. + * @return This builder for chaining. + */ + public Builder setTenantName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenantName_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + /** + * string tenant_name = 4; + * @return This builder for chaining. + */ + public Builder clearTenantName() { + tenantName_ = getDefaultInstance().getTenantName(); + bitField0_ = (bitField0_ & ~0x00000008); + onChanged(); + return this; + } + /** + * string tenant_name = 4; + * @param value The bytes for tenantName to set. + * @return This builder for chaining. + */ + public Builder setTenantNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenantName_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.Catalog) + } + + // @@protoc_insertion_point(class_scope:grpc.Catalog) + private static final io.trino.spi.grpc.Trinomanager.Catalog DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Trinomanager.Catalog(); + } + + public static io.trino.spi.grpc.Trinomanager.Catalog getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public Catalog parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.Catalog getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface ViewOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.View) + com.google.protobuf.MessageOrBuilder { + + /** + * string name = 1; + * @return The name. + */ + java.lang.String getName(); + /** + * string name = 1; + * @return The bytes for name. + */ + com.google.protobuf.ByteString + getNameBytes(); + + /** + * string sql_query = 2; + * @return The sqlQuery. + */ + java.lang.String getSqlQuery(); + /** + * string sql_query = 2; + * @return The bytes for sqlQuery. + */ + com.google.protobuf.ByteString + getSqlQueryBytes(); + + /** + * string schema = 3; + * @return The schema. + */ + java.lang.String getSchema(); + /** + * string schema = 3; + * @return The bytes for schema. + */ + com.google.protobuf.ByteString + getSchemaBytes(); + + /** + *
+     * hash of the sql_query field, used for caching already created views
+     * 
+ * + * uint64 query_hash = 4; + * @return The queryHash. + */ + long getQueryHash(); + + /** + * string tenant_name = 5; + * @return The tenantName. + */ + java.lang.String getTenantName(); + /** + * string tenant_name = 5; + * @return The bytes for tenantName. + */ + com.google.protobuf.ByteString + getTenantNameBytes(); + + /** + * string catalog_name = 6; + * @return The catalogName. + */ + java.lang.String getCatalogName(); + /** + * string catalog_name = 6; + * @return The bytes for catalogName. + */ + com.google.protobuf.ByteString + getCatalogNameBytes(); + } + /** + * Protobuf type {@code grpc.View} + */ + public static final class View extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.View) + ViewOrBuilder { + private static final long serialVersionUID = 0L; + // Use View.newBuilder() to construct. + private View(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private View() { + name_ = ""; + sqlQuery_ = ""; + schema_ = ""; + tenantName_ = ""; + catalogName_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new View(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_View_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_View_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.View.class, io.trino.spi.grpc.Trinomanager.View.Builder.class); + } + + public static final int NAME_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object name_ = ""; + /** + * string name = 1; + * @return The name. + */ + @java.lang.Override + public java.lang.String getName() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } + } + /** + * string name = 1; + * @return The bytes for name. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int SQL_QUERY_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object sqlQuery_ = ""; + /** + * string sql_query = 2; + * @return The sqlQuery. + */ + @java.lang.Override + public java.lang.String getSqlQuery() { + java.lang.Object ref = sqlQuery_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + sqlQuery_ = s; + return s; + } + } + /** + * string sql_query = 2; + * @return The bytes for sqlQuery. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getSqlQueryBytes() { + java.lang.Object ref = sqlQuery_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + sqlQuery_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int SCHEMA_FIELD_NUMBER = 3; + @SuppressWarnings("serial") + private volatile java.lang.Object schema_ = ""; + /** + * string schema = 3; + * @return The schema. + */ + @java.lang.Override + public java.lang.String getSchema() { + java.lang.Object ref = schema_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + schema_ = s; + return s; + } + } + /** + * string schema = 3; + * @return The bytes for schema. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getSchemaBytes() { + java.lang.Object ref = schema_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + schema_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int QUERY_HASH_FIELD_NUMBER = 4; + private long queryHash_ = 0L; + /** + *
+     * hash of the sql_query field, used for caching already created views
+     * 
+ * + * uint64 query_hash = 4; + * @return The queryHash. + */ + @java.lang.Override + public long getQueryHash() { + return queryHash_; + } + + public static final int TENANT_NAME_FIELD_NUMBER = 5; + @SuppressWarnings("serial") + private volatile java.lang.Object tenantName_ = ""; + /** + * string tenant_name = 5; + * @return The tenantName. + */ + @java.lang.Override + public java.lang.String getTenantName() { + java.lang.Object ref = tenantName_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenantName_ = s; + return s; + } + } + /** + * string tenant_name = 5; + * @return The bytes for tenantName. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantNameBytes() { + java.lang.Object ref = tenantName_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenantName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int CATALOG_NAME_FIELD_NUMBER = 6; + @SuppressWarnings("serial") + private volatile java.lang.Object catalogName_ = ""; + /** + * string catalog_name = 6; + * @return The catalogName. + */ + @java.lang.Override + public java.lang.String getCatalogName() { + java.lang.Object ref = catalogName_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + catalogName_ = s; + return s; + } + } + /** + * string catalog_name = 6; + * @return The bytes for catalogName. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getCatalogNameBytes() { + java.lang.Object ref = catalogName_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + catalogName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(name_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, name_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(sqlQuery_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, sqlQuery_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(schema_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 3, schema_); + } + if (queryHash_ != 0L) { + output.writeUInt64(4, queryHash_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenantName_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 5, tenantName_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(catalogName_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 6, catalogName_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(name_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, name_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(sqlQuery_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, sqlQuery_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(schema_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(3, schema_); + } + if (queryHash_ != 0L) { + size += com.google.protobuf.CodedOutputStream + .computeUInt64Size(4, queryHash_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenantName_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(5, tenantName_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(catalogName_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(6, catalogName_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Trinomanager.View)) { + return super.equals(obj); + } + io.trino.spi.grpc.Trinomanager.View other = (io.trino.spi.grpc.Trinomanager.View) obj; + + if (!getName() + .equals(other.getName())) return false; + if (!getSqlQuery() + .equals(other.getSqlQuery())) return false; + if (!getSchema() + .equals(other.getSchema())) return false; + if (getQueryHash() + != other.getQueryHash()) return false; + if (!getTenantName() + .equals(other.getTenantName())) return false; + if (!getCatalogName() + .equals(other.getCatalogName())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + NAME_FIELD_NUMBER; + hash = (53 * hash) + getName().hashCode(); + hash = (37 * hash) + SQL_QUERY_FIELD_NUMBER; + hash = (53 * hash) + getSqlQuery().hashCode(); + hash = (37 * hash) + SCHEMA_FIELD_NUMBER; + hash = (53 * hash) + getSchema().hashCode(); + hash = (37 * hash) + QUERY_HASH_FIELD_NUMBER; + hash = (53 * hash) + com.google.protobuf.Internal.hashLong( + getQueryHash()); + hash = (37 * hash) + TENANT_NAME_FIELD_NUMBER; + hash = (53 * hash) + getTenantName().hashCode(); + hash = (37 * hash) + CATALOG_NAME_FIELD_NUMBER; + hash = (53 * hash) + getCatalogName().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Trinomanager.View parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.View parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.View parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.View parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.View parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.View parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.View parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.View parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Trinomanager.View parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Trinomanager.View parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.View parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.View parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Trinomanager.View prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.View} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.View) + io.trino.spi.grpc.Trinomanager.ViewOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_View_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_View_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.View.class, io.trino.spi.grpc.Trinomanager.View.Builder.class); + } + + // Construct using io.trino.spi.grpc.Trinomanager.View.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + name_ = ""; + sqlQuery_ = ""; + schema_ = ""; + queryHash_ = 0L; + tenantName_ = ""; + catalogName_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_View_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.View getDefaultInstanceForType() { + return io.trino.spi.grpc.Trinomanager.View.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.View build() { + io.trino.spi.grpc.Trinomanager.View result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.View buildPartial() { + io.trino.spi.grpc.Trinomanager.View result = new io.trino.spi.grpc.Trinomanager.View(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Trinomanager.View result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.name_ = name_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.sqlQuery_ = sqlQuery_; + } + if (((from_bitField0_ & 0x00000004) != 0)) { + result.schema_ = schema_; + } + if (((from_bitField0_ & 0x00000008) != 0)) { + result.queryHash_ = queryHash_; + } + if (((from_bitField0_ & 0x00000010) != 0)) { + result.tenantName_ = tenantName_; + } + if (((from_bitField0_ & 0x00000020) != 0)) { + result.catalogName_ = catalogName_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Trinomanager.View) { + return mergeFrom((io.trino.spi.grpc.Trinomanager.View)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Trinomanager.View other) { + if (other == io.trino.spi.grpc.Trinomanager.View.getDefaultInstance()) return this; + if (!other.getName().isEmpty()) { + name_ = other.name_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getSqlQuery().isEmpty()) { + sqlQuery_ = other.sqlQuery_; + bitField0_ |= 0x00000002; + onChanged(); + } + if (!other.getSchema().isEmpty()) { + schema_ = other.schema_; + bitField0_ |= 0x00000004; + onChanged(); + } + if (other.getQueryHash() != 0L) { + setQueryHash(other.getQueryHash()); + } + if (!other.getTenantName().isEmpty()) { + tenantName_ = other.tenantName_; + bitField0_ |= 0x00000010; + onChanged(); + } + if (!other.getCatalogName().isEmpty()) { + catalogName_ = other.catalogName_; + bitField0_ |= 0x00000020; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + name_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + sqlQuery_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + case 26: { + schema_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000004; + break; + } // case 26 + case 32: { + queryHash_ = input.readUInt64(); + bitField0_ |= 0x00000008; + break; + } // case 32 + case 42: { + tenantName_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000010; + break; + } // case 42 + case 50: { + catalogName_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000020; + break; + } // case 50 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object name_ = ""; + /** + * string name = 1; + * @return The name. + */ + public java.lang.String getName() { + java.lang.Object ref = name_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string name = 1; + * @return The bytes for name. + */ + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string name = 1; + * @param value The name to set. + * @return This builder for chaining. + */ + public Builder setName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + name_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string name = 1; + * @return This builder for chaining. + */ + public Builder clearName() { + name_ = getDefaultInstance().getName(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string name = 1; + * @param value The bytes for name to set. + * @return This builder for chaining. + */ + public Builder setNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + name_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object sqlQuery_ = ""; + /** + * string sql_query = 2; + * @return The sqlQuery. + */ + public java.lang.String getSqlQuery() { + java.lang.Object ref = sqlQuery_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + sqlQuery_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string sql_query = 2; + * @return The bytes for sqlQuery. + */ + public com.google.protobuf.ByteString + getSqlQueryBytes() { + java.lang.Object ref = sqlQuery_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + sqlQuery_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string sql_query = 2; + * @param value The sqlQuery to set. + * @return This builder for chaining. + */ + public Builder setSqlQuery( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + sqlQuery_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string sql_query = 2; + * @return This builder for chaining. + */ + public Builder clearSqlQuery() { + sqlQuery_ = getDefaultInstance().getSqlQuery(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string sql_query = 2; + * @param value The bytes for sqlQuery to set. + * @return This builder for chaining. + */ + public Builder setSqlQueryBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + sqlQuery_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + + private java.lang.Object schema_ = ""; + /** + * string schema = 3; + * @return The schema. + */ + public java.lang.String getSchema() { + java.lang.Object ref = schema_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + schema_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string schema = 3; + * @return The bytes for schema. + */ + public com.google.protobuf.ByteString + getSchemaBytes() { + java.lang.Object ref = schema_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + schema_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string schema = 3; + * @param value The schema to set. + * @return This builder for chaining. + */ + public Builder setSchema( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + schema_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + /** + * string schema = 3; + * @return This builder for chaining. + */ + public Builder clearSchema() { + schema_ = getDefaultInstance().getSchema(); + bitField0_ = (bitField0_ & ~0x00000004); + onChanged(); + return this; + } + /** + * string schema = 3; + * @param value The bytes for schema to set. + * @return This builder for chaining. + */ + public Builder setSchemaBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + schema_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + + private long queryHash_ ; + /** + *
+       * hash of the sql_query field, used for caching already created views
+       * 
+ * + * uint64 query_hash = 4; + * @return The queryHash. + */ + @java.lang.Override + public long getQueryHash() { + return queryHash_; + } + /** + *
+       * hash of the sql_query field, used for caching already created views
+       * 
+ * + * uint64 query_hash = 4; + * @param value The queryHash to set. + * @return This builder for chaining. + */ + public Builder setQueryHash(long value) { + + queryHash_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + /** + *
+       * hash of the sql_query field, used for caching already created views
+       * 
+ * + * uint64 query_hash = 4; + * @return This builder for chaining. + */ + public Builder clearQueryHash() { + bitField0_ = (bitField0_ & ~0x00000008); + queryHash_ = 0L; + onChanged(); + return this; + } + + private java.lang.Object tenantName_ = ""; + /** + * string tenant_name = 5; + * @return The tenantName. + */ + public java.lang.String getTenantName() { + java.lang.Object ref = tenantName_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenantName_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant_name = 5; + * @return The bytes for tenantName. + */ + public com.google.protobuf.ByteString + getTenantNameBytes() { + java.lang.Object ref = tenantName_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenantName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant_name = 5; + * @param value The tenantName to set. + * @return This builder for chaining. + */ + public Builder setTenantName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenantName_ = value; + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + /** + * string tenant_name = 5; + * @return This builder for chaining. + */ + public Builder clearTenantName() { + tenantName_ = getDefaultInstance().getTenantName(); + bitField0_ = (bitField0_ & ~0x00000010); + onChanged(); + return this; + } + /** + * string tenant_name = 5; + * @param value The bytes for tenantName to set. + * @return This builder for chaining. + */ + public Builder setTenantNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenantName_ = value; + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + + private java.lang.Object catalogName_ = ""; + /** + * string catalog_name = 6; + * @return The catalogName. + */ + public java.lang.String getCatalogName() { + java.lang.Object ref = catalogName_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + catalogName_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string catalog_name = 6; + * @return The bytes for catalogName. + */ + public com.google.protobuf.ByteString + getCatalogNameBytes() { + java.lang.Object ref = catalogName_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + catalogName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string catalog_name = 6; + * @param value The catalogName to set. + * @return This builder for chaining. + */ + public Builder setCatalogName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + catalogName_ = value; + bitField0_ |= 0x00000020; + onChanged(); + return this; + } + /** + * string catalog_name = 6; + * @return This builder for chaining. + */ + public Builder clearCatalogName() { + catalogName_ = getDefaultInstance().getCatalogName(); + bitField0_ = (bitField0_ & ~0x00000020); + onChanged(); + return this; + } + /** + * string catalog_name = 6; + * @param value The bytes for catalogName to set. + * @return This builder for chaining. + */ + public Builder setCatalogNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + catalogName_ = value; + bitField0_ |= 0x00000020; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.View) + } + + // @@protoc_insertion_point(class_scope:grpc.View) + private static final io.trino.spi.grpc.Trinomanager.View DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Trinomanager.View(); + } + + public static io.trino.spi.grpc.Trinomanager.View getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public View parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.View getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface SQLColumnOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.SQLColumn) + com.google.protobuf.MessageOrBuilder { + + /** + * string name = 1; + * @return The name. + */ + java.lang.String getName(); + /** + * string name = 1; + * @return The bytes for name. + */ + com.google.protobuf.ByteString + getNameBytes(); + + /** + *
+     * Data type as a string (e.g., "VARCHAR", "INTEGER").
+     * 
+ * + * string type = 2; + * @return The type. + */ + java.lang.String getType(); + /** + *
+     * Data type as a string (e.g., "VARCHAR", "INTEGER").
+     * 
+ * + * string type = 2; + * @return The bytes for type. + */ + com.google.protobuf.ByteString + getTypeBytes(); + } + /** + * Protobuf type {@code grpc.SQLColumn} + */ + public static final class SQLColumn extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.SQLColumn) + SQLColumnOrBuilder { + private static final long serialVersionUID = 0L; + // Use SQLColumn.newBuilder() to construct. + private SQLColumn(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private SQLColumn() { + name_ = ""; + type_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new SQLColumn(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_SQLColumn_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_SQLColumn_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.SQLColumn.class, io.trino.spi.grpc.Trinomanager.SQLColumn.Builder.class); + } + + public static final int NAME_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object name_ = ""; + /** + * string name = 1; + * @return The name. + */ + @java.lang.Override + public java.lang.String getName() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } + } + /** + * string name = 1; + * @return The bytes for name. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int TYPE_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object type_ = ""; + /** + *
+     * Data type as a string (e.g., "VARCHAR", "INTEGER").
+     * 
+ * + * string type = 2; + * @return The type. + */ + @java.lang.Override + public java.lang.String getType() { + java.lang.Object ref = type_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + type_ = s; + return s; + } + } + /** + *
+     * Data type as a string (e.g., "VARCHAR", "INTEGER").
+     * 
+ * + * string type = 2; + * @return The bytes for type. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTypeBytes() { + java.lang.Object ref = type_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + type_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(name_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, name_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(type_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, type_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(name_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, name_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(type_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, type_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Trinomanager.SQLColumn)) { + return super.equals(obj); + } + io.trino.spi.grpc.Trinomanager.SQLColumn other = (io.trino.spi.grpc.Trinomanager.SQLColumn) obj; + + if (!getName() + .equals(other.getName())) return false; + if (!getType() + .equals(other.getType())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + NAME_FIELD_NUMBER; + hash = (53 * hash) + getName().hashCode(); + hash = (37 * hash) + TYPE_FIELD_NUMBER; + hash = (53 * hash) + getType().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Trinomanager.SQLColumn parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.SQLColumn parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.SQLColumn parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.SQLColumn parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.SQLColumn parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.SQLColumn parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.SQLColumn parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.SQLColumn parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Trinomanager.SQLColumn parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Trinomanager.SQLColumn parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.SQLColumn parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.SQLColumn parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Trinomanager.SQLColumn prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.SQLColumn} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.SQLColumn) + io.trino.spi.grpc.Trinomanager.SQLColumnOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_SQLColumn_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_SQLColumn_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.SQLColumn.class, io.trino.spi.grpc.Trinomanager.SQLColumn.Builder.class); + } + + // Construct using io.trino.spi.grpc.Trinomanager.SQLColumn.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + name_ = ""; + type_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_SQLColumn_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.SQLColumn getDefaultInstanceForType() { + return io.trino.spi.grpc.Trinomanager.SQLColumn.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.SQLColumn build() { + io.trino.spi.grpc.Trinomanager.SQLColumn result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.SQLColumn buildPartial() { + io.trino.spi.grpc.Trinomanager.SQLColumn result = new io.trino.spi.grpc.Trinomanager.SQLColumn(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Trinomanager.SQLColumn result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.name_ = name_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.type_ = type_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Trinomanager.SQLColumn) { + return mergeFrom((io.trino.spi.grpc.Trinomanager.SQLColumn)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Trinomanager.SQLColumn other) { + if (other == io.trino.spi.grpc.Trinomanager.SQLColumn.getDefaultInstance()) return this; + if (!other.getName().isEmpty()) { + name_ = other.name_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getType().isEmpty()) { + type_ = other.type_; + bitField0_ |= 0x00000002; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + name_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + type_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object name_ = ""; + /** + * string name = 1; + * @return The name. + */ + public java.lang.String getName() { + java.lang.Object ref = name_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string name = 1; + * @return The bytes for name. + */ + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string name = 1; + * @param value The name to set. + * @return This builder for chaining. + */ + public Builder setName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + name_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string name = 1; + * @return This builder for chaining. + */ + public Builder clearName() { + name_ = getDefaultInstance().getName(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string name = 1; + * @param value The bytes for name to set. + * @return This builder for chaining. + */ + public Builder setNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + name_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object type_ = ""; + /** + *
+       * Data type as a string (e.g., "VARCHAR", "INTEGER").
+       * 
+ * + * string type = 2; + * @return The type. + */ + public java.lang.String getType() { + java.lang.Object ref = type_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + type_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + *
+       * Data type as a string (e.g., "VARCHAR", "INTEGER").
+       * 
+ * + * string type = 2; + * @return The bytes for type. + */ + public com.google.protobuf.ByteString + getTypeBytes() { + java.lang.Object ref = type_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + type_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + *
+       * Data type as a string (e.g., "VARCHAR", "INTEGER").
+       * 
+ * + * string type = 2; + * @param value The type to set. + * @return This builder for chaining. + */ + public Builder setType( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + type_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + *
+       * Data type as a string (e.g., "VARCHAR", "INTEGER").
+       * 
+ * + * string type = 2; + * @return This builder for chaining. + */ + public Builder clearType() { + type_ = getDefaultInstance().getType(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + *
+       * Data type as a string (e.g., "VARCHAR", "INTEGER").
+       * 
+ * + * string type = 2; + * @param value The bytes for type to set. + * @return This builder for chaining. + */ + public Builder setTypeBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + type_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.SQLColumn) + } + + // @@protoc_insertion_point(class_scope:grpc.SQLColumn) + private static final io.trino.spi.grpc.Trinomanager.SQLColumn DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Trinomanager.SQLColumn(); + } + + public static io.trino.spi.grpc.Trinomanager.SQLColumn getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public SQLColumn parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.SQLColumn getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface SchemaOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.Schema) + com.google.protobuf.MessageOrBuilder { + + /** + * string name = 1; + * @return The name. + */ + java.lang.String getName(); + /** + * string name = 1; + * @return The bytes for name. + */ + com.google.protobuf.ByteString + getNameBytes(); + } + /** + * Protobuf type {@code grpc.Schema} + */ + public static final class Schema extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.Schema) + SchemaOrBuilder { + private static final long serialVersionUID = 0L; + // Use Schema.newBuilder() to construct. + private Schema(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private Schema() { + name_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new Schema(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_Schema_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_Schema_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.Schema.class, io.trino.spi.grpc.Trinomanager.Schema.Builder.class); + } + + public static final int NAME_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object name_ = ""; + /** + * string name = 1; + * @return The name. + */ + @java.lang.Override + public java.lang.String getName() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } + } + /** + * string name = 1; + * @return The bytes for name. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(name_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, name_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(name_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, name_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Trinomanager.Schema)) { + return super.equals(obj); + } + io.trino.spi.grpc.Trinomanager.Schema other = (io.trino.spi.grpc.Trinomanager.Schema) obj; + + if (!getName() + .equals(other.getName())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + NAME_FIELD_NUMBER; + hash = (53 * hash) + getName().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Trinomanager.Schema parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.Schema parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.Schema parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.Schema parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.Schema parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.Schema parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.Schema parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.Schema parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Trinomanager.Schema parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Trinomanager.Schema parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.Schema parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.Schema parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Trinomanager.Schema prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.Schema} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.Schema) + io.trino.spi.grpc.Trinomanager.SchemaOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_Schema_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_Schema_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.Schema.class, io.trino.spi.grpc.Trinomanager.Schema.Builder.class); + } + + // Construct using io.trino.spi.grpc.Trinomanager.Schema.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + name_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_Schema_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.Schema getDefaultInstanceForType() { + return io.trino.spi.grpc.Trinomanager.Schema.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.Schema build() { + io.trino.spi.grpc.Trinomanager.Schema result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.Schema buildPartial() { + io.trino.spi.grpc.Trinomanager.Schema result = new io.trino.spi.grpc.Trinomanager.Schema(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Trinomanager.Schema result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.name_ = name_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Trinomanager.Schema) { + return mergeFrom((io.trino.spi.grpc.Trinomanager.Schema)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Trinomanager.Schema other) { + if (other == io.trino.spi.grpc.Trinomanager.Schema.getDefaultInstance()) return this; + if (!other.getName().isEmpty()) { + name_ = other.name_; + bitField0_ |= 0x00000001; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + name_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object name_ = ""; + /** + * string name = 1; + * @return The name. + */ + public java.lang.String getName() { + java.lang.Object ref = name_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string name = 1; + * @return The bytes for name. + */ + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string name = 1; + * @param value The name to set. + * @return This builder for chaining. + */ + public Builder setName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + name_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string name = 1; + * @return This builder for chaining. + */ + public Builder clearName() { + name_ = getDefaultInstance().getName(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string name = 1; + * @param value The bytes for name to set. + * @return This builder for chaining. + */ + public Builder setNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + name_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.Schema) + } + + // @@protoc_insertion_point(class_scope:grpc.Schema) + private static final io.trino.spi.grpc.Trinomanager.Schema DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Trinomanager.Schema(); + } + + public static io.trino.spi.grpc.Trinomanager.Schema getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public Schema parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.Schema getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface NotebookCellOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.NotebookCell) + com.google.protobuf.MessageOrBuilder { + + /** + * string tenant = 1; + * @return The tenant. + */ + java.lang.String getTenant(); + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + com.google.protobuf.ByteString + getTenantBytes(); + + /** + * string id = 2; + * @return The id. + */ + java.lang.String getId(); + /** + * string id = 2; + * @return The bytes for id. + */ + com.google.protobuf.ByteString + getIdBytes(); + + /** + * int64 created_at = 3; + * @return The createdAt. + */ + long getCreatedAt(); + + /** + * int64 updated_at = 4; + * @return The updatedAt. + */ + long getUpdatedAt(); + + /** + * string name = 5; + * @return The name. + */ + java.lang.String getName(); + /** + * string name = 5; + * @return The bytes for name. + */ + com.google.protobuf.ByteString + getNameBytes(); + + /** + * string sql_query = 6; + * @return The sqlQuery. + */ + java.lang.String getSqlQuery(); + /** + * string sql_query = 6; + * @return The bytes for sqlQuery. + */ + com.google.protobuf.ByteString + getSqlQueryBytes(); + + /** + * optional int32 order = 7; + * @return Whether the order field is set. + */ + boolean hasOrder(); + /** + * optional int32 order = 7; + * @return The order. + */ + int getOrder(); + + /** + * optional .grpc.NotebookMetadata notebook = 8; + * @return Whether the notebook field is set. + */ + boolean hasNotebook(); + /** + * optional .grpc.NotebookMetadata notebook = 8; + * @return The notebook. + */ + io.trino.spi.grpc.Trinomanager.NotebookMetadata getNotebook(); + /** + * optional .grpc.NotebookMetadata notebook = 8; + */ + io.trino.spi.grpc.Trinomanager.NotebookMetadataOrBuilder getNotebookOrBuilder(); + + /** + * optional string last_executed_trino_qeury_id = 9; + * @return Whether the lastExecutedTrinoQeuryId field is set. + */ + boolean hasLastExecutedTrinoQeuryId(); + /** + * optional string last_executed_trino_qeury_id = 9; + * @return The lastExecutedTrinoQeuryId. + */ + java.lang.String getLastExecutedTrinoQeuryId(); + /** + * optional string last_executed_trino_qeury_id = 9; + * @return The bytes for lastExecutedTrinoQeuryId. + */ + com.google.protobuf.ByteString + getLastExecutedTrinoQeuryIdBytes(); + + /** + * optional string last_execution_state = 10; + * @return Whether the lastExecutionState field is set. + */ + boolean hasLastExecutionState(); + /** + * optional string last_execution_state = 10; + * @return The lastExecutionState. + */ + java.lang.String getLastExecutionState(); + /** + * optional string last_execution_state = 10; + * @return The bytes for lastExecutionState. + */ + com.google.protobuf.ByteString + getLastExecutionStateBytes(); + + /** + * optional string last_execution_error = 11; + * @return Whether the lastExecutionError field is set. + */ + boolean hasLastExecutionError(); + /** + * optional string last_execution_error = 11; + * @return The lastExecutionError. + */ + java.lang.String getLastExecutionError(); + /** + * optional string last_execution_error = 11; + * @return The bytes for lastExecutionError. + */ + com.google.protobuf.ByteString + getLastExecutionErrorBytes(); + + /** + * optional int64 last_executed_at = 12; + * @return Whether the lastExecutedAt field is set. + */ + boolean hasLastExecutedAt(); + /** + * optional int64 last_executed_at = 12; + * @return The lastExecutedAt. + */ + long getLastExecutedAt(); + + /** + * optional .grpc.NotebookCellCellConfig cellConfig = 13; + * @return Whether the cellConfig field is set. + */ + boolean hasCellConfig(); + /** + * optional .grpc.NotebookCellCellConfig cellConfig = 13; + * @return The cellConfig. + */ + io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig getCellConfig(); + /** + * optional .grpc.NotebookCellCellConfig cellConfig = 13; + */ + io.trino.spi.grpc.Trinomanager.NotebookCellCellConfigOrBuilder getCellConfigOrBuilder(); + + /** + * string sql_query_expanded = 14; + * @return The sqlQueryExpanded. + */ + java.lang.String getSqlQueryExpanded(); + /** + * string sql_query_expanded = 14; + * @return The bytes for sqlQueryExpanded. + */ + com.google.protobuf.ByteString + getSqlQueryExpandedBytes(); + } + /** + * Protobuf type {@code grpc.NotebookCell} + */ + public static final class NotebookCell extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.NotebookCell) + NotebookCellOrBuilder { + private static final long serialVersionUID = 0L; + // Use NotebookCell.newBuilder() to construct. + private NotebookCell(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private NotebookCell() { + tenant_ = ""; + id_ = ""; + name_ = ""; + sqlQuery_ = ""; + lastExecutedTrinoQeuryId_ = ""; + lastExecutionState_ = ""; + lastExecutionError_ = ""; + sqlQueryExpanded_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new NotebookCell(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_NotebookCell_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_NotebookCell_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.NotebookCell.class, io.trino.spi.grpc.Trinomanager.NotebookCell.Builder.class); + } + + private int bitField0_; + public static final int TENANT_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + @java.lang.Override + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int ID_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object id_ = ""; + /** + * string id = 2; + * @return The id. + */ + @java.lang.Override + public java.lang.String getId() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } + } + /** + * string id = 2; + * @return The bytes for id. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int CREATED_AT_FIELD_NUMBER = 3; + private long createdAt_ = 0L; + /** + * int64 created_at = 3; + * @return The createdAt. + */ + @java.lang.Override + public long getCreatedAt() { + return createdAt_; + } + + public static final int UPDATED_AT_FIELD_NUMBER = 4; + private long updatedAt_ = 0L; + /** + * int64 updated_at = 4; + * @return The updatedAt. + */ + @java.lang.Override + public long getUpdatedAt() { + return updatedAt_; + } + + public static final int NAME_FIELD_NUMBER = 5; + @SuppressWarnings("serial") + private volatile java.lang.Object name_ = ""; + /** + * string name = 5; + * @return The name. + */ + @java.lang.Override + public java.lang.String getName() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } + } + /** + * string name = 5; + * @return The bytes for name. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int SQL_QUERY_FIELD_NUMBER = 6; + @SuppressWarnings("serial") + private volatile java.lang.Object sqlQuery_ = ""; + /** + * string sql_query = 6; + * @return The sqlQuery. + */ + @java.lang.Override + public java.lang.String getSqlQuery() { + java.lang.Object ref = sqlQuery_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + sqlQuery_ = s; + return s; + } + } + /** + * string sql_query = 6; + * @return The bytes for sqlQuery. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getSqlQueryBytes() { + java.lang.Object ref = sqlQuery_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + sqlQuery_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int ORDER_FIELD_NUMBER = 7; + private int order_ = 0; + /** + * optional int32 order = 7; + * @return Whether the order field is set. + */ + @java.lang.Override + public boolean hasOrder() { + return ((bitField0_ & 0x00000001) != 0); + } + /** + * optional int32 order = 7; + * @return The order. + */ + @java.lang.Override + public int getOrder() { + return order_; + } + + public static final int NOTEBOOK_FIELD_NUMBER = 8; + private io.trino.spi.grpc.Trinomanager.NotebookMetadata notebook_; + /** + * optional .grpc.NotebookMetadata notebook = 8; + * @return Whether the notebook field is set. + */ + @java.lang.Override + public boolean hasNotebook() { + return ((bitField0_ & 0x00000002) != 0); + } + /** + * optional .grpc.NotebookMetadata notebook = 8; + * @return The notebook. + */ + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.NotebookMetadata getNotebook() { + return notebook_ == null ? io.trino.spi.grpc.Trinomanager.NotebookMetadata.getDefaultInstance() : notebook_; + } + /** + * optional .grpc.NotebookMetadata notebook = 8; + */ + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.NotebookMetadataOrBuilder getNotebookOrBuilder() { + return notebook_ == null ? io.trino.spi.grpc.Trinomanager.NotebookMetadata.getDefaultInstance() : notebook_; + } + + public static final int LAST_EXECUTED_TRINO_QEURY_ID_FIELD_NUMBER = 9; + @SuppressWarnings("serial") + private volatile java.lang.Object lastExecutedTrinoQeuryId_ = ""; + /** + * optional string last_executed_trino_qeury_id = 9; + * @return Whether the lastExecutedTrinoQeuryId field is set. + */ + @java.lang.Override + public boolean hasLastExecutedTrinoQeuryId() { + return ((bitField0_ & 0x00000004) != 0); + } + /** + * optional string last_executed_trino_qeury_id = 9; + * @return The lastExecutedTrinoQeuryId. + */ + @java.lang.Override + public java.lang.String getLastExecutedTrinoQeuryId() { + java.lang.Object ref = lastExecutedTrinoQeuryId_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + lastExecutedTrinoQeuryId_ = s; + return s; + } + } + /** + * optional string last_executed_trino_qeury_id = 9; + * @return The bytes for lastExecutedTrinoQeuryId. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getLastExecutedTrinoQeuryIdBytes() { + java.lang.Object ref = lastExecutedTrinoQeuryId_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + lastExecutedTrinoQeuryId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int LAST_EXECUTION_STATE_FIELD_NUMBER = 10; + @SuppressWarnings("serial") + private volatile java.lang.Object lastExecutionState_ = ""; + /** + * optional string last_execution_state = 10; + * @return Whether the lastExecutionState field is set. + */ + @java.lang.Override + public boolean hasLastExecutionState() { + return ((bitField0_ & 0x00000008) != 0); + } + /** + * optional string last_execution_state = 10; + * @return The lastExecutionState. + */ + @java.lang.Override + public java.lang.String getLastExecutionState() { + java.lang.Object ref = lastExecutionState_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + lastExecutionState_ = s; + return s; + } + } + /** + * optional string last_execution_state = 10; + * @return The bytes for lastExecutionState. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getLastExecutionStateBytes() { + java.lang.Object ref = lastExecutionState_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + lastExecutionState_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int LAST_EXECUTION_ERROR_FIELD_NUMBER = 11; + @SuppressWarnings("serial") + private volatile java.lang.Object lastExecutionError_ = ""; + /** + * optional string last_execution_error = 11; + * @return Whether the lastExecutionError field is set. + */ + @java.lang.Override + public boolean hasLastExecutionError() { + return ((bitField0_ & 0x00000010) != 0); + } + /** + * optional string last_execution_error = 11; + * @return The lastExecutionError. + */ + @java.lang.Override + public java.lang.String getLastExecutionError() { + java.lang.Object ref = lastExecutionError_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + lastExecutionError_ = s; + return s; + } + } + /** + * optional string last_execution_error = 11; + * @return The bytes for lastExecutionError. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getLastExecutionErrorBytes() { + java.lang.Object ref = lastExecutionError_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + lastExecutionError_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int LAST_EXECUTED_AT_FIELD_NUMBER = 12; + private long lastExecutedAt_ = 0L; + /** + * optional int64 last_executed_at = 12; + * @return Whether the lastExecutedAt field is set. + */ + @java.lang.Override + public boolean hasLastExecutedAt() { + return ((bitField0_ & 0x00000020) != 0); + } + /** + * optional int64 last_executed_at = 12; + * @return The lastExecutedAt. + */ + @java.lang.Override + public long getLastExecutedAt() { + return lastExecutedAt_; + } + + public static final int CELLCONFIG_FIELD_NUMBER = 13; + private io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig cellConfig_; + /** + * optional .grpc.NotebookCellCellConfig cellConfig = 13; + * @return Whether the cellConfig field is set. + */ + @java.lang.Override + public boolean hasCellConfig() { + return ((bitField0_ & 0x00000040) != 0); + } + /** + * optional .grpc.NotebookCellCellConfig cellConfig = 13; + * @return The cellConfig. + */ + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig getCellConfig() { + return cellConfig_ == null ? io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig.getDefaultInstance() : cellConfig_; + } + /** + * optional .grpc.NotebookCellCellConfig cellConfig = 13; + */ + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.NotebookCellCellConfigOrBuilder getCellConfigOrBuilder() { + return cellConfig_ == null ? io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig.getDefaultInstance() : cellConfig_; + } + + public static final int SQL_QUERY_EXPANDED_FIELD_NUMBER = 14; + @SuppressWarnings("serial") + private volatile java.lang.Object sqlQueryExpanded_ = ""; + /** + * string sql_query_expanded = 14; + * @return The sqlQueryExpanded. + */ + @java.lang.Override + public java.lang.String getSqlQueryExpanded() { + java.lang.Object ref = sqlQueryExpanded_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + sqlQueryExpanded_ = s; + return s; + } + } + /** + * string sql_query_expanded = 14; + * @return The bytes for sqlQueryExpanded. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getSqlQueryExpandedBytes() { + java.lang.Object ref = sqlQueryExpanded_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + sqlQueryExpanded_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, id_); + } + if (createdAt_ != 0L) { + output.writeInt64(3, createdAt_); + } + if (updatedAt_ != 0L) { + output.writeInt64(4, updatedAt_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(name_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 5, name_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(sqlQuery_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 6, sqlQuery_); + } + if (((bitField0_ & 0x00000001) != 0)) { + output.writeInt32(7, order_); + } + if (((bitField0_ & 0x00000002) != 0)) { + output.writeMessage(8, getNotebook()); + } + if (((bitField0_ & 0x00000004) != 0)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 9, lastExecutedTrinoQeuryId_); + } + if (((bitField0_ & 0x00000008) != 0)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 10, lastExecutionState_); + } + if (((bitField0_ & 0x00000010) != 0)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 11, lastExecutionError_); + } + if (((bitField0_ & 0x00000020) != 0)) { + output.writeInt64(12, lastExecutedAt_); + } + if (((bitField0_ & 0x00000040) != 0)) { + output.writeMessage(13, getCellConfig()); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(sqlQueryExpanded_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 14, sqlQueryExpanded_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, id_); + } + if (createdAt_ != 0L) { + size += com.google.protobuf.CodedOutputStream + .computeInt64Size(3, createdAt_); + } + if (updatedAt_ != 0L) { + size += com.google.protobuf.CodedOutputStream + .computeInt64Size(4, updatedAt_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(name_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(5, name_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(sqlQuery_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(6, sqlQuery_); + } + if (((bitField0_ & 0x00000001) != 0)) { + size += com.google.protobuf.CodedOutputStream + .computeInt32Size(7, order_); + } + if (((bitField0_ & 0x00000002) != 0)) { + size += com.google.protobuf.CodedOutputStream + .computeMessageSize(8, getNotebook()); + } + if (((bitField0_ & 0x00000004) != 0)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(9, lastExecutedTrinoQeuryId_); + } + if (((bitField0_ & 0x00000008) != 0)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(10, lastExecutionState_); + } + if (((bitField0_ & 0x00000010) != 0)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(11, lastExecutionError_); + } + if (((bitField0_ & 0x00000020) != 0)) { + size += com.google.protobuf.CodedOutputStream + .computeInt64Size(12, lastExecutedAt_); + } + if (((bitField0_ & 0x00000040) != 0)) { + size += com.google.protobuf.CodedOutputStream + .computeMessageSize(13, getCellConfig()); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(sqlQueryExpanded_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(14, sqlQueryExpanded_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Trinomanager.NotebookCell)) { + return super.equals(obj); + } + io.trino.spi.grpc.Trinomanager.NotebookCell other = (io.trino.spi.grpc.Trinomanager.NotebookCell) obj; + + if (!getTenant() + .equals(other.getTenant())) return false; + if (!getId() + .equals(other.getId())) return false; + if (getCreatedAt() + != other.getCreatedAt()) return false; + if (getUpdatedAt() + != other.getUpdatedAt()) return false; + if (!getName() + .equals(other.getName())) return false; + if (!getSqlQuery() + .equals(other.getSqlQuery())) return false; + if (hasOrder() != other.hasOrder()) return false; + if (hasOrder()) { + if (getOrder() + != other.getOrder()) return false; + } + if (hasNotebook() != other.hasNotebook()) return false; + if (hasNotebook()) { + if (!getNotebook() + .equals(other.getNotebook())) return false; + } + if (hasLastExecutedTrinoQeuryId() != other.hasLastExecutedTrinoQeuryId()) return false; + if (hasLastExecutedTrinoQeuryId()) { + if (!getLastExecutedTrinoQeuryId() + .equals(other.getLastExecutedTrinoQeuryId())) return false; + } + if (hasLastExecutionState() != other.hasLastExecutionState()) return false; + if (hasLastExecutionState()) { + if (!getLastExecutionState() + .equals(other.getLastExecutionState())) return false; + } + if (hasLastExecutionError() != other.hasLastExecutionError()) return false; + if (hasLastExecutionError()) { + if (!getLastExecutionError() + .equals(other.getLastExecutionError())) return false; + } + if (hasLastExecutedAt() != other.hasLastExecutedAt()) return false; + if (hasLastExecutedAt()) { + if (getLastExecutedAt() + != other.getLastExecutedAt()) return false; + } + if (hasCellConfig() != other.hasCellConfig()) return false; + if (hasCellConfig()) { + if (!getCellConfig() + .equals(other.getCellConfig())) return false; + } + if (!getSqlQueryExpanded() + .equals(other.getSqlQueryExpanded())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + TENANT_FIELD_NUMBER; + hash = (53 * hash) + getTenant().hashCode(); + hash = (37 * hash) + ID_FIELD_NUMBER; + hash = (53 * hash) + getId().hashCode(); + hash = (37 * hash) + CREATED_AT_FIELD_NUMBER; + hash = (53 * hash) + com.google.protobuf.Internal.hashLong( + getCreatedAt()); + hash = (37 * hash) + UPDATED_AT_FIELD_NUMBER; + hash = (53 * hash) + com.google.protobuf.Internal.hashLong( + getUpdatedAt()); + hash = (37 * hash) + NAME_FIELD_NUMBER; + hash = (53 * hash) + getName().hashCode(); + hash = (37 * hash) + SQL_QUERY_FIELD_NUMBER; + hash = (53 * hash) + getSqlQuery().hashCode(); + if (hasOrder()) { + hash = (37 * hash) + ORDER_FIELD_NUMBER; + hash = (53 * hash) + getOrder(); + } + if (hasNotebook()) { + hash = (37 * hash) + NOTEBOOK_FIELD_NUMBER; + hash = (53 * hash) + getNotebook().hashCode(); + } + if (hasLastExecutedTrinoQeuryId()) { + hash = (37 * hash) + LAST_EXECUTED_TRINO_QEURY_ID_FIELD_NUMBER; + hash = (53 * hash) + getLastExecutedTrinoQeuryId().hashCode(); + } + if (hasLastExecutionState()) { + hash = (37 * hash) + LAST_EXECUTION_STATE_FIELD_NUMBER; + hash = (53 * hash) + getLastExecutionState().hashCode(); + } + if (hasLastExecutionError()) { + hash = (37 * hash) + LAST_EXECUTION_ERROR_FIELD_NUMBER; + hash = (53 * hash) + getLastExecutionError().hashCode(); + } + if (hasLastExecutedAt()) { + hash = (37 * hash) + LAST_EXECUTED_AT_FIELD_NUMBER; + hash = (53 * hash) + com.google.protobuf.Internal.hashLong( + getLastExecutedAt()); + } + if (hasCellConfig()) { + hash = (37 * hash) + CELLCONFIG_FIELD_NUMBER; + hash = (53 * hash) + getCellConfig().hashCode(); + } + hash = (37 * hash) + SQL_QUERY_EXPANDED_FIELD_NUMBER; + hash = (53 * hash) + getSqlQueryExpanded().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Trinomanager.NotebookCell parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.NotebookCell parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.NotebookCell parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.NotebookCell parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.NotebookCell parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.NotebookCell parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.NotebookCell parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.NotebookCell parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Trinomanager.NotebookCell parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Trinomanager.NotebookCell parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.NotebookCell parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.NotebookCell parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Trinomanager.NotebookCell prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.NotebookCell} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.NotebookCell) + io.trino.spi.grpc.Trinomanager.NotebookCellOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_NotebookCell_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_NotebookCell_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.NotebookCell.class, io.trino.spi.grpc.Trinomanager.NotebookCell.Builder.class); + } + + // Construct using io.trino.spi.grpc.Trinomanager.NotebookCell.newBuilder() + private Builder() { + maybeForceBuilderInitialization(); + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + maybeForceBuilderInitialization(); + } + private void maybeForceBuilderInitialization() { + if (com.google.protobuf.GeneratedMessageV3 + .alwaysUseFieldBuilders) { + getNotebookFieldBuilder(); + getCellConfigFieldBuilder(); + } + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + tenant_ = ""; + id_ = ""; + createdAt_ = 0L; + updatedAt_ = 0L; + name_ = ""; + sqlQuery_ = ""; + order_ = 0; + notebook_ = null; + if (notebookBuilder_ != null) { + notebookBuilder_.dispose(); + notebookBuilder_ = null; + } + lastExecutedTrinoQeuryId_ = ""; + lastExecutionState_ = ""; + lastExecutionError_ = ""; + lastExecutedAt_ = 0L; + cellConfig_ = null; + if (cellConfigBuilder_ != null) { + cellConfigBuilder_.dispose(); + cellConfigBuilder_ = null; + } + sqlQueryExpanded_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_NotebookCell_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.NotebookCell getDefaultInstanceForType() { + return io.trino.spi.grpc.Trinomanager.NotebookCell.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.NotebookCell build() { + io.trino.spi.grpc.Trinomanager.NotebookCell result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.NotebookCell buildPartial() { + io.trino.spi.grpc.Trinomanager.NotebookCell result = new io.trino.spi.grpc.Trinomanager.NotebookCell(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Trinomanager.NotebookCell result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.tenant_ = tenant_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.id_ = id_; + } + if (((from_bitField0_ & 0x00000004) != 0)) { + result.createdAt_ = createdAt_; + } + if (((from_bitField0_ & 0x00000008) != 0)) { + result.updatedAt_ = updatedAt_; + } + if (((from_bitField0_ & 0x00000010) != 0)) { + result.name_ = name_; + } + if (((from_bitField0_ & 0x00000020) != 0)) { + result.sqlQuery_ = sqlQuery_; + } + int to_bitField0_ = 0; + if (((from_bitField0_ & 0x00000040) != 0)) { + result.order_ = order_; + to_bitField0_ |= 0x00000001; + } + if (((from_bitField0_ & 0x00000080) != 0)) { + result.notebook_ = notebookBuilder_ == null + ? notebook_ + : notebookBuilder_.build(); + to_bitField0_ |= 0x00000002; + } + if (((from_bitField0_ & 0x00000100) != 0)) { + result.lastExecutedTrinoQeuryId_ = lastExecutedTrinoQeuryId_; + to_bitField0_ |= 0x00000004; + } + if (((from_bitField0_ & 0x00000200) != 0)) { + result.lastExecutionState_ = lastExecutionState_; + to_bitField0_ |= 0x00000008; + } + if (((from_bitField0_ & 0x00000400) != 0)) { + result.lastExecutionError_ = lastExecutionError_; + to_bitField0_ |= 0x00000010; + } + if (((from_bitField0_ & 0x00000800) != 0)) { + result.lastExecutedAt_ = lastExecutedAt_; + to_bitField0_ |= 0x00000020; + } + if (((from_bitField0_ & 0x00001000) != 0)) { + result.cellConfig_ = cellConfigBuilder_ == null + ? cellConfig_ + : cellConfigBuilder_.build(); + to_bitField0_ |= 0x00000040; + } + if (((from_bitField0_ & 0x00002000) != 0)) { + result.sqlQueryExpanded_ = sqlQueryExpanded_; + } + result.bitField0_ |= to_bitField0_; + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Trinomanager.NotebookCell) { + return mergeFrom((io.trino.spi.grpc.Trinomanager.NotebookCell)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Trinomanager.NotebookCell other) { + if (other == io.trino.spi.grpc.Trinomanager.NotebookCell.getDefaultInstance()) return this; + if (!other.getTenant().isEmpty()) { + tenant_ = other.tenant_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getId().isEmpty()) { + id_ = other.id_; + bitField0_ |= 0x00000002; + onChanged(); + } + if (other.getCreatedAt() != 0L) { + setCreatedAt(other.getCreatedAt()); + } + if (other.getUpdatedAt() != 0L) { + setUpdatedAt(other.getUpdatedAt()); + } + if (!other.getName().isEmpty()) { + name_ = other.name_; + bitField0_ |= 0x00000010; + onChanged(); + } + if (!other.getSqlQuery().isEmpty()) { + sqlQuery_ = other.sqlQuery_; + bitField0_ |= 0x00000020; + onChanged(); + } + if (other.hasOrder()) { + setOrder(other.getOrder()); + } + if (other.hasNotebook()) { + mergeNotebook(other.getNotebook()); + } + if (other.hasLastExecutedTrinoQeuryId()) { + lastExecutedTrinoQeuryId_ = other.lastExecutedTrinoQeuryId_; + bitField0_ |= 0x00000100; + onChanged(); + } + if (other.hasLastExecutionState()) { + lastExecutionState_ = other.lastExecutionState_; + bitField0_ |= 0x00000200; + onChanged(); + } + if (other.hasLastExecutionError()) { + lastExecutionError_ = other.lastExecutionError_; + bitField0_ |= 0x00000400; + onChanged(); + } + if (other.hasLastExecutedAt()) { + setLastExecutedAt(other.getLastExecutedAt()); + } + if (other.hasCellConfig()) { + mergeCellConfig(other.getCellConfig()); + } + if (!other.getSqlQueryExpanded().isEmpty()) { + sqlQueryExpanded_ = other.sqlQueryExpanded_; + bitField0_ |= 0x00002000; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + tenant_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + id_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + case 24: { + createdAt_ = input.readInt64(); + bitField0_ |= 0x00000004; + break; + } // case 24 + case 32: { + updatedAt_ = input.readInt64(); + bitField0_ |= 0x00000008; + break; + } // case 32 + case 42: { + name_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000010; + break; + } // case 42 + case 50: { + sqlQuery_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000020; + break; + } // case 50 + case 56: { + order_ = input.readInt32(); + bitField0_ |= 0x00000040; + break; + } // case 56 + case 66: { + input.readMessage( + getNotebookFieldBuilder().getBuilder(), + extensionRegistry); + bitField0_ |= 0x00000080; + break; + } // case 66 + case 74: { + lastExecutedTrinoQeuryId_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000100; + break; + } // case 74 + case 82: { + lastExecutionState_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000200; + break; + } // case 82 + case 90: { + lastExecutionError_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000400; + break; + } // case 90 + case 96: { + lastExecutedAt_ = input.readInt64(); + bitField0_ |= 0x00000800; + break; + } // case 96 + case 106: { + input.readMessage( + getCellConfigFieldBuilder().getBuilder(), + extensionRegistry); + bitField0_ |= 0x00001000; + break; + } // case 106 + case 114: { + sqlQueryExpanded_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00002000; + break; + } // case 114 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant = 1; + * @param value The tenant to set. + * @return This builder for chaining. + */ + public Builder setTenant( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string tenant = 1; + * @return This builder for chaining. + */ + public Builder clearTenant() { + tenant_ = getDefaultInstance().getTenant(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string tenant = 1; + * @param value The bytes for tenant to set. + * @return This builder for chaining. + */ + public Builder setTenantBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object id_ = ""; + /** + * string id = 2; + * @return The id. + */ + public java.lang.String getId() { + java.lang.Object ref = id_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string id = 2; + * @return The bytes for id. + */ + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string id = 2; + * @param value The id to set. + * @return This builder for chaining. + */ + public Builder setId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + id_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string id = 2; + * @return This builder for chaining. + */ + public Builder clearId() { + id_ = getDefaultInstance().getId(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string id = 2; + * @param value The bytes for id to set. + * @return This builder for chaining. + */ + public Builder setIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + id_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + + private long createdAt_ ; + /** + * int64 created_at = 3; + * @return The createdAt. + */ + @java.lang.Override + public long getCreatedAt() { + return createdAt_; + } + /** + * int64 created_at = 3; + * @param value The createdAt to set. + * @return This builder for chaining. + */ + public Builder setCreatedAt(long value) { + + createdAt_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + /** + * int64 created_at = 3; + * @return This builder for chaining. + */ + public Builder clearCreatedAt() { + bitField0_ = (bitField0_ & ~0x00000004); + createdAt_ = 0L; + onChanged(); + return this; + } + + private long updatedAt_ ; + /** + * int64 updated_at = 4; + * @return The updatedAt. + */ + @java.lang.Override + public long getUpdatedAt() { + return updatedAt_; + } + /** + * int64 updated_at = 4; + * @param value The updatedAt to set. + * @return This builder for chaining. + */ + public Builder setUpdatedAt(long value) { + + updatedAt_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + /** + * int64 updated_at = 4; + * @return This builder for chaining. + */ + public Builder clearUpdatedAt() { + bitField0_ = (bitField0_ & ~0x00000008); + updatedAt_ = 0L; + onChanged(); + return this; + } + + private java.lang.Object name_ = ""; + /** + * string name = 5; + * @return The name. + */ + public java.lang.String getName() { + java.lang.Object ref = name_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string name = 5; + * @return The bytes for name. + */ + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string name = 5; + * @param value The name to set. + * @return This builder for chaining. + */ + public Builder setName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + name_ = value; + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + /** + * string name = 5; + * @return This builder for chaining. + */ + public Builder clearName() { + name_ = getDefaultInstance().getName(); + bitField0_ = (bitField0_ & ~0x00000010); + onChanged(); + return this; + } + /** + * string name = 5; + * @param value The bytes for name to set. + * @return This builder for chaining. + */ + public Builder setNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + name_ = value; + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + + private java.lang.Object sqlQuery_ = ""; + /** + * string sql_query = 6; + * @return The sqlQuery. + */ + public java.lang.String getSqlQuery() { + java.lang.Object ref = sqlQuery_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + sqlQuery_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string sql_query = 6; + * @return The bytes for sqlQuery. + */ + public com.google.protobuf.ByteString + getSqlQueryBytes() { + java.lang.Object ref = sqlQuery_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + sqlQuery_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string sql_query = 6; + * @param value The sqlQuery to set. + * @return This builder for chaining. + */ + public Builder setSqlQuery( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + sqlQuery_ = value; + bitField0_ |= 0x00000020; + onChanged(); + return this; + } + /** + * string sql_query = 6; + * @return This builder for chaining. + */ + public Builder clearSqlQuery() { + sqlQuery_ = getDefaultInstance().getSqlQuery(); + bitField0_ = (bitField0_ & ~0x00000020); + onChanged(); + return this; + } + /** + * string sql_query = 6; + * @param value The bytes for sqlQuery to set. + * @return This builder for chaining. + */ + public Builder setSqlQueryBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + sqlQuery_ = value; + bitField0_ |= 0x00000020; + onChanged(); + return this; + } + + private int order_ ; + /** + * optional int32 order = 7; + * @return Whether the order field is set. + */ + @java.lang.Override + public boolean hasOrder() { + return ((bitField0_ & 0x00000040) != 0); + } + /** + * optional int32 order = 7; + * @return The order. + */ + @java.lang.Override + public int getOrder() { + return order_; + } + /** + * optional int32 order = 7; + * @param value The order to set. + * @return This builder for chaining. + */ + public Builder setOrder(int value) { + + order_ = value; + bitField0_ |= 0x00000040; + onChanged(); + return this; + } + /** + * optional int32 order = 7; + * @return This builder for chaining. + */ + public Builder clearOrder() { + bitField0_ = (bitField0_ & ~0x00000040); + order_ = 0; + onChanged(); + return this; + } + + private io.trino.spi.grpc.Trinomanager.NotebookMetadata notebook_; + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Trinomanager.NotebookMetadata, io.trino.spi.grpc.Trinomanager.NotebookMetadata.Builder, io.trino.spi.grpc.Trinomanager.NotebookMetadataOrBuilder> notebookBuilder_; + /** + * optional .grpc.NotebookMetadata notebook = 8; + * @return Whether the notebook field is set. + */ + public boolean hasNotebook() { + return ((bitField0_ & 0x00000080) != 0); + } + /** + * optional .grpc.NotebookMetadata notebook = 8; + * @return The notebook. + */ + public io.trino.spi.grpc.Trinomanager.NotebookMetadata getNotebook() { + if (notebookBuilder_ == null) { + return notebook_ == null ? io.trino.spi.grpc.Trinomanager.NotebookMetadata.getDefaultInstance() : notebook_; + } else { + return notebookBuilder_.getMessage(); + } + } + /** + * optional .grpc.NotebookMetadata notebook = 8; + */ + public Builder setNotebook(io.trino.spi.grpc.Trinomanager.NotebookMetadata value) { + if (notebookBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + notebook_ = value; + } else { + notebookBuilder_.setMessage(value); + } + bitField0_ |= 0x00000080; + onChanged(); + return this; + } + /** + * optional .grpc.NotebookMetadata notebook = 8; + */ + public Builder setNotebook( + io.trino.spi.grpc.Trinomanager.NotebookMetadata.Builder builderForValue) { + if (notebookBuilder_ == null) { + notebook_ = builderForValue.build(); + } else { + notebookBuilder_.setMessage(builderForValue.build()); + } + bitField0_ |= 0x00000080; + onChanged(); + return this; + } + /** + * optional .grpc.NotebookMetadata notebook = 8; + */ + public Builder mergeNotebook(io.trino.spi.grpc.Trinomanager.NotebookMetadata value) { + if (notebookBuilder_ == null) { + if (((bitField0_ & 0x00000080) != 0) && + notebook_ != null && + notebook_ != io.trino.spi.grpc.Trinomanager.NotebookMetadata.getDefaultInstance()) { + getNotebookBuilder().mergeFrom(value); + } else { + notebook_ = value; + } + } else { + notebookBuilder_.mergeFrom(value); + } + bitField0_ |= 0x00000080; + onChanged(); + return this; + } + /** + * optional .grpc.NotebookMetadata notebook = 8; + */ + public Builder clearNotebook() { + bitField0_ = (bitField0_ & ~0x00000080); + notebook_ = null; + if (notebookBuilder_ != null) { + notebookBuilder_.dispose(); + notebookBuilder_ = null; + } + onChanged(); + return this; + } + /** + * optional .grpc.NotebookMetadata notebook = 8; + */ + public io.trino.spi.grpc.Trinomanager.NotebookMetadata.Builder getNotebookBuilder() { + bitField0_ |= 0x00000080; + onChanged(); + return getNotebookFieldBuilder().getBuilder(); + } + /** + * optional .grpc.NotebookMetadata notebook = 8; + */ + public io.trino.spi.grpc.Trinomanager.NotebookMetadataOrBuilder getNotebookOrBuilder() { + if (notebookBuilder_ != null) { + return notebookBuilder_.getMessageOrBuilder(); + } else { + return notebook_ == null ? + io.trino.spi.grpc.Trinomanager.NotebookMetadata.getDefaultInstance() : notebook_; + } + } + /** + * optional .grpc.NotebookMetadata notebook = 8; + */ + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Trinomanager.NotebookMetadata, io.trino.spi.grpc.Trinomanager.NotebookMetadata.Builder, io.trino.spi.grpc.Trinomanager.NotebookMetadataOrBuilder> + getNotebookFieldBuilder() { + if (notebookBuilder_ == null) { + notebookBuilder_ = new com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Trinomanager.NotebookMetadata, io.trino.spi.grpc.Trinomanager.NotebookMetadata.Builder, io.trino.spi.grpc.Trinomanager.NotebookMetadataOrBuilder>( + getNotebook(), + getParentForChildren(), + isClean()); + notebook_ = null; + } + return notebookBuilder_; + } + + private java.lang.Object lastExecutedTrinoQeuryId_ = ""; + /** + * optional string last_executed_trino_qeury_id = 9; + * @return Whether the lastExecutedTrinoQeuryId field is set. + */ + public boolean hasLastExecutedTrinoQeuryId() { + return ((bitField0_ & 0x00000100) != 0); + } + /** + * optional string last_executed_trino_qeury_id = 9; + * @return The lastExecutedTrinoQeuryId. + */ + public java.lang.String getLastExecutedTrinoQeuryId() { + java.lang.Object ref = lastExecutedTrinoQeuryId_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + lastExecutedTrinoQeuryId_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * optional string last_executed_trino_qeury_id = 9; + * @return The bytes for lastExecutedTrinoQeuryId. + */ + public com.google.protobuf.ByteString + getLastExecutedTrinoQeuryIdBytes() { + java.lang.Object ref = lastExecutedTrinoQeuryId_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + lastExecutedTrinoQeuryId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * optional string last_executed_trino_qeury_id = 9; + * @param value The lastExecutedTrinoQeuryId to set. + * @return This builder for chaining. + */ + public Builder setLastExecutedTrinoQeuryId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + lastExecutedTrinoQeuryId_ = value; + bitField0_ |= 0x00000100; + onChanged(); + return this; + } + /** + * optional string last_executed_trino_qeury_id = 9; + * @return This builder for chaining. + */ + public Builder clearLastExecutedTrinoQeuryId() { + lastExecutedTrinoQeuryId_ = getDefaultInstance().getLastExecutedTrinoQeuryId(); + bitField0_ = (bitField0_ & ~0x00000100); + onChanged(); + return this; + } + /** + * optional string last_executed_trino_qeury_id = 9; + * @param value The bytes for lastExecutedTrinoQeuryId to set. + * @return This builder for chaining. + */ + public Builder setLastExecutedTrinoQeuryIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + lastExecutedTrinoQeuryId_ = value; + bitField0_ |= 0x00000100; + onChanged(); + return this; + } + + private java.lang.Object lastExecutionState_ = ""; + /** + * optional string last_execution_state = 10; + * @return Whether the lastExecutionState field is set. + */ + public boolean hasLastExecutionState() { + return ((bitField0_ & 0x00000200) != 0); + } + /** + * optional string last_execution_state = 10; + * @return The lastExecutionState. + */ + public java.lang.String getLastExecutionState() { + java.lang.Object ref = lastExecutionState_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + lastExecutionState_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * optional string last_execution_state = 10; + * @return The bytes for lastExecutionState. + */ + public com.google.protobuf.ByteString + getLastExecutionStateBytes() { + java.lang.Object ref = lastExecutionState_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + lastExecutionState_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * optional string last_execution_state = 10; + * @param value The lastExecutionState to set. + * @return This builder for chaining. + */ + public Builder setLastExecutionState( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + lastExecutionState_ = value; + bitField0_ |= 0x00000200; + onChanged(); + return this; + } + /** + * optional string last_execution_state = 10; + * @return This builder for chaining. + */ + public Builder clearLastExecutionState() { + lastExecutionState_ = getDefaultInstance().getLastExecutionState(); + bitField0_ = (bitField0_ & ~0x00000200); + onChanged(); + return this; + } + /** + * optional string last_execution_state = 10; + * @param value The bytes for lastExecutionState to set. + * @return This builder for chaining. + */ + public Builder setLastExecutionStateBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + lastExecutionState_ = value; + bitField0_ |= 0x00000200; + onChanged(); + return this; + } + + private java.lang.Object lastExecutionError_ = ""; + /** + * optional string last_execution_error = 11; + * @return Whether the lastExecutionError field is set. + */ + public boolean hasLastExecutionError() { + return ((bitField0_ & 0x00000400) != 0); + } + /** + * optional string last_execution_error = 11; + * @return The lastExecutionError. + */ + public java.lang.String getLastExecutionError() { + java.lang.Object ref = lastExecutionError_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + lastExecutionError_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * optional string last_execution_error = 11; + * @return The bytes for lastExecutionError. + */ + public com.google.protobuf.ByteString + getLastExecutionErrorBytes() { + java.lang.Object ref = lastExecutionError_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + lastExecutionError_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * optional string last_execution_error = 11; + * @param value The lastExecutionError to set. + * @return This builder for chaining. + */ + public Builder setLastExecutionError( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + lastExecutionError_ = value; + bitField0_ |= 0x00000400; + onChanged(); + return this; + } + /** + * optional string last_execution_error = 11; + * @return This builder for chaining. + */ + public Builder clearLastExecutionError() { + lastExecutionError_ = getDefaultInstance().getLastExecutionError(); + bitField0_ = (bitField0_ & ~0x00000400); + onChanged(); + return this; + } + /** + * optional string last_execution_error = 11; + * @param value The bytes for lastExecutionError to set. + * @return This builder for chaining. + */ + public Builder setLastExecutionErrorBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + lastExecutionError_ = value; + bitField0_ |= 0x00000400; + onChanged(); + return this; + } + + private long lastExecutedAt_ ; + /** + * optional int64 last_executed_at = 12; + * @return Whether the lastExecutedAt field is set. + */ + @java.lang.Override + public boolean hasLastExecutedAt() { + return ((bitField0_ & 0x00000800) != 0); + } + /** + * optional int64 last_executed_at = 12; + * @return The lastExecutedAt. + */ + @java.lang.Override + public long getLastExecutedAt() { + return lastExecutedAt_; + } + /** + * optional int64 last_executed_at = 12; + * @param value The lastExecutedAt to set. + * @return This builder for chaining. + */ + public Builder setLastExecutedAt(long value) { + + lastExecutedAt_ = value; + bitField0_ |= 0x00000800; + onChanged(); + return this; + } + /** + * optional int64 last_executed_at = 12; + * @return This builder for chaining. + */ + public Builder clearLastExecutedAt() { + bitField0_ = (bitField0_ & ~0x00000800); + lastExecutedAt_ = 0L; + onChanged(); + return this; + } + + private io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig cellConfig_; + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig, io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig.Builder, io.trino.spi.grpc.Trinomanager.NotebookCellCellConfigOrBuilder> cellConfigBuilder_; + /** + * optional .grpc.NotebookCellCellConfig cellConfig = 13; + * @return Whether the cellConfig field is set. + */ + public boolean hasCellConfig() { + return ((bitField0_ & 0x00001000) != 0); + } + /** + * optional .grpc.NotebookCellCellConfig cellConfig = 13; + * @return The cellConfig. + */ + public io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig getCellConfig() { + if (cellConfigBuilder_ == null) { + return cellConfig_ == null ? io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig.getDefaultInstance() : cellConfig_; + } else { + return cellConfigBuilder_.getMessage(); + } + } + /** + * optional .grpc.NotebookCellCellConfig cellConfig = 13; + */ + public Builder setCellConfig(io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig value) { + if (cellConfigBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + cellConfig_ = value; + } else { + cellConfigBuilder_.setMessage(value); + } + bitField0_ |= 0x00001000; + onChanged(); + return this; + } + /** + * optional .grpc.NotebookCellCellConfig cellConfig = 13; + */ + public Builder setCellConfig( + io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig.Builder builderForValue) { + if (cellConfigBuilder_ == null) { + cellConfig_ = builderForValue.build(); + } else { + cellConfigBuilder_.setMessage(builderForValue.build()); + } + bitField0_ |= 0x00001000; + onChanged(); + return this; + } + /** + * optional .grpc.NotebookCellCellConfig cellConfig = 13; + */ + public Builder mergeCellConfig(io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig value) { + if (cellConfigBuilder_ == null) { + if (((bitField0_ & 0x00001000) != 0) && + cellConfig_ != null && + cellConfig_ != io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig.getDefaultInstance()) { + getCellConfigBuilder().mergeFrom(value); + } else { + cellConfig_ = value; + } + } else { + cellConfigBuilder_.mergeFrom(value); + } + bitField0_ |= 0x00001000; + onChanged(); + return this; + } + /** + * optional .grpc.NotebookCellCellConfig cellConfig = 13; + */ + public Builder clearCellConfig() { + bitField0_ = (bitField0_ & ~0x00001000); + cellConfig_ = null; + if (cellConfigBuilder_ != null) { + cellConfigBuilder_.dispose(); + cellConfigBuilder_ = null; + } + onChanged(); + return this; + } + /** + * optional .grpc.NotebookCellCellConfig cellConfig = 13; + */ + public io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig.Builder getCellConfigBuilder() { + bitField0_ |= 0x00001000; + onChanged(); + return getCellConfigFieldBuilder().getBuilder(); + } + /** + * optional .grpc.NotebookCellCellConfig cellConfig = 13; + */ + public io.trino.spi.grpc.Trinomanager.NotebookCellCellConfigOrBuilder getCellConfigOrBuilder() { + if (cellConfigBuilder_ != null) { + return cellConfigBuilder_.getMessageOrBuilder(); + } else { + return cellConfig_ == null ? + io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig.getDefaultInstance() : cellConfig_; + } + } + /** + * optional .grpc.NotebookCellCellConfig cellConfig = 13; + */ + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig, io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig.Builder, io.trino.spi.grpc.Trinomanager.NotebookCellCellConfigOrBuilder> + getCellConfigFieldBuilder() { + if (cellConfigBuilder_ == null) { + cellConfigBuilder_ = new com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig, io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig.Builder, io.trino.spi.grpc.Trinomanager.NotebookCellCellConfigOrBuilder>( + getCellConfig(), + getParentForChildren(), + isClean()); + cellConfig_ = null; + } + return cellConfigBuilder_; + } + + private java.lang.Object sqlQueryExpanded_ = ""; + /** + * string sql_query_expanded = 14; + * @return The sqlQueryExpanded. + */ + public java.lang.String getSqlQueryExpanded() { + java.lang.Object ref = sqlQueryExpanded_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + sqlQueryExpanded_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string sql_query_expanded = 14; + * @return The bytes for sqlQueryExpanded. + */ + public com.google.protobuf.ByteString + getSqlQueryExpandedBytes() { + java.lang.Object ref = sqlQueryExpanded_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + sqlQueryExpanded_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string sql_query_expanded = 14; + * @param value The sqlQueryExpanded to set. + * @return This builder for chaining. + */ + public Builder setSqlQueryExpanded( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + sqlQueryExpanded_ = value; + bitField0_ |= 0x00002000; + onChanged(); + return this; + } + /** + * string sql_query_expanded = 14; + * @return This builder for chaining. + */ + public Builder clearSqlQueryExpanded() { + sqlQueryExpanded_ = getDefaultInstance().getSqlQueryExpanded(); + bitField0_ = (bitField0_ & ~0x00002000); + onChanged(); + return this; + } + /** + * string sql_query_expanded = 14; + * @param value The bytes for sqlQueryExpanded to set. + * @return This builder for chaining. + */ + public Builder setSqlQueryExpandedBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + sqlQueryExpanded_ = value; + bitField0_ |= 0x00002000; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.NotebookCell) + } + + // @@protoc_insertion_point(class_scope:grpc.NotebookCell) + private static final io.trino.spi.grpc.Trinomanager.NotebookCell DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Trinomanager.NotebookCell(); + } + + public static io.trino.spi.grpc.Trinomanager.NotebookCell getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public NotebookCell parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.NotebookCell getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface DeleteNotebookCellReplyOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.DeleteNotebookCellReply) + com.google.protobuf.MessageOrBuilder { + + /** + * string id = 1; + * @return The id. + */ + java.lang.String getId(); + /** + * string id = 1; + * @return The bytes for id. + */ + com.google.protobuf.ByteString + getIdBytes(); + + /** + * optional .grpc.NotebookMetadata notebook = 2; + * @return Whether the notebook field is set. + */ + boolean hasNotebook(); + /** + * optional .grpc.NotebookMetadata notebook = 2; + * @return The notebook. + */ + io.trino.spi.grpc.Trinomanager.NotebookMetadata getNotebook(); + /** + * optional .grpc.NotebookMetadata notebook = 2; + */ + io.trino.spi.grpc.Trinomanager.NotebookMetadataOrBuilder getNotebookOrBuilder(); + } + /** + * Protobuf type {@code grpc.DeleteNotebookCellReply} + */ + public static final class DeleteNotebookCellReply extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.DeleteNotebookCellReply) + DeleteNotebookCellReplyOrBuilder { + private static final long serialVersionUID = 0L; + // Use DeleteNotebookCellReply.newBuilder() to construct. + private DeleteNotebookCellReply(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private DeleteNotebookCellReply() { + id_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new DeleteNotebookCellReply(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_DeleteNotebookCellReply_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_DeleteNotebookCellReply_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply.class, io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply.Builder.class); + } + + private int bitField0_; + public static final int ID_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object id_ = ""; + /** + * string id = 1; + * @return The id. + */ + @java.lang.Override + public java.lang.String getId() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } + } + /** + * string id = 1; + * @return The bytes for id. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int NOTEBOOK_FIELD_NUMBER = 2; + private io.trino.spi.grpc.Trinomanager.NotebookMetadata notebook_; + /** + * optional .grpc.NotebookMetadata notebook = 2; + * @return Whether the notebook field is set. + */ + @java.lang.Override + public boolean hasNotebook() { + return ((bitField0_ & 0x00000001) != 0); + } + /** + * optional .grpc.NotebookMetadata notebook = 2; + * @return The notebook. + */ + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.NotebookMetadata getNotebook() { + return notebook_ == null ? io.trino.spi.grpc.Trinomanager.NotebookMetadata.getDefaultInstance() : notebook_; + } + /** + * optional .grpc.NotebookMetadata notebook = 2; + */ + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.NotebookMetadataOrBuilder getNotebookOrBuilder() { + return notebook_ == null ? io.trino.spi.grpc.Trinomanager.NotebookMetadata.getDefaultInstance() : notebook_; + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, id_); + } + if (((bitField0_ & 0x00000001) != 0)) { + output.writeMessage(2, getNotebook()); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, id_); + } + if (((bitField0_ & 0x00000001) != 0)) { + size += com.google.protobuf.CodedOutputStream + .computeMessageSize(2, getNotebook()); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply)) { + return super.equals(obj); + } + io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply other = (io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply) obj; + + if (!getId() + .equals(other.getId())) return false; + if (hasNotebook() != other.hasNotebook()) return false; + if (hasNotebook()) { + if (!getNotebook() + .equals(other.getNotebook())) return false; + } + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + ID_FIELD_NUMBER; + hash = (53 * hash) + getId().hashCode(); + if (hasNotebook()) { + hash = (37 * hash) + NOTEBOOK_FIELD_NUMBER; + hash = (53 * hash) + getNotebook().hashCode(); + } + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.DeleteNotebookCellReply} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.DeleteNotebookCellReply) + io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReplyOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_DeleteNotebookCellReply_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_DeleteNotebookCellReply_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply.class, io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply.Builder.class); + } + + // Construct using io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply.newBuilder() + private Builder() { + maybeForceBuilderInitialization(); + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + maybeForceBuilderInitialization(); + } + private void maybeForceBuilderInitialization() { + if (com.google.protobuf.GeneratedMessageV3 + .alwaysUseFieldBuilders) { + getNotebookFieldBuilder(); + } + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + id_ = ""; + notebook_ = null; + if (notebookBuilder_ != null) { + notebookBuilder_.dispose(); + notebookBuilder_ = null; + } + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_DeleteNotebookCellReply_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply getDefaultInstanceForType() { + return io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply build() { + io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply buildPartial() { + io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply result = new io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.id_ = id_; + } + int to_bitField0_ = 0; + if (((from_bitField0_ & 0x00000002) != 0)) { + result.notebook_ = notebookBuilder_ == null + ? notebook_ + : notebookBuilder_.build(); + to_bitField0_ |= 0x00000001; + } + result.bitField0_ |= to_bitField0_; + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply) { + return mergeFrom((io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply other) { + if (other == io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply.getDefaultInstance()) return this; + if (!other.getId().isEmpty()) { + id_ = other.id_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (other.hasNotebook()) { + mergeNotebook(other.getNotebook()); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + id_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + input.readMessage( + getNotebookFieldBuilder().getBuilder(), + extensionRegistry); + bitField0_ |= 0x00000002; + break; + } // case 18 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object id_ = ""; + /** + * string id = 1; + * @return The id. + */ + public java.lang.String getId() { + java.lang.Object ref = id_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string id = 1; + * @return The bytes for id. + */ + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string id = 1; + * @param value The id to set. + * @return This builder for chaining. + */ + public Builder setId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + id_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string id = 1; + * @return This builder for chaining. + */ + public Builder clearId() { + id_ = getDefaultInstance().getId(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string id = 1; + * @param value The bytes for id to set. + * @return This builder for chaining. + */ + public Builder setIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + id_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private io.trino.spi.grpc.Trinomanager.NotebookMetadata notebook_; + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Trinomanager.NotebookMetadata, io.trino.spi.grpc.Trinomanager.NotebookMetadata.Builder, io.trino.spi.grpc.Trinomanager.NotebookMetadataOrBuilder> notebookBuilder_; + /** + * optional .grpc.NotebookMetadata notebook = 2; + * @return Whether the notebook field is set. + */ + public boolean hasNotebook() { + return ((bitField0_ & 0x00000002) != 0); + } + /** + * optional .grpc.NotebookMetadata notebook = 2; + * @return The notebook. + */ + public io.trino.spi.grpc.Trinomanager.NotebookMetadata getNotebook() { + if (notebookBuilder_ == null) { + return notebook_ == null ? io.trino.spi.grpc.Trinomanager.NotebookMetadata.getDefaultInstance() : notebook_; + } else { + return notebookBuilder_.getMessage(); + } + } + /** + * optional .grpc.NotebookMetadata notebook = 2; + */ + public Builder setNotebook(io.trino.spi.grpc.Trinomanager.NotebookMetadata value) { + if (notebookBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + notebook_ = value; + } else { + notebookBuilder_.setMessage(value); + } + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * optional .grpc.NotebookMetadata notebook = 2; + */ + public Builder setNotebook( + io.trino.spi.grpc.Trinomanager.NotebookMetadata.Builder builderForValue) { + if (notebookBuilder_ == null) { + notebook_ = builderForValue.build(); + } else { + notebookBuilder_.setMessage(builderForValue.build()); + } + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * optional .grpc.NotebookMetadata notebook = 2; + */ + public Builder mergeNotebook(io.trino.spi.grpc.Trinomanager.NotebookMetadata value) { + if (notebookBuilder_ == null) { + if (((bitField0_ & 0x00000002) != 0) && + notebook_ != null && + notebook_ != io.trino.spi.grpc.Trinomanager.NotebookMetadata.getDefaultInstance()) { + getNotebookBuilder().mergeFrom(value); + } else { + notebook_ = value; + } + } else { + notebookBuilder_.mergeFrom(value); + } + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * optional .grpc.NotebookMetadata notebook = 2; + */ + public Builder clearNotebook() { + bitField0_ = (bitField0_ & ~0x00000002); + notebook_ = null; + if (notebookBuilder_ != null) { + notebookBuilder_.dispose(); + notebookBuilder_ = null; + } + onChanged(); + return this; + } + /** + * optional .grpc.NotebookMetadata notebook = 2; + */ + public io.trino.spi.grpc.Trinomanager.NotebookMetadata.Builder getNotebookBuilder() { + bitField0_ |= 0x00000002; + onChanged(); + return getNotebookFieldBuilder().getBuilder(); + } + /** + * optional .grpc.NotebookMetadata notebook = 2; + */ + public io.trino.spi.grpc.Trinomanager.NotebookMetadataOrBuilder getNotebookOrBuilder() { + if (notebookBuilder_ != null) { + return notebookBuilder_.getMessageOrBuilder(); + } else { + return notebook_ == null ? + io.trino.spi.grpc.Trinomanager.NotebookMetadata.getDefaultInstance() : notebook_; + } + } + /** + * optional .grpc.NotebookMetadata notebook = 2; + */ + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Trinomanager.NotebookMetadata, io.trino.spi.grpc.Trinomanager.NotebookMetadata.Builder, io.trino.spi.grpc.Trinomanager.NotebookMetadataOrBuilder> + getNotebookFieldBuilder() { + if (notebookBuilder_ == null) { + notebookBuilder_ = new com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Trinomanager.NotebookMetadata, io.trino.spi.grpc.Trinomanager.NotebookMetadata.Builder, io.trino.spi.grpc.Trinomanager.NotebookMetadataOrBuilder>( + getNotebook(), + getParentForChildren(), + isClean()); + notebook_ = null; + } + return notebookBuilder_; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.DeleteNotebookCellReply) + } + + // @@protoc_insertion_point(class_scope:grpc.DeleteNotebookCellReply) + private static final io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply(); + } + + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public DeleteNotebookCellReply parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.DeleteNotebookCellReply getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface NotebookOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.Notebook) + com.google.protobuf.MessageOrBuilder { + + /** + * string tenant = 1; + * @return The tenant. + */ + java.lang.String getTenant(); + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + com.google.protobuf.ByteString + getTenantBytes(); + + /** + * string id = 2; + * @return The id. + */ + java.lang.String getId(); + /** + * string id = 2; + * @return The bytes for id. + */ + com.google.protobuf.ByteString + getIdBytes(); + + /** + * int64 created_at = 3; + * @return The createdAt. + */ + long getCreatedAt(); + + /** + * int64 updated_at = 4; + * @return The updatedAt. + */ + long getUpdatedAt(); + + /** + * string title = 5; + * @return The title. + */ + java.lang.String getTitle(); + /** + * string title = 5; + * @return The bytes for title. + */ + com.google.protobuf.ByteString + getTitleBytes(); + + /** + * string description = 6; + * @return The description. + */ + java.lang.String getDescription(); + /** + * string description = 6; + * @return The bytes for description. + */ + com.google.protobuf.ByteString + getDescriptionBytes(); + + /** + * repeated string authors = 7; + * @return A list containing the authors. + */ + java.util.List + getAuthorsList(); + /** + * repeated string authors = 7; + * @return The count of authors. + */ + int getAuthorsCount(); + /** + * repeated string authors = 7; + * @param index The index of the element to return. + * @return The authors at the given index. + */ + java.lang.String getAuthors(int index); + /** + * repeated string authors = 7; + * @param index The index of the value to return. + * @return The bytes of the authors at the given index. + */ + com.google.protobuf.ByteString + getAuthorsBytes(int index); + + /** + * bool deleted = 8; + * @return The deleted. + */ + boolean getDeleted(); + + /** + * int64 deleted_at = 9; + * @return The deletedAt. + */ + long getDeletedAt(); + + /** + * int32 version = 10; + * @return The version. + */ + int getVersion(); + + /** + * repeated .grpc.NotebookCell cells = 11; + */ + java.util.List + getCellsList(); + /** + * repeated .grpc.NotebookCell cells = 11; + */ + io.trino.spi.grpc.Trinomanager.NotebookCell getCells(int index); + /** + * repeated .grpc.NotebookCell cells = 11; + */ + int getCellsCount(); + /** + * repeated .grpc.NotebookCell cells = 11; + */ + java.util.List + getCellsOrBuilderList(); + /** + * repeated .grpc.NotebookCell cells = 11; + */ + io.trino.spi.grpc.Trinomanager.NotebookCellOrBuilder getCellsOrBuilder( + int index); + + /** + * string owner = 12; + * @return The owner. + */ + java.lang.String getOwner(); + /** + * string owner = 12; + * @return The bytes for owner. + */ + com.google.protobuf.ByteString + getOwnerBytes(); + } + /** + * Protobuf type {@code grpc.Notebook} + */ + public static final class Notebook extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.Notebook) + NotebookOrBuilder { + private static final long serialVersionUID = 0L; + // Use Notebook.newBuilder() to construct. + private Notebook(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private Notebook() { + tenant_ = ""; + id_ = ""; + title_ = ""; + description_ = ""; + authors_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + cells_ = java.util.Collections.emptyList(); + owner_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new Notebook(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_Notebook_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_Notebook_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.Notebook.class, io.trino.spi.grpc.Trinomanager.Notebook.Builder.class); + } + + public static final int TENANT_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + @java.lang.Override + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int ID_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object id_ = ""; + /** + * string id = 2; + * @return The id. + */ + @java.lang.Override + public java.lang.String getId() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } + } + /** + * string id = 2; + * @return The bytes for id. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int CREATED_AT_FIELD_NUMBER = 3; + private long createdAt_ = 0L; + /** + * int64 created_at = 3; + * @return The createdAt. + */ + @java.lang.Override + public long getCreatedAt() { + return createdAt_; + } + + public static final int UPDATED_AT_FIELD_NUMBER = 4; + private long updatedAt_ = 0L; + /** + * int64 updated_at = 4; + * @return The updatedAt. + */ + @java.lang.Override + public long getUpdatedAt() { + return updatedAt_; + } + + public static final int TITLE_FIELD_NUMBER = 5; + @SuppressWarnings("serial") + private volatile java.lang.Object title_ = ""; + /** + * string title = 5; + * @return The title. + */ + @java.lang.Override + public java.lang.String getTitle() { + java.lang.Object ref = title_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + title_ = s; + return s; + } + } + /** + * string title = 5; + * @return The bytes for title. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTitleBytes() { + java.lang.Object ref = title_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + title_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int DESCRIPTION_FIELD_NUMBER = 6; + @SuppressWarnings("serial") + private volatile java.lang.Object description_ = ""; + /** + * string description = 6; + * @return The description. + */ + @java.lang.Override + public java.lang.String getDescription() { + java.lang.Object ref = description_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + description_ = s; + return s; + } + } + /** + * string description = 6; + * @return The bytes for description. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getDescriptionBytes() { + java.lang.Object ref = description_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + description_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int AUTHORS_FIELD_NUMBER = 7; + @SuppressWarnings("serial") + private com.google.protobuf.LazyStringArrayList authors_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + /** + * repeated string authors = 7; + * @return A list containing the authors. + */ + public com.google.protobuf.ProtocolStringList + getAuthorsList() { + return authors_; + } + /** + * repeated string authors = 7; + * @return The count of authors. + */ + public int getAuthorsCount() { + return authors_.size(); + } + /** + * repeated string authors = 7; + * @param index The index of the element to return. + * @return The authors at the given index. + */ + public java.lang.String getAuthors(int index) { + return authors_.get(index); + } + /** + * repeated string authors = 7; + * @param index The index of the value to return. + * @return The bytes of the authors at the given index. + */ + public com.google.protobuf.ByteString + getAuthorsBytes(int index) { + return authors_.getByteString(index); + } + + public static final int DELETED_FIELD_NUMBER = 8; + private boolean deleted_ = false; + /** + * bool deleted = 8; + * @return The deleted. + */ + @java.lang.Override + public boolean getDeleted() { + return deleted_; + } + + public static final int DELETED_AT_FIELD_NUMBER = 9; + private long deletedAt_ = 0L; + /** + * int64 deleted_at = 9; + * @return The deletedAt. + */ + @java.lang.Override + public long getDeletedAt() { + return deletedAt_; + } + + public static final int VERSION_FIELD_NUMBER = 10; + private int version_ = 0; + /** + * int32 version = 10; + * @return The version. + */ + @java.lang.Override + public int getVersion() { + return version_; + } + + public static final int CELLS_FIELD_NUMBER = 11; + @SuppressWarnings("serial") + private java.util.List cells_; + /** + * repeated .grpc.NotebookCell cells = 11; + */ + @java.lang.Override + public java.util.List getCellsList() { + return cells_; + } + /** + * repeated .grpc.NotebookCell cells = 11; + */ + @java.lang.Override + public java.util.List + getCellsOrBuilderList() { + return cells_; + } + /** + * repeated .grpc.NotebookCell cells = 11; + */ + @java.lang.Override + public int getCellsCount() { + return cells_.size(); + } + /** + * repeated .grpc.NotebookCell cells = 11; + */ + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.NotebookCell getCells(int index) { + return cells_.get(index); + } + /** + * repeated .grpc.NotebookCell cells = 11; + */ + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.NotebookCellOrBuilder getCellsOrBuilder( + int index) { + return cells_.get(index); + } + + public static final int OWNER_FIELD_NUMBER = 12; + @SuppressWarnings("serial") + private volatile java.lang.Object owner_ = ""; + /** + * string owner = 12; + * @return The owner. + */ + @java.lang.Override + public java.lang.String getOwner() { + java.lang.Object ref = owner_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + owner_ = s; + return s; + } + } + /** + * string owner = 12; + * @return The bytes for owner. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getOwnerBytes() { + java.lang.Object ref = owner_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + owner_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, id_); + } + if (createdAt_ != 0L) { + output.writeInt64(3, createdAt_); + } + if (updatedAt_ != 0L) { + output.writeInt64(4, updatedAt_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(title_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 5, title_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(description_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 6, description_); + } + for (int i = 0; i < authors_.size(); i++) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 7, authors_.getRaw(i)); + } + if (deleted_ != false) { + output.writeBool(8, deleted_); + } + if (deletedAt_ != 0L) { + output.writeInt64(9, deletedAt_); + } + if (version_ != 0) { + output.writeInt32(10, version_); + } + for (int i = 0; i < cells_.size(); i++) { + output.writeMessage(11, cells_.get(i)); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(owner_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 12, owner_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, id_); + } + if (createdAt_ != 0L) { + size += com.google.protobuf.CodedOutputStream + .computeInt64Size(3, createdAt_); + } + if (updatedAt_ != 0L) { + size += com.google.protobuf.CodedOutputStream + .computeInt64Size(4, updatedAt_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(title_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(5, title_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(description_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(6, description_); + } + { + int dataSize = 0; + for (int i = 0; i < authors_.size(); i++) { + dataSize += computeStringSizeNoTag(authors_.getRaw(i)); + } + size += dataSize; + size += 1 * getAuthorsList().size(); + } + if (deleted_ != false) { + size += com.google.protobuf.CodedOutputStream + .computeBoolSize(8, deleted_); + } + if (deletedAt_ != 0L) { + size += com.google.protobuf.CodedOutputStream + .computeInt64Size(9, deletedAt_); + } + if (version_ != 0) { + size += com.google.protobuf.CodedOutputStream + .computeInt32Size(10, version_); + } + for (int i = 0; i < cells_.size(); i++) { + size += com.google.protobuf.CodedOutputStream + .computeMessageSize(11, cells_.get(i)); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(owner_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(12, owner_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Trinomanager.Notebook)) { + return super.equals(obj); + } + io.trino.spi.grpc.Trinomanager.Notebook other = (io.trino.spi.grpc.Trinomanager.Notebook) obj; + + if (!getTenant() + .equals(other.getTenant())) return false; + if (!getId() + .equals(other.getId())) return false; + if (getCreatedAt() + != other.getCreatedAt()) return false; + if (getUpdatedAt() + != other.getUpdatedAt()) return false; + if (!getTitle() + .equals(other.getTitle())) return false; + if (!getDescription() + .equals(other.getDescription())) return false; + if (!getAuthorsList() + .equals(other.getAuthorsList())) return false; + if (getDeleted() + != other.getDeleted()) return false; + if (getDeletedAt() + != other.getDeletedAt()) return false; + if (getVersion() + != other.getVersion()) return false; + if (!getCellsList() + .equals(other.getCellsList())) return false; + if (!getOwner() + .equals(other.getOwner())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + TENANT_FIELD_NUMBER; + hash = (53 * hash) + getTenant().hashCode(); + hash = (37 * hash) + ID_FIELD_NUMBER; + hash = (53 * hash) + getId().hashCode(); + hash = (37 * hash) + CREATED_AT_FIELD_NUMBER; + hash = (53 * hash) + com.google.protobuf.Internal.hashLong( + getCreatedAt()); + hash = (37 * hash) + UPDATED_AT_FIELD_NUMBER; + hash = (53 * hash) + com.google.protobuf.Internal.hashLong( + getUpdatedAt()); + hash = (37 * hash) + TITLE_FIELD_NUMBER; + hash = (53 * hash) + getTitle().hashCode(); + hash = (37 * hash) + DESCRIPTION_FIELD_NUMBER; + hash = (53 * hash) + getDescription().hashCode(); + if (getAuthorsCount() > 0) { + hash = (37 * hash) + AUTHORS_FIELD_NUMBER; + hash = (53 * hash) + getAuthorsList().hashCode(); + } + hash = (37 * hash) + DELETED_FIELD_NUMBER; + hash = (53 * hash) + com.google.protobuf.Internal.hashBoolean( + getDeleted()); + hash = (37 * hash) + DELETED_AT_FIELD_NUMBER; + hash = (53 * hash) + com.google.protobuf.Internal.hashLong( + getDeletedAt()); + hash = (37 * hash) + VERSION_FIELD_NUMBER; + hash = (53 * hash) + getVersion(); + if (getCellsCount() > 0) { + hash = (37 * hash) + CELLS_FIELD_NUMBER; + hash = (53 * hash) + getCellsList().hashCode(); + } + hash = (37 * hash) + OWNER_FIELD_NUMBER; + hash = (53 * hash) + getOwner().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Trinomanager.Notebook parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.Notebook parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.Notebook parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.Notebook parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.Notebook parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.Notebook parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.Notebook parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.Notebook parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Trinomanager.Notebook parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Trinomanager.Notebook parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.Notebook parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.Notebook parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Trinomanager.Notebook prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.Notebook} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.Notebook) + io.trino.spi.grpc.Trinomanager.NotebookOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_Notebook_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_Notebook_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.Notebook.class, io.trino.spi.grpc.Trinomanager.Notebook.Builder.class); + } + + // Construct using io.trino.spi.grpc.Trinomanager.Notebook.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + tenant_ = ""; + id_ = ""; + createdAt_ = 0L; + updatedAt_ = 0L; + title_ = ""; + description_ = ""; + authors_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + deleted_ = false; + deletedAt_ = 0L; + version_ = 0; + if (cellsBuilder_ == null) { + cells_ = java.util.Collections.emptyList(); + } else { + cells_ = null; + cellsBuilder_.clear(); + } + bitField0_ = (bitField0_ & ~0x00000400); + owner_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_Notebook_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.Notebook getDefaultInstanceForType() { + return io.trino.spi.grpc.Trinomanager.Notebook.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.Notebook build() { + io.trino.spi.grpc.Trinomanager.Notebook result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.Notebook buildPartial() { + io.trino.spi.grpc.Trinomanager.Notebook result = new io.trino.spi.grpc.Trinomanager.Notebook(this); + buildPartialRepeatedFields(result); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartialRepeatedFields(io.trino.spi.grpc.Trinomanager.Notebook result) { + if (cellsBuilder_ == null) { + if (((bitField0_ & 0x00000400) != 0)) { + cells_ = java.util.Collections.unmodifiableList(cells_); + bitField0_ = (bitField0_ & ~0x00000400); + } + result.cells_ = cells_; + } else { + result.cells_ = cellsBuilder_.build(); + } + } + + private void buildPartial0(io.trino.spi.grpc.Trinomanager.Notebook result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.tenant_ = tenant_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.id_ = id_; + } + if (((from_bitField0_ & 0x00000004) != 0)) { + result.createdAt_ = createdAt_; + } + if (((from_bitField0_ & 0x00000008) != 0)) { + result.updatedAt_ = updatedAt_; + } + if (((from_bitField0_ & 0x00000010) != 0)) { + result.title_ = title_; + } + if (((from_bitField0_ & 0x00000020) != 0)) { + result.description_ = description_; + } + if (((from_bitField0_ & 0x00000040) != 0)) { + authors_.makeImmutable(); + result.authors_ = authors_; + } + if (((from_bitField0_ & 0x00000080) != 0)) { + result.deleted_ = deleted_; + } + if (((from_bitField0_ & 0x00000100) != 0)) { + result.deletedAt_ = deletedAt_; + } + if (((from_bitField0_ & 0x00000200) != 0)) { + result.version_ = version_; + } + if (((from_bitField0_ & 0x00000800) != 0)) { + result.owner_ = owner_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Trinomanager.Notebook) { + return mergeFrom((io.trino.spi.grpc.Trinomanager.Notebook)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Trinomanager.Notebook other) { + if (other == io.trino.spi.grpc.Trinomanager.Notebook.getDefaultInstance()) return this; + if (!other.getTenant().isEmpty()) { + tenant_ = other.tenant_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getId().isEmpty()) { + id_ = other.id_; + bitField0_ |= 0x00000002; + onChanged(); + } + if (other.getCreatedAt() != 0L) { + setCreatedAt(other.getCreatedAt()); + } + if (other.getUpdatedAt() != 0L) { + setUpdatedAt(other.getUpdatedAt()); + } + if (!other.getTitle().isEmpty()) { + title_ = other.title_; + bitField0_ |= 0x00000010; + onChanged(); + } + if (!other.getDescription().isEmpty()) { + description_ = other.description_; + bitField0_ |= 0x00000020; + onChanged(); + } + if (!other.authors_.isEmpty()) { + if (authors_.isEmpty()) { + authors_ = other.authors_; + bitField0_ |= 0x00000040; + } else { + ensureAuthorsIsMutable(); + authors_.addAll(other.authors_); + } + onChanged(); + } + if (other.getDeleted() != false) { + setDeleted(other.getDeleted()); + } + if (other.getDeletedAt() != 0L) { + setDeletedAt(other.getDeletedAt()); + } + if (other.getVersion() != 0) { + setVersion(other.getVersion()); + } + if (cellsBuilder_ == null) { + if (!other.cells_.isEmpty()) { + if (cells_.isEmpty()) { + cells_ = other.cells_; + bitField0_ = (bitField0_ & ~0x00000400); + } else { + ensureCellsIsMutable(); + cells_.addAll(other.cells_); + } + onChanged(); + } + } else { + if (!other.cells_.isEmpty()) { + if (cellsBuilder_.isEmpty()) { + cellsBuilder_.dispose(); + cellsBuilder_ = null; + cells_ = other.cells_; + bitField0_ = (bitField0_ & ~0x00000400); + cellsBuilder_ = + com.google.protobuf.GeneratedMessageV3.alwaysUseFieldBuilders ? + getCellsFieldBuilder() : null; + } else { + cellsBuilder_.addAllMessages(other.cells_); + } + } + } + if (!other.getOwner().isEmpty()) { + owner_ = other.owner_; + bitField0_ |= 0x00000800; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + tenant_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + id_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + case 24: { + createdAt_ = input.readInt64(); + bitField0_ |= 0x00000004; + break; + } // case 24 + case 32: { + updatedAt_ = input.readInt64(); + bitField0_ |= 0x00000008; + break; + } // case 32 + case 42: { + title_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000010; + break; + } // case 42 + case 50: { + description_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000020; + break; + } // case 50 + case 58: { + java.lang.String s = input.readStringRequireUtf8(); + ensureAuthorsIsMutable(); + authors_.add(s); + break; + } // case 58 + case 64: { + deleted_ = input.readBool(); + bitField0_ |= 0x00000080; + break; + } // case 64 + case 72: { + deletedAt_ = input.readInt64(); + bitField0_ |= 0x00000100; + break; + } // case 72 + case 80: { + version_ = input.readInt32(); + bitField0_ |= 0x00000200; + break; + } // case 80 + case 90: { + io.trino.spi.grpc.Trinomanager.NotebookCell m = + input.readMessage( + io.trino.spi.grpc.Trinomanager.NotebookCell.parser(), + extensionRegistry); + if (cellsBuilder_ == null) { + ensureCellsIsMutable(); + cells_.add(m); + } else { + cellsBuilder_.addMessage(m); + } + break; + } // case 90 + case 98: { + owner_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000800; + break; + } // case 98 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant = 1; + * @param value The tenant to set. + * @return This builder for chaining. + */ + public Builder setTenant( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string tenant = 1; + * @return This builder for chaining. + */ + public Builder clearTenant() { + tenant_ = getDefaultInstance().getTenant(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string tenant = 1; + * @param value The bytes for tenant to set. + * @return This builder for chaining. + */ + public Builder setTenantBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object id_ = ""; + /** + * string id = 2; + * @return The id. + */ + public java.lang.String getId() { + java.lang.Object ref = id_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string id = 2; + * @return The bytes for id. + */ + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string id = 2; + * @param value The id to set. + * @return This builder for chaining. + */ + public Builder setId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + id_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string id = 2; + * @return This builder for chaining. + */ + public Builder clearId() { + id_ = getDefaultInstance().getId(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string id = 2; + * @param value The bytes for id to set. + * @return This builder for chaining. + */ + public Builder setIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + id_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + + private long createdAt_ ; + /** + * int64 created_at = 3; + * @return The createdAt. + */ + @java.lang.Override + public long getCreatedAt() { + return createdAt_; + } + /** + * int64 created_at = 3; + * @param value The createdAt to set. + * @return This builder for chaining. + */ + public Builder setCreatedAt(long value) { + + createdAt_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + /** + * int64 created_at = 3; + * @return This builder for chaining. + */ + public Builder clearCreatedAt() { + bitField0_ = (bitField0_ & ~0x00000004); + createdAt_ = 0L; + onChanged(); + return this; + } + + private long updatedAt_ ; + /** + * int64 updated_at = 4; + * @return The updatedAt. + */ + @java.lang.Override + public long getUpdatedAt() { + return updatedAt_; + } + /** + * int64 updated_at = 4; + * @param value The updatedAt to set. + * @return This builder for chaining. + */ + public Builder setUpdatedAt(long value) { + + updatedAt_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + /** + * int64 updated_at = 4; + * @return This builder for chaining. + */ + public Builder clearUpdatedAt() { + bitField0_ = (bitField0_ & ~0x00000008); + updatedAt_ = 0L; + onChanged(); + return this; + } + + private java.lang.Object title_ = ""; + /** + * string title = 5; + * @return The title. + */ + public java.lang.String getTitle() { + java.lang.Object ref = title_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + title_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string title = 5; + * @return The bytes for title. + */ + public com.google.protobuf.ByteString + getTitleBytes() { + java.lang.Object ref = title_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + title_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string title = 5; + * @param value The title to set. + * @return This builder for chaining. + */ + public Builder setTitle( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + title_ = value; + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + /** + * string title = 5; + * @return This builder for chaining. + */ + public Builder clearTitle() { + title_ = getDefaultInstance().getTitle(); + bitField0_ = (bitField0_ & ~0x00000010); + onChanged(); + return this; + } + /** + * string title = 5; + * @param value The bytes for title to set. + * @return This builder for chaining. + */ + public Builder setTitleBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + title_ = value; + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + + private java.lang.Object description_ = ""; + /** + * string description = 6; + * @return The description. + */ + public java.lang.String getDescription() { + java.lang.Object ref = description_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + description_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string description = 6; + * @return The bytes for description. + */ + public com.google.protobuf.ByteString + getDescriptionBytes() { + java.lang.Object ref = description_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + description_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string description = 6; + * @param value The description to set. + * @return This builder for chaining. + */ + public Builder setDescription( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + description_ = value; + bitField0_ |= 0x00000020; + onChanged(); + return this; + } + /** + * string description = 6; + * @return This builder for chaining. + */ + public Builder clearDescription() { + description_ = getDefaultInstance().getDescription(); + bitField0_ = (bitField0_ & ~0x00000020); + onChanged(); + return this; + } + /** + * string description = 6; + * @param value The bytes for description to set. + * @return This builder for chaining. + */ + public Builder setDescriptionBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + description_ = value; + bitField0_ |= 0x00000020; + onChanged(); + return this; + } + + private com.google.protobuf.LazyStringArrayList authors_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + private void ensureAuthorsIsMutable() { + if (!authors_.isModifiable()) { + authors_ = new com.google.protobuf.LazyStringArrayList(authors_); + } + bitField0_ |= 0x00000040; + } + /** + * repeated string authors = 7; + * @return A list containing the authors. + */ + public com.google.protobuf.ProtocolStringList + getAuthorsList() { + authors_.makeImmutable(); + return authors_; + } + /** + * repeated string authors = 7; + * @return The count of authors. + */ + public int getAuthorsCount() { + return authors_.size(); + } + /** + * repeated string authors = 7; + * @param index The index of the element to return. + * @return The authors at the given index. + */ + public java.lang.String getAuthors(int index) { + return authors_.get(index); + } + /** + * repeated string authors = 7; + * @param index The index of the value to return. + * @return The bytes of the authors at the given index. + */ + public com.google.protobuf.ByteString + getAuthorsBytes(int index) { + return authors_.getByteString(index); + } + /** + * repeated string authors = 7; + * @param index The index to set the value at. + * @param value The authors to set. + * @return This builder for chaining. + */ + public Builder setAuthors( + int index, java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + ensureAuthorsIsMutable(); + authors_.set(index, value); + bitField0_ |= 0x00000040; + onChanged(); + return this; + } + /** + * repeated string authors = 7; + * @param value The authors to add. + * @return This builder for chaining. + */ + public Builder addAuthors( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + ensureAuthorsIsMutable(); + authors_.add(value); + bitField0_ |= 0x00000040; + onChanged(); + return this; + } + /** + * repeated string authors = 7; + * @param values The authors to add. + * @return This builder for chaining. + */ + public Builder addAllAuthors( + java.lang.Iterable values) { + ensureAuthorsIsMutable(); + com.google.protobuf.AbstractMessageLite.Builder.addAll( + values, authors_); + bitField0_ |= 0x00000040; + onChanged(); + return this; + } + /** + * repeated string authors = 7; + * @return This builder for chaining. + */ + public Builder clearAuthors() { + authors_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + bitField0_ = (bitField0_ & ~0x00000040);; + onChanged(); + return this; + } + /** + * repeated string authors = 7; + * @param value The bytes of the authors to add. + * @return This builder for chaining. + */ + public Builder addAuthorsBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + ensureAuthorsIsMutable(); + authors_.add(value); + bitField0_ |= 0x00000040; + onChanged(); + return this; + } + + private boolean deleted_ ; + /** + * bool deleted = 8; + * @return The deleted. + */ + @java.lang.Override + public boolean getDeleted() { + return deleted_; + } + /** + * bool deleted = 8; + * @param value The deleted to set. + * @return This builder for chaining. + */ + public Builder setDeleted(boolean value) { + + deleted_ = value; + bitField0_ |= 0x00000080; + onChanged(); + return this; + } + /** + * bool deleted = 8; + * @return This builder for chaining. + */ + public Builder clearDeleted() { + bitField0_ = (bitField0_ & ~0x00000080); + deleted_ = false; + onChanged(); + return this; + } + + private long deletedAt_ ; + /** + * int64 deleted_at = 9; + * @return The deletedAt. + */ + @java.lang.Override + public long getDeletedAt() { + return deletedAt_; + } + /** + * int64 deleted_at = 9; + * @param value The deletedAt to set. + * @return This builder for chaining. + */ + public Builder setDeletedAt(long value) { + + deletedAt_ = value; + bitField0_ |= 0x00000100; + onChanged(); + return this; + } + /** + * int64 deleted_at = 9; + * @return This builder for chaining. + */ + public Builder clearDeletedAt() { + bitField0_ = (bitField0_ & ~0x00000100); + deletedAt_ = 0L; + onChanged(); + return this; + } + + private int version_ ; + /** + * int32 version = 10; + * @return The version. + */ + @java.lang.Override + public int getVersion() { + return version_; + } + /** + * int32 version = 10; + * @param value The version to set. + * @return This builder for chaining. + */ + public Builder setVersion(int value) { + + version_ = value; + bitField0_ |= 0x00000200; + onChanged(); + return this; + } + /** + * int32 version = 10; + * @return This builder for chaining. + */ + public Builder clearVersion() { + bitField0_ = (bitField0_ & ~0x00000200); + version_ = 0; + onChanged(); + return this; + } + + private java.util.List cells_ = + java.util.Collections.emptyList(); + private void ensureCellsIsMutable() { + if (!((bitField0_ & 0x00000400) != 0)) { + cells_ = new java.util.ArrayList(cells_); + bitField0_ |= 0x00000400; + } + } + + private com.google.protobuf.RepeatedFieldBuilderV3< + io.trino.spi.grpc.Trinomanager.NotebookCell, io.trino.spi.grpc.Trinomanager.NotebookCell.Builder, io.trino.spi.grpc.Trinomanager.NotebookCellOrBuilder> cellsBuilder_; + + /** + * repeated .grpc.NotebookCell cells = 11; + */ + public java.util.List getCellsList() { + if (cellsBuilder_ == null) { + return java.util.Collections.unmodifiableList(cells_); + } else { + return cellsBuilder_.getMessageList(); + } + } + /** + * repeated .grpc.NotebookCell cells = 11; + */ + public int getCellsCount() { + if (cellsBuilder_ == null) { + return cells_.size(); + } else { + return cellsBuilder_.getCount(); + } + } + /** + * repeated .grpc.NotebookCell cells = 11; + */ + public io.trino.spi.grpc.Trinomanager.NotebookCell getCells(int index) { + if (cellsBuilder_ == null) { + return cells_.get(index); + } else { + return cellsBuilder_.getMessage(index); + } + } + /** + * repeated .grpc.NotebookCell cells = 11; + */ + public Builder setCells( + int index, io.trino.spi.grpc.Trinomanager.NotebookCell value) { + if (cellsBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + ensureCellsIsMutable(); + cells_.set(index, value); + onChanged(); + } else { + cellsBuilder_.setMessage(index, value); + } + return this; + } + /** + * repeated .grpc.NotebookCell cells = 11; + */ + public Builder setCells( + int index, io.trino.spi.grpc.Trinomanager.NotebookCell.Builder builderForValue) { + if (cellsBuilder_ == null) { + ensureCellsIsMutable(); + cells_.set(index, builderForValue.build()); + onChanged(); + } else { + cellsBuilder_.setMessage(index, builderForValue.build()); + } + return this; + } + /** + * repeated .grpc.NotebookCell cells = 11; + */ + public Builder addCells(io.trino.spi.grpc.Trinomanager.NotebookCell value) { + if (cellsBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + ensureCellsIsMutable(); + cells_.add(value); + onChanged(); + } else { + cellsBuilder_.addMessage(value); + } + return this; + } + /** + * repeated .grpc.NotebookCell cells = 11; + */ + public Builder addCells( + int index, io.trino.spi.grpc.Trinomanager.NotebookCell value) { + if (cellsBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + ensureCellsIsMutable(); + cells_.add(index, value); + onChanged(); + } else { + cellsBuilder_.addMessage(index, value); + } + return this; + } + /** + * repeated .grpc.NotebookCell cells = 11; + */ + public Builder addCells( + io.trino.spi.grpc.Trinomanager.NotebookCell.Builder builderForValue) { + if (cellsBuilder_ == null) { + ensureCellsIsMutable(); + cells_.add(builderForValue.build()); + onChanged(); + } else { + cellsBuilder_.addMessage(builderForValue.build()); + } + return this; + } + /** + * repeated .grpc.NotebookCell cells = 11; + */ + public Builder addCells( + int index, io.trino.spi.grpc.Trinomanager.NotebookCell.Builder builderForValue) { + if (cellsBuilder_ == null) { + ensureCellsIsMutable(); + cells_.add(index, builderForValue.build()); + onChanged(); + } else { + cellsBuilder_.addMessage(index, builderForValue.build()); + } + return this; + } + /** + * repeated .grpc.NotebookCell cells = 11; + */ + public Builder addAllCells( + java.lang.Iterable values) { + if (cellsBuilder_ == null) { + ensureCellsIsMutable(); + com.google.protobuf.AbstractMessageLite.Builder.addAll( + values, cells_); + onChanged(); + } else { + cellsBuilder_.addAllMessages(values); + } + return this; + } + /** + * repeated .grpc.NotebookCell cells = 11; + */ + public Builder clearCells() { + if (cellsBuilder_ == null) { + cells_ = java.util.Collections.emptyList(); + bitField0_ = (bitField0_ & ~0x00000400); + onChanged(); + } else { + cellsBuilder_.clear(); + } + return this; + } + /** + * repeated .grpc.NotebookCell cells = 11; + */ + public Builder removeCells(int index) { + if (cellsBuilder_ == null) { + ensureCellsIsMutable(); + cells_.remove(index); + onChanged(); + } else { + cellsBuilder_.remove(index); + } + return this; + } + /** + * repeated .grpc.NotebookCell cells = 11; + */ + public io.trino.spi.grpc.Trinomanager.NotebookCell.Builder getCellsBuilder( + int index) { + return getCellsFieldBuilder().getBuilder(index); + } + /** + * repeated .grpc.NotebookCell cells = 11; + */ + public io.trino.spi.grpc.Trinomanager.NotebookCellOrBuilder getCellsOrBuilder( + int index) { + if (cellsBuilder_ == null) { + return cells_.get(index); } else { + return cellsBuilder_.getMessageOrBuilder(index); + } + } + /** + * repeated .grpc.NotebookCell cells = 11; + */ + public java.util.List + getCellsOrBuilderList() { + if (cellsBuilder_ != null) { + return cellsBuilder_.getMessageOrBuilderList(); + } else { + return java.util.Collections.unmodifiableList(cells_); + } + } + /** + * repeated .grpc.NotebookCell cells = 11; + */ + public io.trino.spi.grpc.Trinomanager.NotebookCell.Builder addCellsBuilder() { + return getCellsFieldBuilder().addBuilder( + io.trino.spi.grpc.Trinomanager.NotebookCell.getDefaultInstance()); + } + /** + * repeated .grpc.NotebookCell cells = 11; + */ + public io.trino.spi.grpc.Trinomanager.NotebookCell.Builder addCellsBuilder( + int index) { + return getCellsFieldBuilder().addBuilder( + index, io.trino.spi.grpc.Trinomanager.NotebookCell.getDefaultInstance()); + } + /** + * repeated .grpc.NotebookCell cells = 11; + */ + public java.util.List + getCellsBuilderList() { + return getCellsFieldBuilder().getBuilderList(); + } + private com.google.protobuf.RepeatedFieldBuilderV3< + io.trino.spi.grpc.Trinomanager.NotebookCell, io.trino.spi.grpc.Trinomanager.NotebookCell.Builder, io.trino.spi.grpc.Trinomanager.NotebookCellOrBuilder> + getCellsFieldBuilder() { + if (cellsBuilder_ == null) { + cellsBuilder_ = new com.google.protobuf.RepeatedFieldBuilderV3< + io.trino.spi.grpc.Trinomanager.NotebookCell, io.trino.spi.grpc.Trinomanager.NotebookCell.Builder, io.trino.spi.grpc.Trinomanager.NotebookCellOrBuilder>( + cells_, + ((bitField0_ & 0x00000400) != 0), + getParentForChildren(), + isClean()); + cells_ = null; + } + return cellsBuilder_; + } + + private java.lang.Object owner_ = ""; + /** + * string owner = 12; + * @return The owner. + */ + public java.lang.String getOwner() { + java.lang.Object ref = owner_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + owner_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string owner = 12; + * @return The bytes for owner. + */ + public com.google.protobuf.ByteString + getOwnerBytes() { + java.lang.Object ref = owner_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + owner_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string owner = 12; + * @param value The owner to set. + * @return This builder for chaining. + */ + public Builder setOwner( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + owner_ = value; + bitField0_ |= 0x00000800; + onChanged(); + return this; + } + /** + * string owner = 12; + * @return This builder for chaining. + */ + public Builder clearOwner() { + owner_ = getDefaultInstance().getOwner(); + bitField0_ = (bitField0_ & ~0x00000800); + onChanged(); + return this; + } + /** + * string owner = 12; + * @param value The bytes for owner to set. + * @return This builder for chaining. + */ + public Builder setOwnerBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + owner_ = value; + bitField0_ |= 0x00000800; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.Notebook) + } + + // @@protoc_insertion_point(class_scope:grpc.Notebook) + private static final io.trino.spi.grpc.Trinomanager.Notebook DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Trinomanager.Notebook(); + } + + public static io.trino.spi.grpc.Trinomanager.Notebook getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public Notebook parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.Notebook getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface NotebookMetadataOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.NotebookMetadata) + com.google.protobuf.MessageOrBuilder { + + /** + * string tenant = 1; + * @return The tenant. + */ + java.lang.String getTenant(); + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + com.google.protobuf.ByteString + getTenantBytes(); + + /** + * string id = 2; + * @return The id. + */ + java.lang.String getId(); + /** + * string id = 2; + * @return The bytes for id. + */ + com.google.protobuf.ByteString + getIdBytes(); + + /** + * int32 version = 3; + * @return The version. + */ + int getVersion(); + + /** + * int64 updated_at = 4; + * @return The updatedAt. + */ + long getUpdatedAt(); + + /** + * string title = 5; + * @return The title. + */ + java.lang.String getTitle(); + /** + * string title = 5; + * @return The bytes for title. + */ + com.google.protobuf.ByteString + getTitleBytes(); + + /** + * string description = 6; + * @return The description. + */ + java.lang.String getDescription(); + /** + * string description = 6; + * @return The bytes for description. + */ + com.google.protobuf.ByteString + getDescriptionBytes(); + + /** + * repeated string authors = 7; + * @return A list containing the authors. + */ + java.util.List + getAuthorsList(); + /** + * repeated string authors = 7; + * @return The count of authors. + */ + int getAuthorsCount(); + /** + * repeated string authors = 7; + * @param index The index of the element to return. + * @return The authors at the given index. + */ + java.lang.String getAuthors(int index); + /** + * repeated string authors = 7; + * @param index The index of the value to return. + * @return The bytes of the authors at the given index. + */ + com.google.protobuf.ByteString + getAuthorsBytes(int index); + } + /** + * Protobuf type {@code grpc.NotebookMetadata} + */ + public static final class NotebookMetadata extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.NotebookMetadata) + NotebookMetadataOrBuilder { + private static final long serialVersionUID = 0L; + // Use NotebookMetadata.newBuilder() to construct. + private NotebookMetadata(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private NotebookMetadata() { + tenant_ = ""; + id_ = ""; + title_ = ""; + description_ = ""; + authors_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new NotebookMetadata(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_NotebookMetadata_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_NotebookMetadata_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.NotebookMetadata.class, io.trino.spi.grpc.Trinomanager.NotebookMetadata.Builder.class); + } + + public static final int TENANT_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + @java.lang.Override + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int ID_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object id_ = ""; + /** + * string id = 2; + * @return The id. + */ + @java.lang.Override + public java.lang.String getId() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } + } + /** + * string id = 2; + * @return The bytes for id. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int VERSION_FIELD_NUMBER = 3; + private int version_ = 0; + /** + * int32 version = 3; + * @return The version. + */ + @java.lang.Override + public int getVersion() { + return version_; + } + + public static final int UPDATED_AT_FIELD_NUMBER = 4; + private long updatedAt_ = 0L; + /** + * int64 updated_at = 4; + * @return The updatedAt. + */ + @java.lang.Override + public long getUpdatedAt() { + return updatedAt_; + } + + public static final int TITLE_FIELD_NUMBER = 5; + @SuppressWarnings("serial") + private volatile java.lang.Object title_ = ""; + /** + * string title = 5; + * @return The title. + */ + @java.lang.Override + public java.lang.String getTitle() { + java.lang.Object ref = title_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + title_ = s; + return s; + } + } + /** + * string title = 5; + * @return The bytes for title. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTitleBytes() { + java.lang.Object ref = title_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + title_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int DESCRIPTION_FIELD_NUMBER = 6; + @SuppressWarnings("serial") + private volatile java.lang.Object description_ = ""; + /** + * string description = 6; + * @return The description. + */ + @java.lang.Override + public java.lang.String getDescription() { + java.lang.Object ref = description_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + description_ = s; + return s; + } + } + /** + * string description = 6; + * @return The bytes for description. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getDescriptionBytes() { + java.lang.Object ref = description_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + description_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int AUTHORS_FIELD_NUMBER = 7; + @SuppressWarnings("serial") + private com.google.protobuf.LazyStringArrayList authors_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + /** + * repeated string authors = 7; + * @return A list containing the authors. + */ + public com.google.protobuf.ProtocolStringList + getAuthorsList() { + return authors_; + } + /** + * repeated string authors = 7; + * @return The count of authors. + */ + public int getAuthorsCount() { + return authors_.size(); + } + /** + * repeated string authors = 7; + * @param index The index of the element to return. + * @return The authors at the given index. + */ + public java.lang.String getAuthors(int index) { + return authors_.get(index); + } + /** + * repeated string authors = 7; + * @param index The index of the value to return. + * @return The bytes of the authors at the given index. + */ + public com.google.protobuf.ByteString + getAuthorsBytes(int index) { + return authors_.getByteString(index); + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, id_); + } + if (version_ != 0) { + output.writeInt32(3, version_); + } + if (updatedAt_ != 0L) { + output.writeInt64(4, updatedAt_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(title_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 5, title_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(description_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 6, description_); + } + for (int i = 0; i < authors_.size(); i++) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 7, authors_.getRaw(i)); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, id_); + } + if (version_ != 0) { + size += com.google.protobuf.CodedOutputStream + .computeInt32Size(3, version_); + } + if (updatedAt_ != 0L) { + size += com.google.protobuf.CodedOutputStream + .computeInt64Size(4, updatedAt_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(title_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(5, title_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(description_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(6, description_); + } + { + int dataSize = 0; + for (int i = 0; i < authors_.size(); i++) { + dataSize += computeStringSizeNoTag(authors_.getRaw(i)); + } + size += dataSize; + size += 1 * getAuthorsList().size(); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Trinomanager.NotebookMetadata)) { + return super.equals(obj); + } + io.trino.spi.grpc.Trinomanager.NotebookMetadata other = (io.trino.spi.grpc.Trinomanager.NotebookMetadata) obj; + + if (!getTenant() + .equals(other.getTenant())) return false; + if (!getId() + .equals(other.getId())) return false; + if (getVersion() + != other.getVersion()) return false; + if (getUpdatedAt() + != other.getUpdatedAt()) return false; + if (!getTitle() + .equals(other.getTitle())) return false; + if (!getDescription() + .equals(other.getDescription())) return false; + if (!getAuthorsList() + .equals(other.getAuthorsList())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + TENANT_FIELD_NUMBER; + hash = (53 * hash) + getTenant().hashCode(); + hash = (37 * hash) + ID_FIELD_NUMBER; + hash = (53 * hash) + getId().hashCode(); + hash = (37 * hash) + VERSION_FIELD_NUMBER; + hash = (53 * hash) + getVersion(); + hash = (37 * hash) + UPDATED_AT_FIELD_NUMBER; + hash = (53 * hash) + com.google.protobuf.Internal.hashLong( + getUpdatedAt()); + hash = (37 * hash) + TITLE_FIELD_NUMBER; + hash = (53 * hash) + getTitle().hashCode(); + hash = (37 * hash) + DESCRIPTION_FIELD_NUMBER; + hash = (53 * hash) + getDescription().hashCode(); + if (getAuthorsCount() > 0) { + hash = (37 * hash) + AUTHORS_FIELD_NUMBER; + hash = (53 * hash) + getAuthorsList().hashCode(); + } + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Trinomanager.NotebookMetadata parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.NotebookMetadata parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.NotebookMetadata parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.NotebookMetadata parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.NotebookMetadata parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.NotebookMetadata parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.NotebookMetadata parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.NotebookMetadata parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Trinomanager.NotebookMetadata parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Trinomanager.NotebookMetadata parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.NotebookMetadata parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.NotebookMetadata parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Trinomanager.NotebookMetadata prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.NotebookMetadata} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.NotebookMetadata) + io.trino.spi.grpc.Trinomanager.NotebookMetadataOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_NotebookMetadata_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_NotebookMetadata_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.NotebookMetadata.class, io.trino.spi.grpc.Trinomanager.NotebookMetadata.Builder.class); + } + + // Construct using io.trino.spi.grpc.Trinomanager.NotebookMetadata.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + tenant_ = ""; + id_ = ""; + version_ = 0; + updatedAt_ = 0L; + title_ = ""; + description_ = ""; + authors_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_NotebookMetadata_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.NotebookMetadata getDefaultInstanceForType() { + return io.trino.spi.grpc.Trinomanager.NotebookMetadata.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.NotebookMetadata build() { + io.trino.spi.grpc.Trinomanager.NotebookMetadata result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.NotebookMetadata buildPartial() { + io.trino.spi.grpc.Trinomanager.NotebookMetadata result = new io.trino.spi.grpc.Trinomanager.NotebookMetadata(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Trinomanager.NotebookMetadata result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.tenant_ = tenant_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.id_ = id_; + } + if (((from_bitField0_ & 0x00000004) != 0)) { + result.version_ = version_; + } + if (((from_bitField0_ & 0x00000008) != 0)) { + result.updatedAt_ = updatedAt_; + } + if (((from_bitField0_ & 0x00000010) != 0)) { + result.title_ = title_; + } + if (((from_bitField0_ & 0x00000020) != 0)) { + result.description_ = description_; + } + if (((from_bitField0_ & 0x00000040) != 0)) { + authors_.makeImmutable(); + result.authors_ = authors_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Trinomanager.NotebookMetadata) { + return mergeFrom((io.trino.spi.grpc.Trinomanager.NotebookMetadata)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Trinomanager.NotebookMetadata other) { + if (other == io.trino.spi.grpc.Trinomanager.NotebookMetadata.getDefaultInstance()) return this; + if (!other.getTenant().isEmpty()) { + tenant_ = other.tenant_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getId().isEmpty()) { + id_ = other.id_; + bitField0_ |= 0x00000002; + onChanged(); + } + if (other.getVersion() != 0) { + setVersion(other.getVersion()); + } + if (other.getUpdatedAt() != 0L) { + setUpdatedAt(other.getUpdatedAt()); + } + if (!other.getTitle().isEmpty()) { + title_ = other.title_; + bitField0_ |= 0x00000010; + onChanged(); + } + if (!other.getDescription().isEmpty()) { + description_ = other.description_; + bitField0_ |= 0x00000020; + onChanged(); + } + if (!other.authors_.isEmpty()) { + if (authors_.isEmpty()) { + authors_ = other.authors_; + bitField0_ |= 0x00000040; + } else { + ensureAuthorsIsMutable(); + authors_.addAll(other.authors_); + } + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + tenant_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + id_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + case 24: { + version_ = input.readInt32(); + bitField0_ |= 0x00000004; + break; + } // case 24 + case 32: { + updatedAt_ = input.readInt64(); + bitField0_ |= 0x00000008; + break; + } // case 32 + case 42: { + title_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000010; + break; + } // case 42 + case 50: { + description_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000020; + break; + } // case 50 + case 58: { + java.lang.String s = input.readStringRequireUtf8(); + ensureAuthorsIsMutable(); + authors_.add(s); + break; + } // case 58 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant = 1; + * @param value The tenant to set. + * @return This builder for chaining. + */ + public Builder setTenant( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string tenant = 1; + * @return This builder for chaining. + */ + public Builder clearTenant() { + tenant_ = getDefaultInstance().getTenant(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string tenant = 1; + * @param value The bytes for tenant to set. + * @return This builder for chaining. + */ + public Builder setTenantBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object id_ = ""; + /** + * string id = 2; + * @return The id. + */ + public java.lang.String getId() { + java.lang.Object ref = id_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string id = 2; + * @return The bytes for id. + */ + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string id = 2; + * @param value The id to set. + * @return This builder for chaining. + */ + public Builder setId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + id_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string id = 2; + * @return This builder for chaining. + */ + public Builder clearId() { + id_ = getDefaultInstance().getId(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string id = 2; + * @param value The bytes for id to set. + * @return This builder for chaining. + */ + public Builder setIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + id_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + + private int version_ ; + /** + * int32 version = 3; + * @return The version. + */ + @java.lang.Override + public int getVersion() { + return version_; + } + /** + * int32 version = 3; + * @param value The version to set. + * @return This builder for chaining. + */ + public Builder setVersion(int value) { + + version_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + /** + * int32 version = 3; + * @return This builder for chaining. + */ + public Builder clearVersion() { + bitField0_ = (bitField0_ & ~0x00000004); + version_ = 0; + onChanged(); + return this; + } + + private long updatedAt_ ; + /** + * int64 updated_at = 4; + * @return The updatedAt. + */ + @java.lang.Override + public long getUpdatedAt() { + return updatedAt_; + } + /** + * int64 updated_at = 4; + * @param value The updatedAt to set. + * @return This builder for chaining. + */ + public Builder setUpdatedAt(long value) { + + updatedAt_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + /** + * int64 updated_at = 4; + * @return This builder for chaining. + */ + public Builder clearUpdatedAt() { + bitField0_ = (bitField0_ & ~0x00000008); + updatedAt_ = 0L; + onChanged(); + return this; + } + + private java.lang.Object title_ = ""; + /** + * string title = 5; + * @return The title. + */ + public java.lang.String getTitle() { + java.lang.Object ref = title_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + title_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string title = 5; + * @return The bytes for title. + */ + public com.google.protobuf.ByteString + getTitleBytes() { + java.lang.Object ref = title_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + title_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string title = 5; + * @param value The title to set. + * @return This builder for chaining. + */ + public Builder setTitle( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + title_ = value; + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + /** + * string title = 5; + * @return This builder for chaining. + */ + public Builder clearTitle() { + title_ = getDefaultInstance().getTitle(); + bitField0_ = (bitField0_ & ~0x00000010); + onChanged(); + return this; + } + /** + * string title = 5; + * @param value The bytes for title to set. + * @return This builder for chaining. + */ + public Builder setTitleBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + title_ = value; + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + + private java.lang.Object description_ = ""; + /** + * string description = 6; + * @return The description. + */ + public java.lang.String getDescription() { + java.lang.Object ref = description_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + description_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string description = 6; + * @return The bytes for description. + */ + public com.google.protobuf.ByteString + getDescriptionBytes() { + java.lang.Object ref = description_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + description_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string description = 6; + * @param value The description to set. + * @return This builder for chaining. + */ + public Builder setDescription( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + description_ = value; + bitField0_ |= 0x00000020; + onChanged(); + return this; + } + /** + * string description = 6; + * @return This builder for chaining. + */ + public Builder clearDescription() { + description_ = getDefaultInstance().getDescription(); + bitField0_ = (bitField0_ & ~0x00000020); + onChanged(); + return this; + } + /** + * string description = 6; + * @param value The bytes for description to set. + * @return This builder for chaining. + */ + public Builder setDescriptionBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + description_ = value; + bitField0_ |= 0x00000020; + onChanged(); + return this; + } + + private com.google.protobuf.LazyStringArrayList authors_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + private void ensureAuthorsIsMutable() { + if (!authors_.isModifiable()) { + authors_ = new com.google.protobuf.LazyStringArrayList(authors_); + } + bitField0_ |= 0x00000040; + } + /** + * repeated string authors = 7; + * @return A list containing the authors. + */ + public com.google.protobuf.ProtocolStringList + getAuthorsList() { + authors_.makeImmutable(); + return authors_; + } + /** + * repeated string authors = 7; + * @return The count of authors. + */ + public int getAuthorsCount() { + return authors_.size(); + } + /** + * repeated string authors = 7; + * @param index The index of the element to return. + * @return The authors at the given index. + */ + public java.lang.String getAuthors(int index) { + return authors_.get(index); + } + /** + * repeated string authors = 7; + * @param index The index of the value to return. + * @return The bytes of the authors at the given index. + */ + public com.google.protobuf.ByteString + getAuthorsBytes(int index) { + return authors_.getByteString(index); + } + /** + * repeated string authors = 7; + * @param index The index to set the value at. + * @param value The authors to set. + * @return This builder for chaining. + */ + public Builder setAuthors( + int index, java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + ensureAuthorsIsMutable(); + authors_.set(index, value); + bitField0_ |= 0x00000040; + onChanged(); + return this; + } + /** + * repeated string authors = 7; + * @param value The authors to add. + * @return This builder for chaining. + */ + public Builder addAuthors( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + ensureAuthorsIsMutable(); + authors_.add(value); + bitField0_ |= 0x00000040; + onChanged(); + return this; + } + /** + * repeated string authors = 7; + * @param values The authors to add. + * @return This builder for chaining. + */ + public Builder addAllAuthors( + java.lang.Iterable values) { + ensureAuthorsIsMutable(); + com.google.protobuf.AbstractMessageLite.Builder.addAll( + values, authors_); + bitField0_ |= 0x00000040; + onChanged(); + return this; + } + /** + * repeated string authors = 7; + * @return This builder for chaining. + */ + public Builder clearAuthors() { + authors_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + bitField0_ = (bitField0_ & ~0x00000040);; + onChanged(); + return this; + } + /** + * repeated string authors = 7; + * @param value The bytes of the authors to add. + * @return This builder for chaining. + */ + public Builder addAuthorsBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + ensureAuthorsIsMutable(); + authors_.add(value); + bitField0_ |= 0x00000040; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.NotebookMetadata) + } + + // @@protoc_insertion_point(class_scope:grpc.NotebookMetadata) + private static final io.trino.spi.grpc.Trinomanager.NotebookMetadata DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Trinomanager.NotebookMetadata(); + } + + public static io.trino.spi.grpc.Trinomanager.NotebookMetadata getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public NotebookMetadata parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.NotebookMetadata getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface QueryDetailsRequestOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.QueryDetailsRequest) + com.google.protobuf.MessageOrBuilder { + + /** + * string tenant_name = 1; + * @return The tenantName. + */ + java.lang.String getTenantName(); + /** + * string tenant_name = 1; + * @return The bytes for tenantName. + */ + com.google.protobuf.ByteString + getTenantNameBytes(); + + /** + * string query_id = 2; + * @return The queryId. + */ + java.lang.String getQueryId(); + /** + * string query_id = 2; + * @return The bytes for queryId. + */ + com.google.protobuf.ByteString + getQueryIdBytes(); + } + /** + * Protobuf type {@code grpc.QueryDetailsRequest} + */ + public static final class QueryDetailsRequest extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.QueryDetailsRequest) + QueryDetailsRequestOrBuilder { + private static final long serialVersionUID = 0L; + // Use QueryDetailsRequest.newBuilder() to construct. + private QueryDetailsRequest(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private QueryDetailsRequest() { + tenantName_ = ""; + queryId_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new QueryDetailsRequest(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_QueryDetailsRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_QueryDetailsRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.QueryDetailsRequest.class, io.trino.spi.grpc.Trinomanager.QueryDetailsRequest.Builder.class); + } + + public static final int TENANT_NAME_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object tenantName_ = ""; + /** + * string tenant_name = 1; + * @return The tenantName. + */ + @java.lang.Override + public java.lang.String getTenantName() { + java.lang.Object ref = tenantName_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenantName_ = s; + return s; + } + } + /** + * string tenant_name = 1; + * @return The bytes for tenantName. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantNameBytes() { + java.lang.Object ref = tenantName_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenantName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int QUERY_ID_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object queryId_ = ""; + /** + * string query_id = 2; + * @return The queryId. + */ + @java.lang.Override + public java.lang.String getQueryId() { + java.lang.Object ref = queryId_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + queryId_ = s; + return s; + } + } + /** + * string query_id = 2; + * @return The bytes for queryId. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getQueryIdBytes() { + java.lang.Object ref = queryId_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + queryId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenantName_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, tenantName_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(queryId_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, queryId_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenantName_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, tenantName_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(queryId_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, queryId_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Trinomanager.QueryDetailsRequest)) { + return super.equals(obj); + } + io.trino.spi.grpc.Trinomanager.QueryDetailsRequest other = (io.trino.spi.grpc.Trinomanager.QueryDetailsRequest) obj; + + if (!getTenantName() + .equals(other.getTenantName())) return false; + if (!getQueryId() + .equals(other.getQueryId())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + TENANT_NAME_FIELD_NUMBER; + hash = (53 * hash) + getTenantName().hashCode(); + hash = (37 * hash) + QUERY_ID_FIELD_NUMBER; + hash = (53 * hash) + getQueryId().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Trinomanager.QueryDetailsRequest parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.QueryDetailsRequest parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.QueryDetailsRequest parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.QueryDetailsRequest parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.QueryDetailsRequest parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.QueryDetailsRequest parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.QueryDetailsRequest parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.QueryDetailsRequest parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Trinomanager.QueryDetailsRequest parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Trinomanager.QueryDetailsRequest parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.QueryDetailsRequest parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.QueryDetailsRequest parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Trinomanager.QueryDetailsRequest prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.QueryDetailsRequest} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.QueryDetailsRequest) + io.trino.spi.grpc.Trinomanager.QueryDetailsRequestOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_QueryDetailsRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_QueryDetailsRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.QueryDetailsRequest.class, io.trino.spi.grpc.Trinomanager.QueryDetailsRequest.Builder.class); + } + + // Construct using io.trino.spi.grpc.Trinomanager.QueryDetailsRequest.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + tenantName_ = ""; + queryId_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_QueryDetailsRequest_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.QueryDetailsRequest getDefaultInstanceForType() { + return io.trino.spi.grpc.Trinomanager.QueryDetailsRequest.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.QueryDetailsRequest build() { + io.trino.spi.grpc.Trinomanager.QueryDetailsRequest result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.QueryDetailsRequest buildPartial() { + io.trino.spi.grpc.Trinomanager.QueryDetailsRequest result = new io.trino.spi.grpc.Trinomanager.QueryDetailsRequest(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Trinomanager.QueryDetailsRequest result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.tenantName_ = tenantName_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.queryId_ = queryId_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Trinomanager.QueryDetailsRequest) { + return mergeFrom((io.trino.spi.grpc.Trinomanager.QueryDetailsRequest)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Trinomanager.QueryDetailsRequest other) { + if (other == io.trino.spi.grpc.Trinomanager.QueryDetailsRequest.getDefaultInstance()) return this; + if (!other.getTenantName().isEmpty()) { + tenantName_ = other.tenantName_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getQueryId().isEmpty()) { + queryId_ = other.queryId_; + bitField0_ |= 0x00000002; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + tenantName_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + queryId_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object tenantName_ = ""; + /** + * string tenant_name = 1; + * @return The tenantName. + */ + public java.lang.String getTenantName() { + java.lang.Object ref = tenantName_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenantName_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant_name = 1; + * @return The bytes for tenantName. + */ + public com.google.protobuf.ByteString + getTenantNameBytes() { + java.lang.Object ref = tenantName_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenantName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant_name = 1; + * @param value The tenantName to set. + * @return This builder for chaining. + */ + public Builder setTenantName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenantName_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string tenant_name = 1; + * @return This builder for chaining. + */ + public Builder clearTenantName() { + tenantName_ = getDefaultInstance().getTenantName(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string tenant_name = 1; + * @param value The bytes for tenantName to set. + * @return This builder for chaining. + */ + public Builder setTenantNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenantName_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object queryId_ = ""; + /** + * string query_id = 2; + * @return The queryId. + */ + public java.lang.String getQueryId() { + java.lang.Object ref = queryId_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + queryId_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string query_id = 2; + * @return The bytes for queryId. + */ + public com.google.protobuf.ByteString + getQueryIdBytes() { + java.lang.Object ref = queryId_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + queryId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string query_id = 2; + * @param value The queryId to set. + * @return This builder for chaining. + */ + public Builder setQueryId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + queryId_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string query_id = 2; + * @return This builder for chaining. + */ + public Builder clearQueryId() { + queryId_ = getDefaultInstance().getQueryId(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string query_id = 2; + * @param value The bytes for queryId to set. + * @return This builder for chaining. + */ + public Builder setQueryIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + queryId_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.QueryDetailsRequest) + } + + // @@protoc_insertion_point(class_scope:grpc.QueryDetailsRequest) + private static final io.trino.spi.grpc.Trinomanager.QueryDetailsRequest DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Trinomanager.QueryDetailsRequest(); + } + + public static io.trino.spi.grpc.Trinomanager.QueryDetailsRequest getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public QueryDetailsRequest parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.QueryDetailsRequest getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface QueryDetailsReplyOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.QueryDetailsReply) + com.google.protobuf.MessageOrBuilder { + + /** + * string query_id = 1; + * @return The queryId. + */ + java.lang.String getQueryId(); + /** + * string query_id = 1; + * @return The bytes for queryId. + */ + com.google.protobuf.ByteString + getQueryIdBytes(); + + /** + * int32 state = 2; + * @return The state. + */ + int getState(); + + /** + * optional string error_message = 3; + * @return Whether the errorMessage field is set. + */ + boolean hasErrorMessage(); + /** + * optional string error_message = 3; + * @return The errorMessage. + */ + java.lang.String getErrorMessage(); + /** + * optional string error_message = 3; + * @return The bytes for errorMessage. + */ + com.google.protobuf.ByteString + getErrorMessageBytes(); + + /** + * string tenant_name = 4; + * @return The tenantName. + */ + java.lang.String getTenantName(); + /** + * string tenant_name = 4; + * @return The bytes for tenantName. + */ + com.google.protobuf.ByteString + getTenantNameBytes(); + } + /** + * Protobuf type {@code grpc.QueryDetailsReply} + */ + public static final class QueryDetailsReply extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.QueryDetailsReply) + QueryDetailsReplyOrBuilder { + private static final long serialVersionUID = 0L; + // Use QueryDetailsReply.newBuilder() to construct. + private QueryDetailsReply(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private QueryDetailsReply() { + queryId_ = ""; + errorMessage_ = ""; + tenantName_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new QueryDetailsReply(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_QueryDetailsReply_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_QueryDetailsReply_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.QueryDetailsReply.class, io.trino.spi.grpc.Trinomanager.QueryDetailsReply.Builder.class); + } + + private int bitField0_; + public static final int QUERY_ID_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object queryId_ = ""; + /** + * string query_id = 1; + * @return The queryId. + */ + @java.lang.Override + public java.lang.String getQueryId() { + java.lang.Object ref = queryId_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + queryId_ = s; + return s; + } + } + /** + * string query_id = 1; + * @return The bytes for queryId. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getQueryIdBytes() { + java.lang.Object ref = queryId_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + queryId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int STATE_FIELD_NUMBER = 2; + private int state_ = 0; + /** + * int32 state = 2; + * @return The state. + */ + @java.lang.Override + public int getState() { + return state_; + } + + public static final int ERROR_MESSAGE_FIELD_NUMBER = 3; + @SuppressWarnings("serial") + private volatile java.lang.Object errorMessage_ = ""; + /** + * optional string error_message = 3; + * @return Whether the errorMessage field is set. + */ + @java.lang.Override + public boolean hasErrorMessage() { + return ((bitField0_ & 0x00000001) != 0); + } + /** + * optional string error_message = 3; + * @return The errorMessage. + */ + @java.lang.Override + public java.lang.String getErrorMessage() { + java.lang.Object ref = errorMessage_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + errorMessage_ = s; + return s; + } + } + /** + * optional string error_message = 3; + * @return The bytes for errorMessage. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getErrorMessageBytes() { + java.lang.Object ref = errorMessage_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + errorMessage_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int TENANT_NAME_FIELD_NUMBER = 4; + @SuppressWarnings("serial") + private volatile java.lang.Object tenantName_ = ""; + /** + * string tenant_name = 4; + * @return The tenantName. + */ + @java.lang.Override + public java.lang.String getTenantName() { + java.lang.Object ref = tenantName_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenantName_ = s; + return s; + } + } + /** + * string tenant_name = 4; + * @return The bytes for tenantName. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantNameBytes() { + java.lang.Object ref = tenantName_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenantName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(queryId_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, queryId_); + } + if (state_ != 0) { + output.writeInt32(2, state_); + } + if (((bitField0_ & 0x00000001) != 0)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 3, errorMessage_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenantName_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 4, tenantName_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(queryId_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, queryId_); + } + if (state_ != 0) { + size += com.google.protobuf.CodedOutputStream + .computeInt32Size(2, state_); + } + if (((bitField0_ & 0x00000001) != 0)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(3, errorMessage_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenantName_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(4, tenantName_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Trinomanager.QueryDetailsReply)) { + return super.equals(obj); + } + io.trino.spi.grpc.Trinomanager.QueryDetailsReply other = (io.trino.spi.grpc.Trinomanager.QueryDetailsReply) obj; + + if (!getQueryId() + .equals(other.getQueryId())) return false; + if (getState() + != other.getState()) return false; + if (hasErrorMessage() != other.hasErrorMessage()) return false; + if (hasErrorMessage()) { + if (!getErrorMessage() + .equals(other.getErrorMessage())) return false; + } + if (!getTenantName() + .equals(other.getTenantName())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + QUERY_ID_FIELD_NUMBER; + hash = (53 * hash) + getQueryId().hashCode(); + hash = (37 * hash) + STATE_FIELD_NUMBER; + hash = (53 * hash) + getState(); + if (hasErrorMessage()) { + hash = (37 * hash) + ERROR_MESSAGE_FIELD_NUMBER; + hash = (53 * hash) + getErrorMessage().hashCode(); + } + hash = (37 * hash) + TENANT_NAME_FIELD_NUMBER; + hash = (53 * hash) + getTenantName().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Trinomanager.QueryDetailsReply parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.QueryDetailsReply parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.QueryDetailsReply parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.QueryDetailsReply parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.QueryDetailsReply parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.QueryDetailsReply parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.QueryDetailsReply parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.QueryDetailsReply parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Trinomanager.QueryDetailsReply parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Trinomanager.QueryDetailsReply parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.QueryDetailsReply parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.QueryDetailsReply parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Trinomanager.QueryDetailsReply prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.QueryDetailsReply} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.QueryDetailsReply) + io.trino.spi.grpc.Trinomanager.QueryDetailsReplyOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_QueryDetailsReply_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_QueryDetailsReply_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.QueryDetailsReply.class, io.trino.spi.grpc.Trinomanager.QueryDetailsReply.Builder.class); + } + + // Construct using io.trino.spi.grpc.Trinomanager.QueryDetailsReply.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + queryId_ = ""; + state_ = 0; + errorMessage_ = ""; + tenantName_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_QueryDetailsReply_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.QueryDetailsReply getDefaultInstanceForType() { + return io.trino.spi.grpc.Trinomanager.QueryDetailsReply.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.QueryDetailsReply build() { + io.trino.spi.grpc.Trinomanager.QueryDetailsReply result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.QueryDetailsReply buildPartial() { + io.trino.spi.grpc.Trinomanager.QueryDetailsReply result = new io.trino.spi.grpc.Trinomanager.QueryDetailsReply(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Trinomanager.QueryDetailsReply result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.queryId_ = queryId_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.state_ = state_; + } + int to_bitField0_ = 0; + if (((from_bitField0_ & 0x00000004) != 0)) { + result.errorMessage_ = errorMessage_; + to_bitField0_ |= 0x00000001; + } + if (((from_bitField0_ & 0x00000008) != 0)) { + result.tenantName_ = tenantName_; + } + result.bitField0_ |= to_bitField0_; + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Trinomanager.QueryDetailsReply) { + return mergeFrom((io.trino.spi.grpc.Trinomanager.QueryDetailsReply)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Trinomanager.QueryDetailsReply other) { + if (other == io.trino.spi.grpc.Trinomanager.QueryDetailsReply.getDefaultInstance()) return this; + if (!other.getQueryId().isEmpty()) { + queryId_ = other.queryId_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (other.getState() != 0) { + setState(other.getState()); + } + if (other.hasErrorMessage()) { + errorMessage_ = other.errorMessage_; + bitField0_ |= 0x00000004; + onChanged(); + } + if (!other.getTenantName().isEmpty()) { + tenantName_ = other.tenantName_; + bitField0_ |= 0x00000008; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + queryId_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 16: { + state_ = input.readInt32(); + bitField0_ |= 0x00000002; + break; + } // case 16 + case 26: { + errorMessage_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000004; + break; + } // case 26 + case 34: { + tenantName_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000008; + break; + } // case 34 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object queryId_ = ""; + /** + * string query_id = 1; + * @return The queryId. + */ + public java.lang.String getQueryId() { + java.lang.Object ref = queryId_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + queryId_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string query_id = 1; + * @return The bytes for queryId. + */ + public com.google.protobuf.ByteString + getQueryIdBytes() { + java.lang.Object ref = queryId_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + queryId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string query_id = 1; + * @param value The queryId to set. + * @return This builder for chaining. + */ + public Builder setQueryId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + queryId_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string query_id = 1; + * @return This builder for chaining. + */ + public Builder clearQueryId() { + queryId_ = getDefaultInstance().getQueryId(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string query_id = 1; + * @param value The bytes for queryId to set. + * @return This builder for chaining. + */ + public Builder setQueryIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + queryId_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private int state_ ; + /** + * int32 state = 2; + * @return The state. + */ + @java.lang.Override + public int getState() { + return state_; + } + /** + * int32 state = 2; + * @param value The state to set. + * @return This builder for chaining. + */ + public Builder setState(int value) { + + state_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * int32 state = 2; + * @return This builder for chaining. + */ + public Builder clearState() { + bitField0_ = (bitField0_ & ~0x00000002); + state_ = 0; + onChanged(); + return this; + } + + private java.lang.Object errorMessage_ = ""; + /** + * optional string error_message = 3; + * @return Whether the errorMessage field is set. + */ + public boolean hasErrorMessage() { + return ((bitField0_ & 0x00000004) != 0); + } + /** + * optional string error_message = 3; + * @return The errorMessage. + */ + public java.lang.String getErrorMessage() { + java.lang.Object ref = errorMessage_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + errorMessage_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * optional string error_message = 3; + * @return The bytes for errorMessage. + */ + public com.google.protobuf.ByteString + getErrorMessageBytes() { + java.lang.Object ref = errorMessage_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + errorMessage_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * optional string error_message = 3; + * @param value The errorMessage to set. + * @return This builder for chaining. + */ + public Builder setErrorMessage( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + errorMessage_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + /** + * optional string error_message = 3; + * @return This builder for chaining. + */ + public Builder clearErrorMessage() { + errorMessage_ = getDefaultInstance().getErrorMessage(); + bitField0_ = (bitField0_ & ~0x00000004); + onChanged(); + return this; + } + /** + * optional string error_message = 3; + * @param value The bytes for errorMessage to set. + * @return This builder for chaining. + */ + public Builder setErrorMessageBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + errorMessage_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + + private java.lang.Object tenantName_ = ""; + /** + * string tenant_name = 4; + * @return The tenantName. + */ + public java.lang.String getTenantName() { + java.lang.Object ref = tenantName_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenantName_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant_name = 4; + * @return The bytes for tenantName. + */ + public com.google.protobuf.ByteString + getTenantNameBytes() { + java.lang.Object ref = tenantName_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenantName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant_name = 4; + * @param value The tenantName to set. + * @return This builder for chaining. + */ + public Builder setTenantName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenantName_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + /** + * string tenant_name = 4; + * @return This builder for chaining. + */ + public Builder clearTenantName() { + tenantName_ = getDefaultInstance().getTenantName(); + bitField0_ = (bitField0_ & ~0x00000008); + onChanged(); + return this; + } + /** + * string tenant_name = 4; + * @param value The bytes for tenantName to set. + * @return This builder for chaining. + */ + public Builder setTenantNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenantName_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.QueryDetailsReply) + } + + // @@protoc_insertion_point(class_scope:grpc.QueryDetailsReply) + private static final io.trino.spi.grpc.Trinomanager.QueryDetailsReply DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Trinomanager.QueryDetailsReply(); + } + + public static io.trino.spi.grpc.Trinomanager.QueryDetailsReply getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public QueryDetailsReply parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.QueryDetailsReply getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface ExpandQueryByDataSourceIDsRequestOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.ExpandQueryByDataSourceIDsRequest) + com.google.protobuf.MessageOrBuilder { + + /** + * repeated string data_source_ids = 1; + * @return A list containing the dataSourceIds. + */ + java.util.List + getDataSourceIdsList(); + /** + * repeated string data_source_ids = 1; + * @return The count of dataSourceIds. + */ + int getDataSourceIdsCount(); + /** + * repeated string data_source_ids = 1; + * @param index The index of the element to return. + * @return The dataSourceIds at the given index. + */ + java.lang.String getDataSourceIds(int index); + /** + * repeated string data_source_ids = 1; + * @param index The index of the value to return. + * @return The bytes of the dataSourceIds at the given index. + */ + com.google.protobuf.ByteString + getDataSourceIdsBytes(int index); + + /** + * string query = 2; + * @return The query. + */ + java.lang.String getQuery(); + /** + * string query = 2; + * @return The bytes for query. + */ + com.google.protobuf.ByteString + getQueryBytes(); + + /** + * string tenant_name = 3; + * @return The tenantName. + */ + java.lang.String getTenantName(); + /** + * string tenant_name = 3; + * @return The bytes for tenantName. + */ + com.google.protobuf.ByteString + getTenantNameBytes(); + } + /** + * Protobuf type {@code grpc.ExpandQueryByDataSourceIDsRequest} + */ + public static final class ExpandQueryByDataSourceIDsRequest extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.ExpandQueryByDataSourceIDsRequest) + ExpandQueryByDataSourceIDsRequestOrBuilder { + private static final long serialVersionUID = 0L; + // Use ExpandQueryByDataSourceIDsRequest.newBuilder() to construct. + private ExpandQueryByDataSourceIDsRequest(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private ExpandQueryByDataSourceIDsRequest() { + dataSourceIds_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + query_ = ""; + tenantName_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new ExpandQueryByDataSourceIDsRequest(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_ExpandQueryByDataSourceIDsRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_ExpandQueryByDataSourceIDsRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest.class, io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest.Builder.class); + } + + public static final int DATA_SOURCE_IDS_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private com.google.protobuf.LazyStringArrayList dataSourceIds_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + /** + * repeated string data_source_ids = 1; + * @return A list containing the dataSourceIds. + */ + public com.google.protobuf.ProtocolStringList + getDataSourceIdsList() { + return dataSourceIds_; + } + /** + * repeated string data_source_ids = 1; + * @return The count of dataSourceIds. + */ + public int getDataSourceIdsCount() { + return dataSourceIds_.size(); + } + /** + * repeated string data_source_ids = 1; + * @param index The index of the element to return. + * @return The dataSourceIds at the given index. + */ + public java.lang.String getDataSourceIds(int index) { + return dataSourceIds_.get(index); + } + /** + * repeated string data_source_ids = 1; + * @param index The index of the value to return. + * @return The bytes of the dataSourceIds at the given index. + */ + public com.google.protobuf.ByteString + getDataSourceIdsBytes(int index) { + return dataSourceIds_.getByteString(index); + } + + public static final int QUERY_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object query_ = ""; + /** + * string query = 2; + * @return The query. + */ + @java.lang.Override + public java.lang.String getQuery() { + java.lang.Object ref = query_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + query_ = s; + return s; + } + } + /** + * string query = 2; + * @return The bytes for query. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getQueryBytes() { + java.lang.Object ref = query_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + query_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int TENANT_NAME_FIELD_NUMBER = 3; + @SuppressWarnings("serial") + private volatile java.lang.Object tenantName_ = ""; + /** + * string tenant_name = 3; + * @return The tenantName. + */ + @java.lang.Override + public java.lang.String getTenantName() { + java.lang.Object ref = tenantName_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenantName_ = s; + return s; + } + } + /** + * string tenant_name = 3; + * @return The bytes for tenantName. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantNameBytes() { + java.lang.Object ref = tenantName_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenantName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + for (int i = 0; i < dataSourceIds_.size(); i++) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, dataSourceIds_.getRaw(i)); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(query_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, query_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenantName_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 3, tenantName_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + { + int dataSize = 0; + for (int i = 0; i < dataSourceIds_.size(); i++) { + dataSize += computeStringSizeNoTag(dataSourceIds_.getRaw(i)); + } + size += dataSize; + size += 1 * getDataSourceIdsList().size(); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(query_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, query_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenantName_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(3, tenantName_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest)) { + return super.equals(obj); + } + io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest other = (io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest) obj; + + if (!getDataSourceIdsList() + .equals(other.getDataSourceIdsList())) return false; + if (!getQuery() + .equals(other.getQuery())) return false; + if (!getTenantName() + .equals(other.getTenantName())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + if (getDataSourceIdsCount() > 0) { + hash = (37 * hash) + DATA_SOURCE_IDS_FIELD_NUMBER; + hash = (53 * hash) + getDataSourceIdsList().hashCode(); + } + hash = (37 * hash) + QUERY_FIELD_NUMBER; + hash = (53 * hash) + getQuery().hashCode(); + hash = (37 * hash) + TENANT_NAME_FIELD_NUMBER; + hash = (53 * hash) + getTenantName().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.ExpandQueryByDataSourceIDsRequest} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.ExpandQueryByDataSourceIDsRequest) + io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequestOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_ExpandQueryByDataSourceIDsRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_ExpandQueryByDataSourceIDsRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest.class, io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest.Builder.class); + } + + // Construct using io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + dataSourceIds_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + query_ = ""; + tenantName_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_ExpandQueryByDataSourceIDsRequest_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest getDefaultInstanceForType() { + return io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest build() { + io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest buildPartial() { + io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest result = new io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + dataSourceIds_.makeImmutable(); + result.dataSourceIds_ = dataSourceIds_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.query_ = query_; + } + if (((from_bitField0_ & 0x00000004) != 0)) { + result.tenantName_ = tenantName_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest) { + return mergeFrom((io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest other) { + if (other == io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest.getDefaultInstance()) return this; + if (!other.dataSourceIds_.isEmpty()) { + if (dataSourceIds_.isEmpty()) { + dataSourceIds_ = other.dataSourceIds_; + bitField0_ |= 0x00000001; + } else { + ensureDataSourceIdsIsMutable(); + dataSourceIds_.addAll(other.dataSourceIds_); + } + onChanged(); + } + if (!other.getQuery().isEmpty()) { + query_ = other.query_; + bitField0_ |= 0x00000002; + onChanged(); + } + if (!other.getTenantName().isEmpty()) { + tenantName_ = other.tenantName_; + bitField0_ |= 0x00000004; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + java.lang.String s = input.readStringRequireUtf8(); + ensureDataSourceIdsIsMutable(); + dataSourceIds_.add(s); + break; + } // case 10 + case 18: { + query_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + case 26: { + tenantName_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000004; + break; + } // case 26 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private com.google.protobuf.LazyStringArrayList dataSourceIds_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + private void ensureDataSourceIdsIsMutable() { + if (!dataSourceIds_.isModifiable()) { + dataSourceIds_ = new com.google.protobuf.LazyStringArrayList(dataSourceIds_); + } + bitField0_ |= 0x00000001; + } + /** + * repeated string data_source_ids = 1; + * @return A list containing the dataSourceIds. + */ + public com.google.protobuf.ProtocolStringList + getDataSourceIdsList() { + dataSourceIds_.makeImmutable(); + return dataSourceIds_; + } + /** + * repeated string data_source_ids = 1; + * @return The count of dataSourceIds. + */ + public int getDataSourceIdsCount() { + return dataSourceIds_.size(); + } + /** + * repeated string data_source_ids = 1; + * @param index The index of the element to return. + * @return The dataSourceIds at the given index. + */ + public java.lang.String getDataSourceIds(int index) { + return dataSourceIds_.get(index); + } + /** + * repeated string data_source_ids = 1; + * @param index The index of the value to return. + * @return The bytes of the dataSourceIds at the given index. + */ + public com.google.protobuf.ByteString + getDataSourceIdsBytes(int index) { + return dataSourceIds_.getByteString(index); + } + /** + * repeated string data_source_ids = 1; + * @param index The index to set the value at. + * @param value The dataSourceIds to set. + * @return This builder for chaining. + */ + public Builder setDataSourceIds( + int index, java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + ensureDataSourceIdsIsMutable(); + dataSourceIds_.set(index, value); + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * repeated string data_source_ids = 1; + * @param value The dataSourceIds to add. + * @return This builder for chaining. + */ + public Builder addDataSourceIds( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + ensureDataSourceIdsIsMutable(); + dataSourceIds_.add(value); + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * repeated string data_source_ids = 1; + * @param values The dataSourceIds to add. + * @return This builder for chaining. + */ + public Builder addAllDataSourceIds( + java.lang.Iterable values) { + ensureDataSourceIdsIsMutable(); + com.google.protobuf.AbstractMessageLite.Builder.addAll( + values, dataSourceIds_); + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * repeated string data_source_ids = 1; + * @return This builder for chaining. + */ + public Builder clearDataSourceIds() { + dataSourceIds_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + bitField0_ = (bitField0_ & ~0x00000001);; + onChanged(); + return this; + } + /** + * repeated string data_source_ids = 1; + * @param value The bytes of the dataSourceIds to add. + * @return This builder for chaining. + */ + public Builder addDataSourceIdsBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + ensureDataSourceIdsIsMutable(); + dataSourceIds_.add(value); + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object query_ = ""; + /** + * string query = 2; + * @return The query. + */ + public java.lang.String getQuery() { + java.lang.Object ref = query_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + query_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string query = 2; + * @return The bytes for query. + */ + public com.google.protobuf.ByteString + getQueryBytes() { + java.lang.Object ref = query_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + query_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string query = 2; + * @param value The query to set. + * @return This builder for chaining. + */ + public Builder setQuery( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + query_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string query = 2; + * @return This builder for chaining. + */ + public Builder clearQuery() { + query_ = getDefaultInstance().getQuery(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string query = 2; + * @param value The bytes for query to set. + * @return This builder for chaining. + */ + public Builder setQueryBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + query_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + + private java.lang.Object tenantName_ = ""; + /** + * string tenant_name = 3; + * @return The tenantName. + */ + public java.lang.String getTenantName() { + java.lang.Object ref = tenantName_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenantName_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant_name = 3; + * @return The bytes for tenantName. + */ + public com.google.protobuf.ByteString + getTenantNameBytes() { + java.lang.Object ref = tenantName_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenantName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant_name = 3; + * @param value The tenantName to set. + * @return This builder for chaining. + */ + public Builder setTenantName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenantName_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + /** + * string tenant_name = 3; + * @return This builder for chaining. + */ + public Builder clearTenantName() { + tenantName_ = getDefaultInstance().getTenantName(); + bitField0_ = (bitField0_ & ~0x00000004); + onChanged(); + return this; + } + /** + * string tenant_name = 3; + * @param value The bytes for tenantName to set. + * @return This builder for chaining. + */ + public Builder setTenantNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenantName_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.ExpandQueryByDataSourceIDsRequest) + } + + // @@protoc_insertion_point(class_scope:grpc.ExpandQueryByDataSourceIDsRequest) + private static final io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest(); + } + + public static io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public ExpandQueryByDataSourceIDsRequest parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceIDsRequest getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface ExpandQueryByDataSourceInstancesIDsRequestOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.ExpandQueryByDataSourceInstancesIDsRequest) + com.google.protobuf.MessageOrBuilder { + + /** + * repeated string data_source_instances_ids = 1; + * @return A list containing the dataSourceInstancesIds. + */ + java.util.List + getDataSourceInstancesIdsList(); + /** + * repeated string data_source_instances_ids = 1; + * @return The count of dataSourceInstancesIds. + */ + int getDataSourceInstancesIdsCount(); + /** + * repeated string data_source_instances_ids = 1; + * @param index The index of the element to return. + * @return The dataSourceInstancesIds at the given index. + */ + java.lang.String getDataSourceInstancesIds(int index); + /** + * repeated string data_source_instances_ids = 1; + * @param index The index of the value to return. + * @return The bytes of the dataSourceInstancesIds at the given index. + */ + com.google.protobuf.ByteString + getDataSourceInstancesIdsBytes(int index); + + /** + * string query = 2; + * @return The query. + */ + java.lang.String getQuery(); + /** + * string query = 2; + * @return The bytes for query. + */ + com.google.protobuf.ByteString + getQueryBytes(); + + /** + * string tenant_name = 3; + * @return The tenantName. + */ + java.lang.String getTenantName(); + /** + * string tenant_name = 3; + * @return The bytes for tenantName. + */ + com.google.protobuf.ByteString + getTenantNameBytes(); + } + /** + * Protobuf type {@code grpc.ExpandQueryByDataSourceInstancesIDsRequest} + */ + public static final class ExpandQueryByDataSourceInstancesIDsRequest extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.ExpandQueryByDataSourceInstancesIDsRequest) + ExpandQueryByDataSourceInstancesIDsRequestOrBuilder { + private static final long serialVersionUID = 0L; + // Use ExpandQueryByDataSourceInstancesIDsRequest.newBuilder() to construct. + private ExpandQueryByDataSourceInstancesIDsRequest(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private ExpandQueryByDataSourceInstancesIDsRequest() { + dataSourceInstancesIds_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + query_ = ""; + tenantName_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new ExpandQueryByDataSourceInstancesIDsRequest(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_ExpandQueryByDataSourceInstancesIDsRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_ExpandQueryByDataSourceInstancesIDsRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest.class, io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest.Builder.class); + } + + public static final int DATA_SOURCE_INSTANCES_IDS_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private com.google.protobuf.LazyStringArrayList dataSourceInstancesIds_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + /** + * repeated string data_source_instances_ids = 1; + * @return A list containing the dataSourceInstancesIds. + */ + public com.google.protobuf.ProtocolStringList + getDataSourceInstancesIdsList() { + return dataSourceInstancesIds_; + } + /** + * repeated string data_source_instances_ids = 1; + * @return The count of dataSourceInstancesIds. + */ + public int getDataSourceInstancesIdsCount() { + return dataSourceInstancesIds_.size(); + } + /** + * repeated string data_source_instances_ids = 1; + * @param index The index of the element to return. + * @return The dataSourceInstancesIds at the given index. + */ + public java.lang.String getDataSourceInstancesIds(int index) { + return dataSourceInstancesIds_.get(index); + } + /** + * repeated string data_source_instances_ids = 1; + * @param index The index of the value to return. + * @return The bytes of the dataSourceInstancesIds at the given index. + */ + public com.google.protobuf.ByteString + getDataSourceInstancesIdsBytes(int index) { + return dataSourceInstancesIds_.getByteString(index); + } + + public static final int QUERY_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object query_ = ""; + /** + * string query = 2; + * @return The query. + */ + @java.lang.Override + public java.lang.String getQuery() { + java.lang.Object ref = query_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + query_ = s; + return s; + } + } + /** + * string query = 2; + * @return The bytes for query. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getQueryBytes() { + java.lang.Object ref = query_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + query_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int TENANT_NAME_FIELD_NUMBER = 3; + @SuppressWarnings("serial") + private volatile java.lang.Object tenantName_ = ""; + /** + * string tenant_name = 3; + * @return The tenantName. + */ + @java.lang.Override + public java.lang.String getTenantName() { + java.lang.Object ref = tenantName_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenantName_ = s; + return s; + } + } + /** + * string tenant_name = 3; + * @return The bytes for tenantName. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantNameBytes() { + java.lang.Object ref = tenantName_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenantName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + for (int i = 0; i < dataSourceInstancesIds_.size(); i++) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, dataSourceInstancesIds_.getRaw(i)); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(query_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, query_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenantName_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 3, tenantName_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + { + int dataSize = 0; + for (int i = 0; i < dataSourceInstancesIds_.size(); i++) { + dataSize += computeStringSizeNoTag(dataSourceInstancesIds_.getRaw(i)); + } + size += dataSize; + size += 1 * getDataSourceInstancesIdsList().size(); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(query_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, query_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenantName_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(3, tenantName_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest)) { + return super.equals(obj); + } + io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest other = (io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest) obj; + + if (!getDataSourceInstancesIdsList() + .equals(other.getDataSourceInstancesIdsList())) return false; + if (!getQuery() + .equals(other.getQuery())) return false; + if (!getTenantName() + .equals(other.getTenantName())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + if (getDataSourceInstancesIdsCount() > 0) { + hash = (37 * hash) + DATA_SOURCE_INSTANCES_IDS_FIELD_NUMBER; + hash = (53 * hash) + getDataSourceInstancesIdsList().hashCode(); + } + hash = (37 * hash) + QUERY_FIELD_NUMBER; + hash = (53 * hash) + getQuery().hashCode(); + hash = (37 * hash) + TENANT_NAME_FIELD_NUMBER; + hash = (53 * hash) + getTenantName().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.ExpandQueryByDataSourceInstancesIDsRequest} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.ExpandQueryByDataSourceInstancesIDsRequest) + io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequestOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_ExpandQueryByDataSourceInstancesIDsRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_ExpandQueryByDataSourceInstancesIDsRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest.class, io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest.Builder.class); + } + + // Construct using io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + dataSourceInstancesIds_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + query_ = ""; + tenantName_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_ExpandQueryByDataSourceInstancesIDsRequest_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest getDefaultInstanceForType() { + return io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest build() { + io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest buildPartial() { + io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest result = new io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + dataSourceInstancesIds_.makeImmutable(); + result.dataSourceInstancesIds_ = dataSourceInstancesIds_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.query_ = query_; + } + if (((from_bitField0_ & 0x00000004) != 0)) { + result.tenantName_ = tenantName_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest) { + return mergeFrom((io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest other) { + if (other == io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest.getDefaultInstance()) return this; + if (!other.dataSourceInstancesIds_.isEmpty()) { + if (dataSourceInstancesIds_.isEmpty()) { + dataSourceInstancesIds_ = other.dataSourceInstancesIds_; + bitField0_ |= 0x00000001; + } else { + ensureDataSourceInstancesIdsIsMutable(); + dataSourceInstancesIds_.addAll(other.dataSourceInstancesIds_); + } + onChanged(); + } + if (!other.getQuery().isEmpty()) { + query_ = other.query_; + bitField0_ |= 0x00000002; + onChanged(); + } + if (!other.getTenantName().isEmpty()) { + tenantName_ = other.tenantName_; + bitField0_ |= 0x00000004; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + java.lang.String s = input.readStringRequireUtf8(); + ensureDataSourceInstancesIdsIsMutable(); + dataSourceInstancesIds_.add(s); + break; + } // case 10 + case 18: { + query_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + case 26: { + tenantName_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000004; + break; + } // case 26 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private com.google.protobuf.LazyStringArrayList dataSourceInstancesIds_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + private void ensureDataSourceInstancesIdsIsMutable() { + if (!dataSourceInstancesIds_.isModifiable()) { + dataSourceInstancesIds_ = new com.google.protobuf.LazyStringArrayList(dataSourceInstancesIds_); + } + bitField0_ |= 0x00000001; + } + /** + * repeated string data_source_instances_ids = 1; + * @return A list containing the dataSourceInstancesIds. + */ + public com.google.protobuf.ProtocolStringList + getDataSourceInstancesIdsList() { + dataSourceInstancesIds_.makeImmutable(); + return dataSourceInstancesIds_; + } + /** + * repeated string data_source_instances_ids = 1; + * @return The count of dataSourceInstancesIds. + */ + public int getDataSourceInstancesIdsCount() { + return dataSourceInstancesIds_.size(); + } + /** + * repeated string data_source_instances_ids = 1; + * @param index The index of the element to return. + * @return The dataSourceInstancesIds at the given index. + */ + public java.lang.String getDataSourceInstancesIds(int index) { + return dataSourceInstancesIds_.get(index); + } + /** + * repeated string data_source_instances_ids = 1; + * @param index The index of the value to return. + * @return The bytes of the dataSourceInstancesIds at the given index. + */ + public com.google.protobuf.ByteString + getDataSourceInstancesIdsBytes(int index) { + return dataSourceInstancesIds_.getByteString(index); + } + /** + * repeated string data_source_instances_ids = 1; + * @param index The index to set the value at. + * @param value The dataSourceInstancesIds to set. + * @return This builder for chaining. + */ + public Builder setDataSourceInstancesIds( + int index, java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + ensureDataSourceInstancesIdsIsMutable(); + dataSourceInstancesIds_.set(index, value); + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * repeated string data_source_instances_ids = 1; + * @param value The dataSourceInstancesIds to add. + * @return This builder for chaining. + */ + public Builder addDataSourceInstancesIds( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + ensureDataSourceInstancesIdsIsMutable(); + dataSourceInstancesIds_.add(value); + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * repeated string data_source_instances_ids = 1; + * @param values The dataSourceInstancesIds to add. + * @return This builder for chaining. + */ + public Builder addAllDataSourceInstancesIds( + java.lang.Iterable values) { + ensureDataSourceInstancesIdsIsMutable(); + com.google.protobuf.AbstractMessageLite.Builder.addAll( + values, dataSourceInstancesIds_); + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * repeated string data_source_instances_ids = 1; + * @return This builder for chaining. + */ + public Builder clearDataSourceInstancesIds() { + dataSourceInstancesIds_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + bitField0_ = (bitField0_ & ~0x00000001);; + onChanged(); + return this; + } + /** + * repeated string data_source_instances_ids = 1; + * @param value The bytes of the dataSourceInstancesIds to add. + * @return This builder for chaining. + */ + public Builder addDataSourceInstancesIdsBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + ensureDataSourceInstancesIdsIsMutable(); + dataSourceInstancesIds_.add(value); + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object query_ = ""; + /** + * string query = 2; + * @return The query. + */ + public java.lang.String getQuery() { + java.lang.Object ref = query_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + query_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string query = 2; + * @return The bytes for query. + */ + public com.google.protobuf.ByteString + getQueryBytes() { + java.lang.Object ref = query_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + query_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string query = 2; + * @param value The query to set. + * @return This builder for chaining. + */ + public Builder setQuery( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + query_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string query = 2; + * @return This builder for chaining. + */ + public Builder clearQuery() { + query_ = getDefaultInstance().getQuery(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string query = 2; + * @param value The bytes for query to set. + * @return This builder for chaining. + */ + public Builder setQueryBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + query_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + + private java.lang.Object tenantName_ = ""; + /** + * string tenant_name = 3; + * @return The tenantName. + */ + public java.lang.String getTenantName() { + java.lang.Object ref = tenantName_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenantName_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant_name = 3; + * @return The bytes for tenantName. + */ + public com.google.protobuf.ByteString + getTenantNameBytes() { + java.lang.Object ref = tenantName_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenantName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant_name = 3; + * @param value The tenantName to set. + * @return This builder for chaining. + */ + public Builder setTenantName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenantName_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + /** + * string tenant_name = 3; + * @return This builder for chaining. + */ + public Builder clearTenantName() { + tenantName_ = getDefaultInstance().getTenantName(); + bitField0_ = (bitField0_ & ~0x00000004); + onChanged(); + return this; + } + /** + * string tenant_name = 3; + * @param value The bytes for tenantName to set. + * @return This builder for chaining. + */ + public Builder setTenantNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenantName_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.ExpandQueryByDataSourceInstancesIDsRequest) + } + + // @@protoc_insertion_point(class_scope:grpc.ExpandQueryByDataSourceInstancesIDsRequest) + private static final io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest(); + } + + public static io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public ExpandQueryByDataSourceInstancesIDsRequest parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.ExpandQueryByDataSourceInstancesIDsRequest getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface ExpandedQueryReplyOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.ExpandedQueryReply) + com.google.protobuf.MessageOrBuilder { + + /** + * string query = 1; + * @return The query. + */ + java.lang.String getQuery(); + /** + * string query = 1; + * @return The bytes for query. + */ + com.google.protobuf.ByteString + getQueryBytes(); + } + /** + * Protobuf type {@code grpc.ExpandedQueryReply} + */ + public static final class ExpandedQueryReply extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.ExpandedQueryReply) + ExpandedQueryReplyOrBuilder { + private static final long serialVersionUID = 0L; + // Use ExpandedQueryReply.newBuilder() to construct. + private ExpandedQueryReply(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private ExpandedQueryReply() { + query_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new ExpandedQueryReply(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_ExpandedQueryReply_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_ExpandedQueryReply_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.ExpandedQueryReply.class, io.trino.spi.grpc.Trinomanager.ExpandedQueryReply.Builder.class); + } + + public static final int QUERY_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object query_ = ""; + /** + * string query = 1; + * @return The query. + */ + @java.lang.Override + public java.lang.String getQuery() { + java.lang.Object ref = query_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + query_ = s; + return s; + } + } + /** + * string query = 1; + * @return The bytes for query. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getQueryBytes() { + java.lang.Object ref = query_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + query_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(query_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, query_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(query_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, query_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Trinomanager.ExpandedQueryReply)) { + return super.equals(obj); + } + io.trino.spi.grpc.Trinomanager.ExpandedQueryReply other = (io.trino.spi.grpc.Trinomanager.ExpandedQueryReply) obj; + + if (!getQuery() + .equals(other.getQuery())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + QUERY_FIELD_NUMBER; + hash = (53 * hash) + getQuery().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Trinomanager.ExpandedQueryReply parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.ExpandedQueryReply parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.ExpandedQueryReply parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.ExpandedQueryReply parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.ExpandedQueryReply parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.ExpandedQueryReply parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.ExpandedQueryReply parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.ExpandedQueryReply parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Trinomanager.ExpandedQueryReply parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Trinomanager.ExpandedQueryReply parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.ExpandedQueryReply parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.ExpandedQueryReply parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Trinomanager.ExpandedQueryReply prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.ExpandedQueryReply} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.ExpandedQueryReply) + io.trino.spi.grpc.Trinomanager.ExpandedQueryReplyOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_ExpandedQueryReply_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_ExpandedQueryReply_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.ExpandedQueryReply.class, io.trino.spi.grpc.Trinomanager.ExpandedQueryReply.Builder.class); + } + + // Construct using io.trino.spi.grpc.Trinomanager.ExpandedQueryReply.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + query_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_ExpandedQueryReply_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.ExpandedQueryReply getDefaultInstanceForType() { + return io.trino.spi.grpc.Trinomanager.ExpandedQueryReply.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.ExpandedQueryReply build() { + io.trino.spi.grpc.Trinomanager.ExpandedQueryReply result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.ExpandedQueryReply buildPartial() { + io.trino.spi.grpc.Trinomanager.ExpandedQueryReply result = new io.trino.spi.grpc.Trinomanager.ExpandedQueryReply(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Trinomanager.ExpandedQueryReply result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.query_ = query_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Trinomanager.ExpandedQueryReply) { + return mergeFrom((io.trino.spi.grpc.Trinomanager.ExpandedQueryReply)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Trinomanager.ExpandedQueryReply other) { + if (other == io.trino.spi.grpc.Trinomanager.ExpandedQueryReply.getDefaultInstance()) return this; + if (!other.getQuery().isEmpty()) { + query_ = other.query_; + bitField0_ |= 0x00000001; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + query_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object query_ = ""; + /** + * string query = 1; + * @return The query. + */ + public java.lang.String getQuery() { + java.lang.Object ref = query_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + query_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string query = 1; + * @return The bytes for query. + */ + public com.google.protobuf.ByteString + getQueryBytes() { + java.lang.Object ref = query_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + query_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string query = 1; + * @param value The query to set. + * @return This builder for chaining. + */ + public Builder setQuery( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + query_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string query = 1; + * @return This builder for chaining. + */ + public Builder clearQuery() { + query_ = getDefaultInstance().getQuery(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string query = 1; + * @param value The bytes for query to set. + * @return This builder for chaining. + */ + public Builder setQueryBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + query_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.ExpandedQueryReply) + } + + // @@protoc_insertion_point(class_scope:grpc.ExpandedQueryReply) + private static final io.trino.spi.grpc.Trinomanager.ExpandedQueryReply DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Trinomanager.ExpandedQueryReply(); + } + + public static io.trino.spi.grpc.Trinomanager.ExpandedQueryReply getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public ExpandedQueryReply parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.ExpandedQueryReply getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface DataSourceRequestOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.DataSourceRequest) + com.google.protobuf.MessageOrBuilder { + + /** + * string name = 1; + * @return The name. + */ + java.lang.String getName(); + /** + * string name = 1; + * @return The bytes for name. + */ + com.google.protobuf.ByteString + getNameBytes(); + + /** + * string storageName = 2; + * @return The storageName. + */ + java.lang.String getStorageName(); + /** + * string storageName = 2; + * @return The bytes for storageName. + */ + com.google.protobuf.ByteString + getStorageNameBytes(); + } + /** + * Protobuf type {@code grpc.DataSourceRequest} + */ + public static final class DataSourceRequest extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.DataSourceRequest) + DataSourceRequestOrBuilder { + private static final long serialVersionUID = 0L; + // Use DataSourceRequest.newBuilder() to construct. + private DataSourceRequest(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private DataSourceRequest() { + name_ = ""; + storageName_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new DataSourceRequest(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_DataSourceRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_DataSourceRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.DataSourceRequest.class, io.trino.spi.grpc.Trinomanager.DataSourceRequest.Builder.class); + } + + public static final int NAME_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object name_ = ""; + /** + * string name = 1; + * @return The name. + */ + @java.lang.Override + public java.lang.String getName() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } + } + /** + * string name = 1; + * @return The bytes for name. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int STORAGENAME_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object storageName_ = ""; + /** + * string storageName = 2; + * @return The storageName. + */ + @java.lang.Override + public java.lang.String getStorageName() { + java.lang.Object ref = storageName_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + storageName_ = s; + return s; + } + } + /** + * string storageName = 2; + * @return The bytes for storageName. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getStorageNameBytes() { + java.lang.Object ref = storageName_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + storageName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(name_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, name_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(storageName_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, storageName_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(name_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, name_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(storageName_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, storageName_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Trinomanager.DataSourceRequest)) { + return super.equals(obj); + } + io.trino.spi.grpc.Trinomanager.DataSourceRequest other = (io.trino.spi.grpc.Trinomanager.DataSourceRequest) obj; + + if (!getName() + .equals(other.getName())) return false; + if (!getStorageName() + .equals(other.getStorageName())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + NAME_FIELD_NUMBER; + hash = (53 * hash) + getName().hashCode(); + hash = (37 * hash) + STORAGENAME_FIELD_NUMBER; + hash = (53 * hash) + getStorageName().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Trinomanager.DataSourceRequest parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.DataSourceRequest parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.DataSourceRequest parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.DataSourceRequest parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.DataSourceRequest parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.DataSourceRequest parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.DataSourceRequest parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.DataSourceRequest parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Trinomanager.DataSourceRequest parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Trinomanager.DataSourceRequest parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.DataSourceRequest parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.DataSourceRequest parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Trinomanager.DataSourceRequest prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.DataSourceRequest} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.DataSourceRequest) + io.trino.spi.grpc.Trinomanager.DataSourceRequestOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_DataSourceRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_DataSourceRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.DataSourceRequest.class, io.trino.spi.grpc.Trinomanager.DataSourceRequest.Builder.class); + } + + // Construct using io.trino.spi.grpc.Trinomanager.DataSourceRequest.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + name_ = ""; + storageName_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_DataSourceRequest_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.DataSourceRequest getDefaultInstanceForType() { + return io.trino.spi.grpc.Trinomanager.DataSourceRequest.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.DataSourceRequest build() { + io.trino.spi.grpc.Trinomanager.DataSourceRequest result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.DataSourceRequest buildPartial() { + io.trino.spi.grpc.Trinomanager.DataSourceRequest result = new io.trino.spi.grpc.Trinomanager.DataSourceRequest(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Trinomanager.DataSourceRequest result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.name_ = name_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.storageName_ = storageName_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Trinomanager.DataSourceRequest) { + return mergeFrom((io.trino.spi.grpc.Trinomanager.DataSourceRequest)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Trinomanager.DataSourceRequest other) { + if (other == io.trino.spi.grpc.Trinomanager.DataSourceRequest.getDefaultInstance()) return this; + if (!other.getName().isEmpty()) { + name_ = other.name_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getStorageName().isEmpty()) { + storageName_ = other.storageName_; + bitField0_ |= 0x00000002; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + name_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + storageName_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object name_ = ""; + /** + * string name = 1; + * @return The name. + */ + public java.lang.String getName() { + java.lang.Object ref = name_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string name = 1; + * @return The bytes for name. + */ + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string name = 1; + * @param value The name to set. + * @return This builder for chaining. + */ + public Builder setName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + name_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string name = 1; + * @return This builder for chaining. + */ + public Builder clearName() { + name_ = getDefaultInstance().getName(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string name = 1; + * @param value The bytes for name to set. + * @return This builder for chaining. + */ + public Builder setNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + name_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object storageName_ = ""; + /** + * string storageName = 2; + * @return The storageName. + */ + public java.lang.String getStorageName() { + java.lang.Object ref = storageName_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + storageName_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string storageName = 2; + * @return The bytes for storageName. + */ + public com.google.protobuf.ByteString + getStorageNameBytes() { + java.lang.Object ref = storageName_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + storageName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string storageName = 2; + * @param value The storageName to set. + * @return This builder for chaining. + */ + public Builder setStorageName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + storageName_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string storageName = 2; + * @return This builder for chaining. + */ + public Builder clearStorageName() { + storageName_ = getDefaultInstance().getStorageName(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string storageName = 2; + * @param value The bytes for storageName to set. + * @return This builder for chaining. + */ + public Builder setStorageNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + storageName_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.DataSourceRequest) + } + + // @@protoc_insertion_point(class_scope:grpc.DataSourceRequest) + private static final io.trino.spi.grpc.Trinomanager.DataSourceRequest DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Trinomanager.DataSourceRequest(); + } + + public static io.trino.spi.grpc.Trinomanager.DataSourceRequest getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public DataSourceRequest parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.DataSourceRequest getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface ExecuteQueryNotebookMetadataOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.ExecuteQueryNotebookMetadata) + com.google.protobuf.MessageOrBuilder { + + /** + * string tenant = 1; + * @return The tenant. + */ + java.lang.String getTenant(); + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + com.google.protobuf.ByteString + getTenantBytes(); + + /** + * string notebook_id = 2; + * @return The notebookId. + */ + java.lang.String getNotebookId(); + /** + * string notebook_id = 2; + * @return The bytes for notebookId. + */ + com.google.protobuf.ByteString + getNotebookIdBytes(); + + /** + * int32 notebook_version = 3; + * @return The notebookVersion. + */ + int getNotebookVersion(); + + /** + * string notebook_cell_id = 4; + * @return The notebookCellId. + */ + java.lang.String getNotebookCellId(); + /** + * string notebook_cell_id = 4; + * @return The bytes for notebookCellId. + */ + com.google.protobuf.ByteString + getNotebookCellIdBytes(); + } + /** + * Protobuf type {@code grpc.ExecuteQueryNotebookMetadata} + */ + public static final class ExecuteQueryNotebookMetadata extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.ExecuteQueryNotebookMetadata) + ExecuteQueryNotebookMetadataOrBuilder { + private static final long serialVersionUID = 0L; + // Use ExecuteQueryNotebookMetadata.newBuilder() to construct. + private ExecuteQueryNotebookMetadata(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private ExecuteQueryNotebookMetadata() { + tenant_ = ""; + notebookId_ = ""; + notebookCellId_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new ExecuteQueryNotebookMetadata(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_ExecuteQueryNotebookMetadata_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_ExecuteQueryNotebookMetadata_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata.class, io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata.Builder.class); + } + + public static final int TENANT_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + @java.lang.Override + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int NOTEBOOK_ID_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object notebookId_ = ""; + /** + * string notebook_id = 2; + * @return The notebookId. + */ + @java.lang.Override + public java.lang.String getNotebookId() { + java.lang.Object ref = notebookId_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + notebookId_ = s; + return s; + } + } + /** + * string notebook_id = 2; + * @return The bytes for notebookId. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getNotebookIdBytes() { + java.lang.Object ref = notebookId_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + notebookId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int NOTEBOOK_VERSION_FIELD_NUMBER = 3; + private int notebookVersion_ = 0; + /** + * int32 notebook_version = 3; + * @return The notebookVersion. + */ + @java.lang.Override + public int getNotebookVersion() { + return notebookVersion_; + } + + public static final int NOTEBOOK_CELL_ID_FIELD_NUMBER = 4; + @SuppressWarnings("serial") + private volatile java.lang.Object notebookCellId_ = ""; + /** + * string notebook_cell_id = 4; + * @return The notebookCellId. + */ + @java.lang.Override + public java.lang.String getNotebookCellId() { + java.lang.Object ref = notebookCellId_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + notebookCellId_ = s; + return s; + } + } + /** + * string notebook_cell_id = 4; + * @return The bytes for notebookCellId. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getNotebookCellIdBytes() { + java.lang.Object ref = notebookCellId_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + notebookCellId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(notebookId_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, notebookId_); + } + if (notebookVersion_ != 0) { + output.writeInt32(3, notebookVersion_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(notebookCellId_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 4, notebookCellId_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(notebookId_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, notebookId_); + } + if (notebookVersion_ != 0) { + size += com.google.protobuf.CodedOutputStream + .computeInt32Size(3, notebookVersion_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(notebookCellId_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(4, notebookCellId_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata)) { + return super.equals(obj); + } + io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata other = (io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata) obj; + + if (!getTenant() + .equals(other.getTenant())) return false; + if (!getNotebookId() + .equals(other.getNotebookId())) return false; + if (getNotebookVersion() + != other.getNotebookVersion()) return false; + if (!getNotebookCellId() + .equals(other.getNotebookCellId())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + TENANT_FIELD_NUMBER; + hash = (53 * hash) + getTenant().hashCode(); + hash = (37 * hash) + NOTEBOOK_ID_FIELD_NUMBER; + hash = (53 * hash) + getNotebookId().hashCode(); + hash = (37 * hash) + NOTEBOOK_VERSION_FIELD_NUMBER; + hash = (53 * hash) + getNotebookVersion(); + hash = (37 * hash) + NOTEBOOK_CELL_ID_FIELD_NUMBER; + hash = (53 * hash) + getNotebookCellId().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.ExecuteQueryNotebookMetadata} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.ExecuteQueryNotebookMetadata) + io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadataOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_ExecuteQueryNotebookMetadata_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_ExecuteQueryNotebookMetadata_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata.class, io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata.Builder.class); + } + + // Construct using io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + tenant_ = ""; + notebookId_ = ""; + notebookVersion_ = 0; + notebookCellId_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_ExecuteQueryNotebookMetadata_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata getDefaultInstanceForType() { + return io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata build() { + io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata buildPartial() { + io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata result = new io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.tenant_ = tenant_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.notebookId_ = notebookId_; + } + if (((from_bitField0_ & 0x00000004) != 0)) { + result.notebookVersion_ = notebookVersion_; + } + if (((from_bitField0_ & 0x00000008) != 0)) { + result.notebookCellId_ = notebookCellId_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata) { + return mergeFrom((io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata other) { + if (other == io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata.getDefaultInstance()) return this; + if (!other.getTenant().isEmpty()) { + tenant_ = other.tenant_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getNotebookId().isEmpty()) { + notebookId_ = other.notebookId_; + bitField0_ |= 0x00000002; + onChanged(); + } + if (other.getNotebookVersion() != 0) { + setNotebookVersion(other.getNotebookVersion()); + } + if (!other.getNotebookCellId().isEmpty()) { + notebookCellId_ = other.notebookCellId_; + bitField0_ |= 0x00000008; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + tenant_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + notebookId_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + case 24: { + notebookVersion_ = input.readInt32(); + bitField0_ |= 0x00000004; + break; + } // case 24 + case 34: { + notebookCellId_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000008; + break; + } // case 34 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant = 1; + * @param value The tenant to set. + * @return This builder for chaining. + */ + public Builder setTenant( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string tenant = 1; + * @return This builder for chaining. + */ + public Builder clearTenant() { + tenant_ = getDefaultInstance().getTenant(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string tenant = 1; + * @param value The bytes for tenant to set. + * @return This builder for chaining. + */ + public Builder setTenantBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object notebookId_ = ""; + /** + * string notebook_id = 2; + * @return The notebookId. + */ + public java.lang.String getNotebookId() { + java.lang.Object ref = notebookId_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + notebookId_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string notebook_id = 2; + * @return The bytes for notebookId. + */ + public com.google.protobuf.ByteString + getNotebookIdBytes() { + java.lang.Object ref = notebookId_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + notebookId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string notebook_id = 2; + * @param value The notebookId to set. + * @return This builder for chaining. + */ + public Builder setNotebookId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + notebookId_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string notebook_id = 2; + * @return This builder for chaining. + */ + public Builder clearNotebookId() { + notebookId_ = getDefaultInstance().getNotebookId(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string notebook_id = 2; + * @param value The bytes for notebookId to set. + * @return This builder for chaining. + */ + public Builder setNotebookIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + notebookId_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + + private int notebookVersion_ ; + /** + * int32 notebook_version = 3; + * @return The notebookVersion. + */ + @java.lang.Override + public int getNotebookVersion() { + return notebookVersion_; + } + /** + * int32 notebook_version = 3; + * @param value The notebookVersion to set. + * @return This builder for chaining. + */ + public Builder setNotebookVersion(int value) { + + notebookVersion_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + /** + * int32 notebook_version = 3; + * @return This builder for chaining. + */ + public Builder clearNotebookVersion() { + bitField0_ = (bitField0_ & ~0x00000004); + notebookVersion_ = 0; + onChanged(); + return this; + } + + private java.lang.Object notebookCellId_ = ""; + /** + * string notebook_cell_id = 4; + * @return The notebookCellId. + */ + public java.lang.String getNotebookCellId() { + java.lang.Object ref = notebookCellId_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + notebookCellId_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string notebook_cell_id = 4; + * @return The bytes for notebookCellId. + */ + public com.google.protobuf.ByteString + getNotebookCellIdBytes() { + java.lang.Object ref = notebookCellId_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + notebookCellId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string notebook_cell_id = 4; + * @param value The notebookCellId to set. + * @return This builder for chaining. + */ + public Builder setNotebookCellId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + notebookCellId_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + /** + * string notebook_cell_id = 4; + * @return This builder for chaining. + */ + public Builder clearNotebookCellId() { + notebookCellId_ = getDefaultInstance().getNotebookCellId(); + bitField0_ = (bitField0_ & ~0x00000008); + onChanged(); + return this; + } + /** + * string notebook_cell_id = 4; + * @param value The bytes for notebookCellId to set. + * @return This builder for chaining. + */ + public Builder setNotebookCellIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + notebookCellId_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.ExecuteQueryNotebookMetadata) + } + + // @@protoc_insertion_point(class_scope:grpc.ExecuteQueryNotebookMetadata) + private static final io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata(); + } + + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public ExecuteQueryNotebookMetadata parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface ExecuteQueryRequestOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.ExecuteQueryRequest) + com.google.protobuf.MessageOrBuilder { + + /** + * string tenant_name = 1; + * @return The tenantName. + */ + java.lang.String getTenantName(); + /** + * string tenant_name = 1; + * @return The bytes for tenantName. + */ + com.google.protobuf.ByteString + getTenantNameBytes(); + + /** + * string sql_query = 2; + * @return The sqlQuery. + */ + java.lang.String getSqlQuery(); + /** + * string sql_query = 2; + * @return The bytes for sqlQuery. + */ + com.google.protobuf.ByteString + getSqlQueryBytes(); + + /** + * string query_id = 3; + * @return The queryId. + */ + java.lang.String getQueryId(); + /** + * string query_id = 3; + * @return The bytes for queryId. + */ + com.google.protobuf.ByteString + getQueryIdBytes(); + + /** + * repeated .grpc.DataSourceRequest data_sources = 4; + */ + java.util.List + getDataSourcesList(); + /** + * repeated .grpc.DataSourceRequest data_sources = 4; + */ + io.trino.spi.grpc.Trinomanager.DataSourceRequest getDataSources(int index); + /** + * repeated .grpc.DataSourceRequest data_sources = 4; + */ + int getDataSourcesCount(); + /** + * repeated .grpc.DataSourceRequest data_sources = 4; + */ + java.util.List + getDataSourcesOrBuilderList(); + /** + * repeated .grpc.DataSourceRequest data_sources = 4; + */ + io.trino.spi.grpc.Trinomanager.DataSourceRequestOrBuilder getDataSourcesOrBuilder( + int index); + + /** + * optional .grpc.ExecuteQueryNotebookMetadata notebook_metadata = 5; + * @return Whether the notebookMetadata field is set. + */ + boolean hasNotebookMetadata(); + /** + * optional .grpc.ExecuteQueryNotebookMetadata notebook_metadata = 5; + * @return The notebookMetadata. + */ + io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata getNotebookMetadata(); + /** + * optional .grpc.ExecuteQueryNotebookMetadata notebook_metadata = 5; + */ + io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadataOrBuilder getNotebookMetadataOrBuilder(); + + /** + * optional string timespan = 6; + * @return Whether the timespan field is set. + */ + boolean hasTimespan(); + /** + * optional string timespan = 6; + * @return The timespan. + */ + java.lang.String getTimespan(); + /** + * optional string timespan = 6; + * @return The bytes for timespan. + */ + com.google.protobuf.ByteString + getTimespanBytes(); + + /** + * string trino_header_query_id = 7; + * @return The trinoHeaderQueryId. + */ + java.lang.String getTrinoHeaderQueryId(); + /** + * string trino_header_query_id = 7; + * @return The bytes for trinoHeaderQueryId. + */ + com.google.protobuf.ByteString + getTrinoHeaderQueryIdBytes(); + + /** + * string user_email = 8; + * @return The userEmail. + */ + java.lang.String getUserEmail(); + /** + * string user_email = 8; + * @return The bytes for userEmail. + */ + com.google.protobuf.ByteString + getUserEmailBytes(); + } + /** + * Protobuf type {@code grpc.ExecuteQueryRequest} + */ + public static final class ExecuteQueryRequest extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.ExecuteQueryRequest) + ExecuteQueryRequestOrBuilder { + private static final long serialVersionUID = 0L; + // Use ExecuteQueryRequest.newBuilder() to construct. + private ExecuteQueryRequest(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private ExecuteQueryRequest() { + tenantName_ = ""; + sqlQuery_ = ""; + queryId_ = ""; + dataSources_ = java.util.Collections.emptyList(); + timespan_ = ""; + trinoHeaderQueryId_ = ""; + userEmail_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new ExecuteQueryRequest(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_ExecuteQueryRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_ExecuteQueryRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest.class, io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest.Builder.class); + } + + private int bitField0_; + public static final int TENANT_NAME_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object tenantName_ = ""; + /** + * string tenant_name = 1; + * @return The tenantName. + */ + @java.lang.Override + public java.lang.String getTenantName() { + java.lang.Object ref = tenantName_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenantName_ = s; + return s; + } + } + /** + * string tenant_name = 1; + * @return The bytes for tenantName. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantNameBytes() { + java.lang.Object ref = tenantName_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenantName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int SQL_QUERY_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object sqlQuery_ = ""; + /** + * string sql_query = 2; + * @return The sqlQuery. + */ + @java.lang.Override + public java.lang.String getSqlQuery() { + java.lang.Object ref = sqlQuery_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + sqlQuery_ = s; + return s; + } + } + /** + * string sql_query = 2; + * @return The bytes for sqlQuery. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getSqlQueryBytes() { + java.lang.Object ref = sqlQuery_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + sqlQuery_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int QUERY_ID_FIELD_NUMBER = 3; + @SuppressWarnings("serial") + private volatile java.lang.Object queryId_ = ""; + /** + * string query_id = 3; + * @return The queryId. + */ + @java.lang.Override + public java.lang.String getQueryId() { + java.lang.Object ref = queryId_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + queryId_ = s; + return s; + } + } + /** + * string query_id = 3; + * @return The bytes for queryId. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getQueryIdBytes() { + java.lang.Object ref = queryId_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + queryId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int DATA_SOURCES_FIELD_NUMBER = 4; + @SuppressWarnings("serial") + private java.util.List dataSources_; + /** + * repeated .grpc.DataSourceRequest data_sources = 4; + */ + @java.lang.Override + public java.util.List getDataSourcesList() { + return dataSources_; + } + /** + * repeated .grpc.DataSourceRequest data_sources = 4; + */ + @java.lang.Override + public java.util.List + getDataSourcesOrBuilderList() { + return dataSources_; + } + /** + * repeated .grpc.DataSourceRequest data_sources = 4; + */ + @java.lang.Override + public int getDataSourcesCount() { + return dataSources_.size(); + } + /** + * repeated .grpc.DataSourceRequest data_sources = 4; + */ + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.DataSourceRequest getDataSources(int index) { + return dataSources_.get(index); + } + /** + * repeated .grpc.DataSourceRequest data_sources = 4; + */ + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.DataSourceRequestOrBuilder getDataSourcesOrBuilder( + int index) { + return dataSources_.get(index); + } + + public static final int NOTEBOOK_METADATA_FIELD_NUMBER = 5; + private io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata notebookMetadata_; + /** + * optional .grpc.ExecuteQueryNotebookMetadata notebook_metadata = 5; + * @return Whether the notebookMetadata field is set. + */ + @java.lang.Override + public boolean hasNotebookMetadata() { + return ((bitField0_ & 0x00000001) != 0); + } + /** + * optional .grpc.ExecuteQueryNotebookMetadata notebook_metadata = 5; + * @return The notebookMetadata. + */ + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata getNotebookMetadata() { + return notebookMetadata_ == null ? io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata.getDefaultInstance() : notebookMetadata_; + } + /** + * optional .grpc.ExecuteQueryNotebookMetadata notebook_metadata = 5; + */ + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadataOrBuilder getNotebookMetadataOrBuilder() { + return notebookMetadata_ == null ? io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata.getDefaultInstance() : notebookMetadata_; + } + + public static final int TIMESPAN_FIELD_NUMBER = 6; + @SuppressWarnings("serial") + private volatile java.lang.Object timespan_ = ""; + /** + * optional string timespan = 6; + * @return Whether the timespan field is set. + */ + @java.lang.Override + public boolean hasTimespan() { + return ((bitField0_ & 0x00000002) != 0); + } + /** + * optional string timespan = 6; + * @return The timespan. + */ + @java.lang.Override + public java.lang.String getTimespan() { + java.lang.Object ref = timespan_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + timespan_ = s; + return s; + } + } + /** + * optional string timespan = 6; + * @return The bytes for timespan. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTimespanBytes() { + java.lang.Object ref = timespan_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + timespan_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int TRINO_HEADER_QUERY_ID_FIELD_NUMBER = 7; + @SuppressWarnings("serial") + private volatile java.lang.Object trinoHeaderQueryId_ = ""; + /** + * string trino_header_query_id = 7; + * @return The trinoHeaderQueryId. + */ + @java.lang.Override + public java.lang.String getTrinoHeaderQueryId() { + java.lang.Object ref = trinoHeaderQueryId_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + trinoHeaderQueryId_ = s; + return s; + } + } + /** + * string trino_header_query_id = 7; + * @return The bytes for trinoHeaderQueryId. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTrinoHeaderQueryIdBytes() { + java.lang.Object ref = trinoHeaderQueryId_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + trinoHeaderQueryId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int USER_EMAIL_FIELD_NUMBER = 8; + @SuppressWarnings("serial") + private volatile java.lang.Object userEmail_ = ""; + /** + * string user_email = 8; + * @return The userEmail. + */ + @java.lang.Override + public java.lang.String getUserEmail() { + java.lang.Object ref = userEmail_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + userEmail_ = s; + return s; + } + } + /** + * string user_email = 8; + * @return The bytes for userEmail. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getUserEmailBytes() { + java.lang.Object ref = userEmail_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + userEmail_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenantName_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, tenantName_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(sqlQuery_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, sqlQuery_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(queryId_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 3, queryId_); + } + for (int i = 0; i < dataSources_.size(); i++) { + output.writeMessage(4, dataSources_.get(i)); + } + if (((bitField0_ & 0x00000001) != 0)) { + output.writeMessage(5, getNotebookMetadata()); + } + if (((bitField0_ & 0x00000002) != 0)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 6, timespan_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(trinoHeaderQueryId_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 7, trinoHeaderQueryId_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(userEmail_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 8, userEmail_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenantName_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, tenantName_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(sqlQuery_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, sqlQuery_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(queryId_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(3, queryId_); + } + for (int i = 0; i < dataSources_.size(); i++) { + size += com.google.protobuf.CodedOutputStream + .computeMessageSize(4, dataSources_.get(i)); + } + if (((bitField0_ & 0x00000001) != 0)) { + size += com.google.protobuf.CodedOutputStream + .computeMessageSize(5, getNotebookMetadata()); + } + if (((bitField0_ & 0x00000002) != 0)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(6, timespan_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(trinoHeaderQueryId_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(7, trinoHeaderQueryId_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(userEmail_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(8, userEmail_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest)) { + return super.equals(obj); + } + io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest other = (io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest) obj; + + if (!getTenantName() + .equals(other.getTenantName())) return false; + if (!getSqlQuery() + .equals(other.getSqlQuery())) return false; + if (!getQueryId() + .equals(other.getQueryId())) return false; + if (!getDataSourcesList() + .equals(other.getDataSourcesList())) return false; + if (hasNotebookMetadata() != other.hasNotebookMetadata()) return false; + if (hasNotebookMetadata()) { + if (!getNotebookMetadata() + .equals(other.getNotebookMetadata())) return false; + } + if (hasTimespan() != other.hasTimespan()) return false; + if (hasTimespan()) { + if (!getTimespan() + .equals(other.getTimespan())) return false; + } + if (!getTrinoHeaderQueryId() + .equals(other.getTrinoHeaderQueryId())) return false; + if (!getUserEmail() + .equals(other.getUserEmail())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + TENANT_NAME_FIELD_NUMBER; + hash = (53 * hash) + getTenantName().hashCode(); + hash = (37 * hash) + SQL_QUERY_FIELD_NUMBER; + hash = (53 * hash) + getSqlQuery().hashCode(); + hash = (37 * hash) + QUERY_ID_FIELD_NUMBER; + hash = (53 * hash) + getQueryId().hashCode(); + if (getDataSourcesCount() > 0) { + hash = (37 * hash) + DATA_SOURCES_FIELD_NUMBER; + hash = (53 * hash) + getDataSourcesList().hashCode(); + } + if (hasNotebookMetadata()) { + hash = (37 * hash) + NOTEBOOK_METADATA_FIELD_NUMBER; + hash = (53 * hash) + getNotebookMetadata().hashCode(); + } + if (hasTimespan()) { + hash = (37 * hash) + TIMESPAN_FIELD_NUMBER; + hash = (53 * hash) + getTimespan().hashCode(); + } + hash = (37 * hash) + TRINO_HEADER_QUERY_ID_FIELD_NUMBER; + hash = (53 * hash) + getTrinoHeaderQueryId().hashCode(); + hash = (37 * hash) + USER_EMAIL_FIELD_NUMBER; + hash = (53 * hash) + getUserEmail().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.ExecuteQueryRequest} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.ExecuteQueryRequest) + io.trino.spi.grpc.Trinomanager.ExecuteQueryRequestOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_ExecuteQueryRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_ExecuteQueryRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest.class, io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest.Builder.class); + } + + // Construct using io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest.newBuilder() + private Builder() { + maybeForceBuilderInitialization(); + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + maybeForceBuilderInitialization(); + } + private void maybeForceBuilderInitialization() { + if (com.google.protobuf.GeneratedMessageV3 + .alwaysUseFieldBuilders) { + getDataSourcesFieldBuilder(); + getNotebookMetadataFieldBuilder(); + } + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + tenantName_ = ""; + sqlQuery_ = ""; + queryId_ = ""; + if (dataSourcesBuilder_ == null) { + dataSources_ = java.util.Collections.emptyList(); + } else { + dataSources_ = null; + dataSourcesBuilder_.clear(); + } + bitField0_ = (bitField0_ & ~0x00000008); + notebookMetadata_ = null; + if (notebookMetadataBuilder_ != null) { + notebookMetadataBuilder_.dispose(); + notebookMetadataBuilder_ = null; + } + timespan_ = ""; + trinoHeaderQueryId_ = ""; + userEmail_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_ExecuteQueryRequest_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest getDefaultInstanceForType() { + return io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest build() { + io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest buildPartial() { + io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest result = new io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest(this); + buildPartialRepeatedFields(result); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartialRepeatedFields(io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest result) { + if (dataSourcesBuilder_ == null) { + if (((bitField0_ & 0x00000008) != 0)) { + dataSources_ = java.util.Collections.unmodifiableList(dataSources_); + bitField0_ = (bitField0_ & ~0x00000008); + } + result.dataSources_ = dataSources_; + } else { + result.dataSources_ = dataSourcesBuilder_.build(); + } + } + + private void buildPartial0(io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.tenantName_ = tenantName_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.sqlQuery_ = sqlQuery_; + } + if (((from_bitField0_ & 0x00000004) != 0)) { + result.queryId_ = queryId_; + } + int to_bitField0_ = 0; + if (((from_bitField0_ & 0x00000010) != 0)) { + result.notebookMetadata_ = notebookMetadataBuilder_ == null + ? notebookMetadata_ + : notebookMetadataBuilder_.build(); + to_bitField0_ |= 0x00000001; + } + if (((from_bitField0_ & 0x00000020) != 0)) { + result.timespan_ = timespan_; + to_bitField0_ |= 0x00000002; + } + if (((from_bitField0_ & 0x00000040) != 0)) { + result.trinoHeaderQueryId_ = trinoHeaderQueryId_; + } + if (((from_bitField0_ & 0x00000080) != 0)) { + result.userEmail_ = userEmail_; + } + result.bitField0_ |= to_bitField0_; + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest) { + return mergeFrom((io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest other) { + if (other == io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest.getDefaultInstance()) return this; + if (!other.getTenantName().isEmpty()) { + tenantName_ = other.tenantName_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getSqlQuery().isEmpty()) { + sqlQuery_ = other.sqlQuery_; + bitField0_ |= 0x00000002; + onChanged(); + } + if (!other.getQueryId().isEmpty()) { + queryId_ = other.queryId_; + bitField0_ |= 0x00000004; + onChanged(); + } + if (dataSourcesBuilder_ == null) { + if (!other.dataSources_.isEmpty()) { + if (dataSources_.isEmpty()) { + dataSources_ = other.dataSources_; + bitField0_ = (bitField0_ & ~0x00000008); + } else { + ensureDataSourcesIsMutable(); + dataSources_.addAll(other.dataSources_); + } + onChanged(); + } + } else { + if (!other.dataSources_.isEmpty()) { + if (dataSourcesBuilder_.isEmpty()) { + dataSourcesBuilder_.dispose(); + dataSourcesBuilder_ = null; + dataSources_ = other.dataSources_; + bitField0_ = (bitField0_ & ~0x00000008); + dataSourcesBuilder_ = + com.google.protobuf.GeneratedMessageV3.alwaysUseFieldBuilders ? + getDataSourcesFieldBuilder() : null; + } else { + dataSourcesBuilder_.addAllMessages(other.dataSources_); + } + } + } + if (other.hasNotebookMetadata()) { + mergeNotebookMetadata(other.getNotebookMetadata()); + } + if (other.hasTimespan()) { + timespan_ = other.timespan_; + bitField0_ |= 0x00000020; + onChanged(); + } + if (!other.getTrinoHeaderQueryId().isEmpty()) { + trinoHeaderQueryId_ = other.trinoHeaderQueryId_; + bitField0_ |= 0x00000040; + onChanged(); + } + if (!other.getUserEmail().isEmpty()) { + userEmail_ = other.userEmail_; + bitField0_ |= 0x00000080; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + tenantName_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + sqlQuery_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + case 26: { + queryId_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000004; + break; + } // case 26 + case 34: { + io.trino.spi.grpc.Trinomanager.DataSourceRequest m = + input.readMessage( + io.trino.spi.grpc.Trinomanager.DataSourceRequest.parser(), + extensionRegistry); + if (dataSourcesBuilder_ == null) { + ensureDataSourcesIsMutable(); + dataSources_.add(m); + } else { + dataSourcesBuilder_.addMessage(m); + } + break; + } // case 34 + case 42: { + input.readMessage( + getNotebookMetadataFieldBuilder().getBuilder(), + extensionRegistry); + bitField0_ |= 0x00000010; + break; + } // case 42 + case 50: { + timespan_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000020; + break; + } // case 50 + case 58: { + trinoHeaderQueryId_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000040; + break; + } // case 58 + case 66: { + userEmail_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000080; + break; + } // case 66 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object tenantName_ = ""; + /** + * string tenant_name = 1; + * @return The tenantName. + */ + public java.lang.String getTenantName() { + java.lang.Object ref = tenantName_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenantName_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant_name = 1; + * @return The bytes for tenantName. + */ + public com.google.protobuf.ByteString + getTenantNameBytes() { + java.lang.Object ref = tenantName_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenantName_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant_name = 1; + * @param value The tenantName to set. + * @return This builder for chaining. + */ + public Builder setTenantName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenantName_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string tenant_name = 1; + * @return This builder for chaining. + */ + public Builder clearTenantName() { + tenantName_ = getDefaultInstance().getTenantName(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string tenant_name = 1; + * @param value The bytes for tenantName to set. + * @return This builder for chaining. + */ + public Builder setTenantNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenantName_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object sqlQuery_ = ""; + /** + * string sql_query = 2; + * @return The sqlQuery. + */ + public java.lang.String getSqlQuery() { + java.lang.Object ref = sqlQuery_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + sqlQuery_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string sql_query = 2; + * @return The bytes for sqlQuery. + */ + public com.google.protobuf.ByteString + getSqlQueryBytes() { + java.lang.Object ref = sqlQuery_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + sqlQuery_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string sql_query = 2; + * @param value The sqlQuery to set. + * @return This builder for chaining. + */ + public Builder setSqlQuery( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + sqlQuery_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string sql_query = 2; + * @return This builder for chaining. + */ + public Builder clearSqlQuery() { + sqlQuery_ = getDefaultInstance().getSqlQuery(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string sql_query = 2; + * @param value The bytes for sqlQuery to set. + * @return This builder for chaining. + */ + public Builder setSqlQueryBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + sqlQuery_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + + private java.lang.Object queryId_ = ""; + /** + * string query_id = 3; + * @return The queryId. + */ + public java.lang.String getQueryId() { + java.lang.Object ref = queryId_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + queryId_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string query_id = 3; + * @return The bytes for queryId. + */ + public com.google.protobuf.ByteString + getQueryIdBytes() { + java.lang.Object ref = queryId_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + queryId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string query_id = 3; + * @param value The queryId to set. + * @return This builder for chaining. + */ + public Builder setQueryId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + queryId_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + /** + * string query_id = 3; + * @return This builder for chaining. + */ + public Builder clearQueryId() { + queryId_ = getDefaultInstance().getQueryId(); + bitField0_ = (bitField0_ & ~0x00000004); + onChanged(); + return this; + } + /** + * string query_id = 3; + * @param value The bytes for queryId to set. + * @return This builder for chaining. + */ + public Builder setQueryIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + queryId_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + + private java.util.List dataSources_ = + java.util.Collections.emptyList(); + private void ensureDataSourcesIsMutable() { + if (!((bitField0_ & 0x00000008) != 0)) { + dataSources_ = new java.util.ArrayList(dataSources_); + bitField0_ |= 0x00000008; + } + } + + private com.google.protobuf.RepeatedFieldBuilderV3< + io.trino.spi.grpc.Trinomanager.DataSourceRequest, io.trino.spi.grpc.Trinomanager.DataSourceRequest.Builder, io.trino.spi.grpc.Trinomanager.DataSourceRequestOrBuilder> dataSourcesBuilder_; + + /** + * repeated .grpc.DataSourceRequest data_sources = 4; + */ + public java.util.List getDataSourcesList() { + if (dataSourcesBuilder_ == null) { + return java.util.Collections.unmodifiableList(dataSources_); + } else { + return dataSourcesBuilder_.getMessageList(); + } + } + /** + * repeated .grpc.DataSourceRequest data_sources = 4; + */ + public int getDataSourcesCount() { + if (dataSourcesBuilder_ == null) { + return dataSources_.size(); + } else { + return dataSourcesBuilder_.getCount(); + } + } + /** + * repeated .grpc.DataSourceRequest data_sources = 4; + */ + public io.trino.spi.grpc.Trinomanager.DataSourceRequest getDataSources(int index) { + if (dataSourcesBuilder_ == null) { + return dataSources_.get(index); + } else { + return dataSourcesBuilder_.getMessage(index); + } + } + /** + * repeated .grpc.DataSourceRequest data_sources = 4; + */ + public Builder setDataSources( + int index, io.trino.spi.grpc.Trinomanager.DataSourceRequest value) { + if (dataSourcesBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + ensureDataSourcesIsMutable(); + dataSources_.set(index, value); + onChanged(); + } else { + dataSourcesBuilder_.setMessage(index, value); + } + return this; + } + /** + * repeated .grpc.DataSourceRequest data_sources = 4; + */ + public Builder setDataSources( + int index, io.trino.spi.grpc.Trinomanager.DataSourceRequest.Builder builderForValue) { + if (dataSourcesBuilder_ == null) { + ensureDataSourcesIsMutable(); + dataSources_.set(index, builderForValue.build()); + onChanged(); + } else { + dataSourcesBuilder_.setMessage(index, builderForValue.build()); + } + return this; + } + /** + * repeated .grpc.DataSourceRequest data_sources = 4; + */ + public Builder addDataSources(io.trino.spi.grpc.Trinomanager.DataSourceRequest value) { + if (dataSourcesBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + ensureDataSourcesIsMutable(); + dataSources_.add(value); + onChanged(); + } else { + dataSourcesBuilder_.addMessage(value); + } + return this; + } + /** + * repeated .grpc.DataSourceRequest data_sources = 4; + */ + public Builder addDataSources( + int index, io.trino.spi.grpc.Trinomanager.DataSourceRequest value) { + if (dataSourcesBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + ensureDataSourcesIsMutable(); + dataSources_.add(index, value); + onChanged(); + } else { + dataSourcesBuilder_.addMessage(index, value); + } + return this; + } + /** + * repeated .grpc.DataSourceRequest data_sources = 4; + */ + public Builder addDataSources( + io.trino.spi.grpc.Trinomanager.DataSourceRequest.Builder builderForValue) { + if (dataSourcesBuilder_ == null) { + ensureDataSourcesIsMutable(); + dataSources_.add(builderForValue.build()); + onChanged(); + } else { + dataSourcesBuilder_.addMessage(builderForValue.build()); + } + return this; + } + /** + * repeated .grpc.DataSourceRequest data_sources = 4; + */ + public Builder addDataSources( + int index, io.trino.spi.grpc.Trinomanager.DataSourceRequest.Builder builderForValue) { + if (dataSourcesBuilder_ == null) { + ensureDataSourcesIsMutable(); + dataSources_.add(index, builderForValue.build()); + onChanged(); + } else { + dataSourcesBuilder_.addMessage(index, builderForValue.build()); + } + return this; + } + /** + * repeated .grpc.DataSourceRequest data_sources = 4; + */ + public Builder addAllDataSources( + java.lang.Iterable values) { + if (dataSourcesBuilder_ == null) { + ensureDataSourcesIsMutable(); + com.google.protobuf.AbstractMessageLite.Builder.addAll( + values, dataSources_); + onChanged(); + } else { + dataSourcesBuilder_.addAllMessages(values); + } + return this; + } + /** + * repeated .grpc.DataSourceRequest data_sources = 4; + */ + public Builder clearDataSources() { + if (dataSourcesBuilder_ == null) { + dataSources_ = java.util.Collections.emptyList(); + bitField0_ = (bitField0_ & ~0x00000008); + onChanged(); + } else { + dataSourcesBuilder_.clear(); + } + return this; + } + /** + * repeated .grpc.DataSourceRequest data_sources = 4; + */ + public Builder removeDataSources(int index) { + if (dataSourcesBuilder_ == null) { + ensureDataSourcesIsMutable(); + dataSources_.remove(index); + onChanged(); + } else { + dataSourcesBuilder_.remove(index); + } + return this; + } + /** + * repeated .grpc.DataSourceRequest data_sources = 4; + */ + public io.trino.spi.grpc.Trinomanager.DataSourceRequest.Builder getDataSourcesBuilder( + int index) { + return getDataSourcesFieldBuilder().getBuilder(index); + } + /** + * repeated .grpc.DataSourceRequest data_sources = 4; + */ + public io.trino.spi.grpc.Trinomanager.DataSourceRequestOrBuilder getDataSourcesOrBuilder( + int index) { + if (dataSourcesBuilder_ == null) { + return dataSources_.get(index); } else { + return dataSourcesBuilder_.getMessageOrBuilder(index); + } + } + /** + * repeated .grpc.DataSourceRequest data_sources = 4; + */ + public java.util.List + getDataSourcesOrBuilderList() { + if (dataSourcesBuilder_ != null) { + return dataSourcesBuilder_.getMessageOrBuilderList(); + } else { + return java.util.Collections.unmodifiableList(dataSources_); + } + } + /** + * repeated .grpc.DataSourceRequest data_sources = 4; + */ + public io.trino.spi.grpc.Trinomanager.DataSourceRequest.Builder addDataSourcesBuilder() { + return getDataSourcesFieldBuilder().addBuilder( + io.trino.spi.grpc.Trinomanager.DataSourceRequest.getDefaultInstance()); + } + /** + * repeated .grpc.DataSourceRequest data_sources = 4; + */ + public io.trino.spi.grpc.Trinomanager.DataSourceRequest.Builder addDataSourcesBuilder( + int index) { + return getDataSourcesFieldBuilder().addBuilder( + index, io.trino.spi.grpc.Trinomanager.DataSourceRequest.getDefaultInstance()); + } + /** + * repeated .grpc.DataSourceRequest data_sources = 4; + */ + public java.util.List + getDataSourcesBuilderList() { + return getDataSourcesFieldBuilder().getBuilderList(); + } + private com.google.protobuf.RepeatedFieldBuilderV3< + io.trino.spi.grpc.Trinomanager.DataSourceRequest, io.trino.spi.grpc.Trinomanager.DataSourceRequest.Builder, io.trino.spi.grpc.Trinomanager.DataSourceRequestOrBuilder> + getDataSourcesFieldBuilder() { + if (dataSourcesBuilder_ == null) { + dataSourcesBuilder_ = new com.google.protobuf.RepeatedFieldBuilderV3< + io.trino.spi.grpc.Trinomanager.DataSourceRequest, io.trino.spi.grpc.Trinomanager.DataSourceRequest.Builder, io.trino.spi.grpc.Trinomanager.DataSourceRequestOrBuilder>( + dataSources_, + ((bitField0_ & 0x00000008) != 0), + getParentForChildren(), + isClean()); + dataSources_ = null; + } + return dataSourcesBuilder_; + } + + private io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata notebookMetadata_; + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata, io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata.Builder, io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadataOrBuilder> notebookMetadataBuilder_; + /** + * optional .grpc.ExecuteQueryNotebookMetadata notebook_metadata = 5; + * @return Whether the notebookMetadata field is set. + */ + public boolean hasNotebookMetadata() { + return ((bitField0_ & 0x00000010) != 0); + } + /** + * optional .grpc.ExecuteQueryNotebookMetadata notebook_metadata = 5; + * @return The notebookMetadata. + */ + public io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata getNotebookMetadata() { + if (notebookMetadataBuilder_ == null) { + return notebookMetadata_ == null ? io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata.getDefaultInstance() : notebookMetadata_; + } else { + return notebookMetadataBuilder_.getMessage(); + } + } + /** + * optional .grpc.ExecuteQueryNotebookMetadata notebook_metadata = 5; + */ + public Builder setNotebookMetadata(io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata value) { + if (notebookMetadataBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + notebookMetadata_ = value; + } else { + notebookMetadataBuilder_.setMessage(value); + } + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + /** + * optional .grpc.ExecuteQueryNotebookMetadata notebook_metadata = 5; + */ + public Builder setNotebookMetadata( + io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata.Builder builderForValue) { + if (notebookMetadataBuilder_ == null) { + notebookMetadata_ = builderForValue.build(); + } else { + notebookMetadataBuilder_.setMessage(builderForValue.build()); + } + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + /** + * optional .grpc.ExecuteQueryNotebookMetadata notebook_metadata = 5; + */ + public Builder mergeNotebookMetadata(io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata value) { + if (notebookMetadataBuilder_ == null) { + if (((bitField0_ & 0x00000010) != 0) && + notebookMetadata_ != null && + notebookMetadata_ != io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata.getDefaultInstance()) { + getNotebookMetadataBuilder().mergeFrom(value); + } else { + notebookMetadata_ = value; + } + } else { + notebookMetadataBuilder_.mergeFrom(value); + } + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + /** + * optional .grpc.ExecuteQueryNotebookMetadata notebook_metadata = 5; + */ + public Builder clearNotebookMetadata() { + bitField0_ = (bitField0_ & ~0x00000010); + notebookMetadata_ = null; + if (notebookMetadataBuilder_ != null) { + notebookMetadataBuilder_.dispose(); + notebookMetadataBuilder_ = null; + } + onChanged(); + return this; + } + /** + * optional .grpc.ExecuteQueryNotebookMetadata notebook_metadata = 5; + */ + public io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata.Builder getNotebookMetadataBuilder() { + bitField0_ |= 0x00000010; + onChanged(); + return getNotebookMetadataFieldBuilder().getBuilder(); + } + /** + * optional .grpc.ExecuteQueryNotebookMetadata notebook_metadata = 5; + */ + public io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadataOrBuilder getNotebookMetadataOrBuilder() { + if (notebookMetadataBuilder_ != null) { + return notebookMetadataBuilder_.getMessageOrBuilder(); + } else { + return notebookMetadata_ == null ? + io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata.getDefaultInstance() : notebookMetadata_; + } + } + /** + * optional .grpc.ExecuteQueryNotebookMetadata notebook_metadata = 5; + */ + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata, io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata.Builder, io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadataOrBuilder> + getNotebookMetadataFieldBuilder() { + if (notebookMetadataBuilder_ == null) { + notebookMetadataBuilder_ = new com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata, io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadata.Builder, io.trino.spi.grpc.Trinomanager.ExecuteQueryNotebookMetadataOrBuilder>( + getNotebookMetadata(), + getParentForChildren(), + isClean()); + notebookMetadata_ = null; + } + return notebookMetadataBuilder_; + } + + private java.lang.Object timespan_ = ""; + /** + * optional string timespan = 6; + * @return Whether the timespan field is set. + */ + public boolean hasTimespan() { + return ((bitField0_ & 0x00000020) != 0); + } + /** + * optional string timespan = 6; + * @return The timespan. + */ + public java.lang.String getTimespan() { + java.lang.Object ref = timespan_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + timespan_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * optional string timespan = 6; + * @return The bytes for timespan. + */ + public com.google.protobuf.ByteString + getTimespanBytes() { + java.lang.Object ref = timespan_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + timespan_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * optional string timespan = 6; + * @param value The timespan to set. + * @return This builder for chaining. + */ + public Builder setTimespan( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + timespan_ = value; + bitField0_ |= 0x00000020; + onChanged(); + return this; + } + /** + * optional string timespan = 6; + * @return This builder for chaining. + */ + public Builder clearTimespan() { + timespan_ = getDefaultInstance().getTimespan(); + bitField0_ = (bitField0_ & ~0x00000020); + onChanged(); + return this; + } + /** + * optional string timespan = 6; + * @param value The bytes for timespan to set. + * @return This builder for chaining. + */ + public Builder setTimespanBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + timespan_ = value; + bitField0_ |= 0x00000020; + onChanged(); + return this; + } + + private java.lang.Object trinoHeaderQueryId_ = ""; + /** + * string trino_header_query_id = 7; + * @return The trinoHeaderQueryId. + */ + public java.lang.String getTrinoHeaderQueryId() { + java.lang.Object ref = trinoHeaderQueryId_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + trinoHeaderQueryId_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string trino_header_query_id = 7; + * @return The bytes for trinoHeaderQueryId. + */ + public com.google.protobuf.ByteString + getTrinoHeaderQueryIdBytes() { + java.lang.Object ref = trinoHeaderQueryId_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + trinoHeaderQueryId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string trino_header_query_id = 7; + * @param value The trinoHeaderQueryId to set. + * @return This builder for chaining. + */ + public Builder setTrinoHeaderQueryId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + trinoHeaderQueryId_ = value; + bitField0_ |= 0x00000040; + onChanged(); + return this; + } + /** + * string trino_header_query_id = 7; + * @return This builder for chaining. + */ + public Builder clearTrinoHeaderQueryId() { + trinoHeaderQueryId_ = getDefaultInstance().getTrinoHeaderQueryId(); + bitField0_ = (bitField0_ & ~0x00000040); + onChanged(); + return this; + } + /** + * string trino_header_query_id = 7; + * @param value The bytes for trinoHeaderQueryId to set. + * @return This builder for chaining. + */ + public Builder setTrinoHeaderQueryIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + trinoHeaderQueryId_ = value; + bitField0_ |= 0x00000040; + onChanged(); + return this; + } + + private java.lang.Object userEmail_ = ""; + /** + * string user_email = 8; + * @return The userEmail. + */ + public java.lang.String getUserEmail() { + java.lang.Object ref = userEmail_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + userEmail_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string user_email = 8; + * @return The bytes for userEmail. + */ + public com.google.protobuf.ByteString + getUserEmailBytes() { + java.lang.Object ref = userEmail_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + userEmail_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string user_email = 8; + * @param value The userEmail to set. + * @return This builder for chaining. + */ + public Builder setUserEmail( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + userEmail_ = value; + bitField0_ |= 0x00000080; + onChanged(); + return this; + } + /** + * string user_email = 8; + * @return This builder for chaining. + */ + public Builder clearUserEmail() { + userEmail_ = getDefaultInstance().getUserEmail(); + bitField0_ = (bitField0_ & ~0x00000080); + onChanged(); + return this; + } + /** + * string user_email = 8; + * @param value The bytes for userEmail to set. + * @return This builder for chaining. + */ + public Builder setUserEmailBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + userEmail_ = value; + bitField0_ |= 0x00000080; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.ExecuteQueryRequest) + } + + // @@protoc_insertion_point(class_scope:grpc.ExecuteQueryRequest) + private static final io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest(); + } + + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public ExecuteQueryRequest parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.ExecuteQueryRequest getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface ExecuteQueryReplyOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.ExecuteQueryReply) + com.google.protobuf.MessageOrBuilder { + + /** + * int32 state = 1; + * @return The state. + */ + int getState(); + + /** + * repeated string columns = 2; + * @return A list containing the columns. + */ + java.util.List + getColumnsList(); + /** + * repeated string columns = 2; + * @return The count of columns. + */ + int getColumnsCount(); + /** + * repeated string columns = 2; + * @param index The index of the element to return. + * @return The columns at the given index. + */ + java.lang.String getColumns(int index); + /** + * repeated string columns = 2; + * @param index The index of the value to return. + * @return The bytes of the columns at the given index. + */ + com.google.protobuf.ByteString + getColumnsBytes(int index); + + /** + * string row = 3; + * @return The row. + */ + java.lang.String getRow(); + /** + * string row = 3; + * @return The bytes for row. + */ + com.google.protobuf.ByteString + getRowBytes(); + } + /** + * Protobuf type {@code grpc.ExecuteQueryReply} + */ + public static final class ExecuteQueryReply extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.ExecuteQueryReply) + ExecuteQueryReplyOrBuilder { + private static final long serialVersionUID = 0L; + // Use ExecuteQueryReply.newBuilder() to construct. + private ExecuteQueryReply(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private ExecuteQueryReply() { + columns_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + row_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new ExecuteQueryReply(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_ExecuteQueryReply_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_ExecuteQueryReply_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.ExecuteQueryReply.class, io.trino.spi.grpc.Trinomanager.ExecuteQueryReply.Builder.class); + } + + public static final int STATE_FIELD_NUMBER = 1; + private int state_ = 0; + /** + * int32 state = 1; + * @return The state. + */ + @java.lang.Override + public int getState() { + return state_; + } + + public static final int COLUMNS_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private com.google.protobuf.LazyStringArrayList columns_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + /** + * repeated string columns = 2; + * @return A list containing the columns. + */ + public com.google.protobuf.ProtocolStringList + getColumnsList() { + return columns_; + } + /** + * repeated string columns = 2; + * @return The count of columns. + */ + public int getColumnsCount() { + return columns_.size(); + } + /** + * repeated string columns = 2; + * @param index The index of the element to return. + * @return The columns at the given index. + */ + public java.lang.String getColumns(int index) { + return columns_.get(index); + } + /** + * repeated string columns = 2; + * @param index The index of the value to return. + * @return The bytes of the columns at the given index. + */ + public com.google.protobuf.ByteString + getColumnsBytes(int index) { + return columns_.getByteString(index); + } + + public static final int ROW_FIELD_NUMBER = 3; + @SuppressWarnings("serial") + private volatile java.lang.Object row_ = ""; + /** + * string row = 3; + * @return The row. + */ + @java.lang.Override + public java.lang.String getRow() { + java.lang.Object ref = row_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + row_ = s; + return s; + } + } + /** + * string row = 3; + * @return The bytes for row. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getRowBytes() { + java.lang.Object ref = row_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + row_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (state_ != 0) { + output.writeInt32(1, state_); + } + for (int i = 0; i < columns_.size(); i++) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, columns_.getRaw(i)); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(row_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 3, row_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (state_ != 0) { + size += com.google.protobuf.CodedOutputStream + .computeInt32Size(1, state_); + } + { + int dataSize = 0; + for (int i = 0; i < columns_.size(); i++) { + dataSize += computeStringSizeNoTag(columns_.getRaw(i)); + } + size += dataSize; + size += 1 * getColumnsList().size(); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(row_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(3, row_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Trinomanager.ExecuteQueryReply)) { + return super.equals(obj); + } + io.trino.spi.grpc.Trinomanager.ExecuteQueryReply other = (io.trino.spi.grpc.Trinomanager.ExecuteQueryReply) obj; + + if (getState() + != other.getState()) return false; + if (!getColumnsList() + .equals(other.getColumnsList())) return false; + if (!getRow() + .equals(other.getRow())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + STATE_FIELD_NUMBER; + hash = (53 * hash) + getState(); + if (getColumnsCount() > 0) { + hash = (37 * hash) + COLUMNS_FIELD_NUMBER; + hash = (53 * hash) + getColumnsList().hashCode(); + } + hash = (37 * hash) + ROW_FIELD_NUMBER; + hash = (53 * hash) + getRow().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryReply parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryReply parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryReply parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryReply parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryReply parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryReply parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryReply parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryReply parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryReply parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryReply parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryReply parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryReply parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Trinomanager.ExecuteQueryReply prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.ExecuteQueryReply} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.ExecuteQueryReply) + io.trino.spi.grpc.Trinomanager.ExecuteQueryReplyOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_ExecuteQueryReply_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_ExecuteQueryReply_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.ExecuteQueryReply.class, io.trino.spi.grpc.Trinomanager.ExecuteQueryReply.Builder.class); + } + + // Construct using io.trino.spi.grpc.Trinomanager.ExecuteQueryReply.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + state_ = 0; + columns_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + row_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_ExecuteQueryReply_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.ExecuteQueryReply getDefaultInstanceForType() { + return io.trino.spi.grpc.Trinomanager.ExecuteQueryReply.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.ExecuteQueryReply build() { + io.trino.spi.grpc.Trinomanager.ExecuteQueryReply result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.ExecuteQueryReply buildPartial() { + io.trino.spi.grpc.Trinomanager.ExecuteQueryReply result = new io.trino.spi.grpc.Trinomanager.ExecuteQueryReply(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Trinomanager.ExecuteQueryReply result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.state_ = state_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + columns_.makeImmutable(); + result.columns_ = columns_; + } + if (((from_bitField0_ & 0x00000004) != 0)) { + result.row_ = row_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Trinomanager.ExecuteQueryReply) { + return mergeFrom((io.trino.spi.grpc.Trinomanager.ExecuteQueryReply)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Trinomanager.ExecuteQueryReply other) { + if (other == io.trino.spi.grpc.Trinomanager.ExecuteQueryReply.getDefaultInstance()) return this; + if (other.getState() != 0) { + setState(other.getState()); + } + if (!other.columns_.isEmpty()) { + if (columns_.isEmpty()) { + columns_ = other.columns_; + bitField0_ |= 0x00000002; + } else { + ensureColumnsIsMutable(); + columns_.addAll(other.columns_); + } + onChanged(); + } + if (!other.getRow().isEmpty()) { + row_ = other.row_; + bitField0_ |= 0x00000004; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 8: { + state_ = input.readInt32(); + bitField0_ |= 0x00000001; + break; + } // case 8 + case 18: { + java.lang.String s = input.readStringRequireUtf8(); + ensureColumnsIsMutable(); + columns_.add(s); + break; + } // case 18 + case 26: { + row_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000004; + break; + } // case 26 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private int state_ ; + /** + * int32 state = 1; + * @return The state. + */ + @java.lang.Override + public int getState() { + return state_; + } + /** + * int32 state = 1; + * @param value The state to set. + * @return This builder for chaining. + */ + public Builder setState(int value) { + + state_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * int32 state = 1; + * @return This builder for chaining. + */ + public Builder clearState() { + bitField0_ = (bitField0_ & ~0x00000001); + state_ = 0; + onChanged(); + return this; + } + + private com.google.protobuf.LazyStringArrayList columns_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + private void ensureColumnsIsMutable() { + if (!columns_.isModifiable()) { + columns_ = new com.google.protobuf.LazyStringArrayList(columns_); + } + bitField0_ |= 0x00000002; + } + /** + * repeated string columns = 2; + * @return A list containing the columns. + */ + public com.google.protobuf.ProtocolStringList + getColumnsList() { + columns_.makeImmutable(); + return columns_; + } + /** + * repeated string columns = 2; + * @return The count of columns. + */ + public int getColumnsCount() { + return columns_.size(); + } + /** + * repeated string columns = 2; + * @param index The index of the element to return. + * @return The columns at the given index. + */ + public java.lang.String getColumns(int index) { + return columns_.get(index); + } + /** + * repeated string columns = 2; + * @param index The index of the value to return. + * @return The bytes of the columns at the given index. + */ + public com.google.protobuf.ByteString + getColumnsBytes(int index) { + return columns_.getByteString(index); + } + /** + * repeated string columns = 2; + * @param index The index to set the value at. + * @param value The columns to set. + * @return This builder for chaining. + */ + public Builder setColumns( + int index, java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + ensureColumnsIsMutable(); + columns_.set(index, value); + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * repeated string columns = 2; + * @param value The columns to add. + * @return This builder for chaining. + */ + public Builder addColumns( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + ensureColumnsIsMutable(); + columns_.add(value); + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * repeated string columns = 2; + * @param values The columns to add. + * @return This builder for chaining. + */ + public Builder addAllColumns( + java.lang.Iterable values) { + ensureColumnsIsMutable(); + com.google.protobuf.AbstractMessageLite.Builder.addAll( + values, columns_); + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * repeated string columns = 2; + * @return This builder for chaining. + */ + public Builder clearColumns() { + columns_ = + com.google.protobuf.LazyStringArrayList.emptyList(); + bitField0_ = (bitField0_ & ~0x00000002);; + onChanged(); + return this; + } + /** + * repeated string columns = 2; + * @param value The bytes of the columns to add. + * @return This builder for chaining. + */ + public Builder addColumnsBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + ensureColumnsIsMutable(); + columns_.add(value); + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + + private java.lang.Object row_ = ""; + /** + * string row = 3; + * @return The row. + */ + public java.lang.String getRow() { + java.lang.Object ref = row_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + row_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string row = 3; + * @return The bytes for row. + */ + public com.google.protobuf.ByteString + getRowBytes() { + java.lang.Object ref = row_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + row_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string row = 3; + * @param value The row to set. + * @return This builder for chaining. + */ + public Builder setRow( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + row_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + /** + * string row = 3; + * @return This builder for chaining. + */ + public Builder clearRow() { + row_ = getDefaultInstance().getRow(); + bitField0_ = (bitField0_ & ~0x00000004); + onChanged(); + return this; + } + /** + * string row = 3; + * @param value The bytes for row to set. + * @return This builder for chaining. + */ + public Builder setRowBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + row_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.ExecuteQueryReply) + } + + // @@protoc_insertion_point(class_scope:grpc.ExecuteQueryReply) + private static final io.trino.spi.grpc.Trinomanager.ExecuteQueryReply DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Trinomanager.ExecuteQueryReply(); + } + + public static io.trino.spi.grpc.Trinomanager.ExecuteQueryReply getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public ExecuteQueryReply parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.ExecuteQueryReply getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface TenantDataRequestOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.TenantDataRequest) + com.google.protobuf.MessageOrBuilder { + + /** + * string tenant = 1; + * @return The tenant. + */ + java.lang.String getTenant(); + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + com.google.protobuf.ByteString + getTenantBytes(); + } + /** + * Protobuf type {@code grpc.TenantDataRequest} + */ + public static final class TenantDataRequest extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.TenantDataRequest) + TenantDataRequestOrBuilder { + private static final long serialVersionUID = 0L; + // Use TenantDataRequest.newBuilder() to construct. + private TenantDataRequest(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private TenantDataRequest() { + tenant_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new TenantDataRequest(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_TenantDataRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_TenantDataRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.TenantDataRequest.class, io.trino.spi.grpc.Trinomanager.TenantDataRequest.Builder.class); + } + + public static final int TENANT_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + @java.lang.Override + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, tenant_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, tenant_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Trinomanager.TenantDataRequest)) { + return super.equals(obj); + } + io.trino.spi.grpc.Trinomanager.TenantDataRequest other = (io.trino.spi.grpc.Trinomanager.TenantDataRequest) obj; + + if (!getTenant() + .equals(other.getTenant())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + TENANT_FIELD_NUMBER; + hash = (53 * hash) + getTenant().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Trinomanager.TenantDataRequest parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.TenantDataRequest parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.TenantDataRequest parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.TenantDataRequest parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.TenantDataRequest parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.TenantDataRequest parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.TenantDataRequest parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.TenantDataRequest parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Trinomanager.TenantDataRequest parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Trinomanager.TenantDataRequest parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.TenantDataRequest parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.TenantDataRequest parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Trinomanager.TenantDataRequest prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.TenantDataRequest} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.TenantDataRequest) + io.trino.spi.grpc.Trinomanager.TenantDataRequestOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_TenantDataRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_TenantDataRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.TenantDataRequest.class, io.trino.spi.grpc.Trinomanager.TenantDataRequest.Builder.class); + } + + // Construct using io.trino.spi.grpc.Trinomanager.TenantDataRequest.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + tenant_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_TenantDataRequest_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.TenantDataRequest getDefaultInstanceForType() { + return io.trino.spi.grpc.Trinomanager.TenantDataRequest.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.TenantDataRequest build() { + io.trino.spi.grpc.Trinomanager.TenantDataRequest result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.TenantDataRequest buildPartial() { + io.trino.spi.grpc.Trinomanager.TenantDataRequest result = new io.trino.spi.grpc.Trinomanager.TenantDataRequest(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Trinomanager.TenantDataRequest result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.tenant_ = tenant_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Trinomanager.TenantDataRequest) { + return mergeFrom((io.trino.spi.grpc.Trinomanager.TenantDataRequest)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Trinomanager.TenantDataRequest other) { + if (other == io.trino.spi.grpc.Trinomanager.TenantDataRequest.getDefaultInstance()) return this; + if (!other.getTenant().isEmpty()) { + tenant_ = other.tenant_; + bitField0_ |= 0x00000001; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + tenant_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant = 1; + * @param value The tenant to set. + * @return This builder for chaining. + */ + public Builder setTenant( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string tenant = 1; + * @return This builder for chaining. + */ + public Builder clearTenant() { + tenant_ = getDefaultInstance().getTenant(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string tenant = 1; + * @param value The bytes for tenant to set. + * @return This builder for chaining. + */ + public Builder setTenantBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.TenantDataRequest) + } + + // @@protoc_insertion_point(class_scope:grpc.TenantDataRequest) + private static final io.trino.spi.grpc.Trinomanager.TenantDataRequest DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Trinomanager.TenantDataRequest(); + } + + public static io.trino.spi.grpc.Trinomanager.TenantDataRequest getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public TenantDataRequest parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.TenantDataRequest getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface WorkflowRunReplyOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.WorkflowRunReply) + com.google.protobuf.MessageOrBuilder { + + /** + * string result = 1; + * @return The result. + */ + java.lang.String getResult(); + /** + * string result = 1; + * @return The bytes for result. + */ + com.google.protobuf.ByteString + getResultBytes(); + } + /** + * Protobuf type {@code grpc.WorkflowRunReply} + */ + public static final class WorkflowRunReply extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.WorkflowRunReply) + WorkflowRunReplyOrBuilder { + private static final long serialVersionUID = 0L; + // Use WorkflowRunReply.newBuilder() to construct. + private WorkflowRunReply(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private WorkflowRunReply() { + result_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new WorkflowRunReply(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_WorkflowRunReply_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_WorkflowRunReply_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.WorkflowRunReply.class, io.trino.spi.grpc.Trinomanager.WorkflowRunReply.Builder.class); + } + + public static final int RESULT_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object result_ = ""; + /** + * string result = 1; + * @return The result. + */ + @java.lang.Override + public java.lang.String getResult() { + java.lang.Object ref = result_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + result_ = s; + return s; + } + } + /** + * string result = 1; + * @return The bytes for result. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getResultBytes() { + java.lang.Object ref = result_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + result_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(result_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, result_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(result_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, result_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Trinomanager.WorkflowRunReply)) { + return super.equals(obj); + } + io.trino.spi.grpc.Trinomanager.WorkflowRunReply other = (io.trino.spi.grpc.Trinomanager.WorkflowRunReply) obj; + + if (!getResult() + .equals(other.getResult())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + RESULT_FIELD_NUMBER; + hash = (53 * hash) + getResult().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Trinomanager.WorkflowRunReply parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.WorkflowRunReply parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.WorkflowRunReply parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.WorkflowRunReply parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.WorkflowRunReply parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.WorkflowRunReply parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.WorkflowRunReply parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.WorkflowRunReply parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Trinomanager.WorkflowRunReply parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Trinomanager.WorkflowRunReply parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.WorkflowRunReply parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.WorkflowRunReply parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Trinomanager.WorkflowRunReply prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.WorkflowRunReply} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.WorkflowRunReply) + io.trino.spi.grpc.Trinomanager.WorkflowRunReplyOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_WorkflowRunReply_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_WorkflowRunReply_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.WorkflowRunReply.class, io.trino.spi.grpc.Trinomanager.WorkflowRunReply.Builder.class); + } + + // Construct using io.trino.spi.grpc.Trinomanager.WorkflowRunReply.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + result_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_WorkflowRunReply_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.WorkflowRunReply getDefaultInstanceForType() { + return io.trino.spi.grpc.Trinomanager.WorkflowRunReply.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.WorkflowRunReply build() { + io.trino.spi.grpc.Trinomanager.WorkflowRunReply result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.WorkflowRunReply buildPartial() { + io.trino.spi.grpc.Trinomanager.WorkflowRunReply result = new io.trino.spi.grpc.Trinomanager.WorkflowRunReply(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Trinomanager.WorkflowRunReply result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.result_ = result_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Trinomanager.WorkflowRunReply) { + return mergeFrom((io.trino.spi.grpc.Trinomanager.WorkflowRunReply)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Trinomanager.WorkflowRunReply other) { + if (other == io.trino.spi.grpc.Trinomanager.WorkflowRunReply.getDefaultInstance()) return this; + if (!other.getResult().isEmpty()) { + result_ = other.result_; + bitField0_ |= 0x00000001; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + result_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object result_ = ""; + /** + * string result = 1; + * @return The result. + */ + public java.lang.String getResult() { + java.lang.Object ref = result_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + result_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string result = 1; + * @return The bytes for result. + */ + public com.google.protobuf.ByteString + getResultBytes() { + java.lang.Object ref = result_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + result_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string result = 1; + * @param value The result to set. + * @return This builder for chaining. + */ + public Builder setResult( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + result_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string result = 1; + * @return This builder for chaining. + */ + public Builder clearResult() { + result_ = getDefaultInstance().getResult(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string result = 1; + * @param value The bytes for result to set. + * @return This builder for chaining. + */ + public Builder setResultBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + result_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.WorkflowRunReply) + } + + // @@protoc_insertion_point(class_scope:grpc.WorkflowRunReply) + private static final io.trino.spi.grpc.Trinomanager.WorkflowRunReply DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Trinomanager.WorkflowRunReply(); + } + + public static io.trino.spi.grpc.Trinomanager.WorkflowRunReply getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public WorkflowRunReply parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.WorkflowRunReply getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface NotebookCellCellConfigOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.NotebookCellCellConfig) + com.google.protobuf.MessageOrBuilder { + + /** + * repeated .grpc.DataSourceRequest datasources = 1; + */ + java.util.List + getDatasourcesList(); + /** + * repeated .grpc.DataSourceRequest datasources = 1; + */ + io.trino.spi.grpc.Trinomanager.DataSourceRequest getDatasources(int index); + /** + * repeated .grpc.DataSourceRequest datasources = 1; + */ + int getDatasourcesCount(); + /** + * repeated .grpc.DataSourceRequest datasources = 1; + */ + java.util.List + getDatasourcesOrBuilderList(); + /** + * repeated .grpc.DataSourceRequest datasources = 1; + */ + io.trino.spi.grpc.Trinomanager.DataSourceRequestOrBuilder getDatasourcesOrBuilder( + int index); + } + /** + * Protobuf type {@code grpc.NotebookCellCellConfig} + */ + public static final class NotebookCellCellConfig extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.NotebookCellCellConfig) + NotebookCellCellConfigOrBuilder { + private static final long serialVersionUID = 0L; + // Use NotebookCellCellConfig.newBuilder() to construct. + private NotebookCellCellConfig(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private NotebookCellCellConfig() { + datasources_ = java.util.Collections.emptyList(); + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new NotebookCellCellConfig(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_NotebookCellCellConfig_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_NotebookCellCellConfig_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig.class, io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig.Builder.class); + } + + public static final int DATASOURCES_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private java.util.List datasources_; + /** + * repeated .grpc.DataSourceRequest datasources = 1; + */ + @java.lang.Override + public java.util.List getDatasourcesList() { + return datasources_; + } + /** + * repeated .grpc.DataSourceRequest datasources = 1; + */ + @java.lang.Override + public java.util.List + getDatasourcesOrBuilderList() { + return datasources_; + } + /** + * repeated .grpc.DataSourceRequest datasources = 1; + */ + @java.lang.Override + public int getDatasourcesCount() { + return datasources_.size(); + } + /** + * repeated .grpc.DataSourceRequest datasources = 1; + */ + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.DataSourceRequest getDatasources(int index) { + return datasources_.get(index); + } + /** + * repeated .grpc.DataSourceRequest datasources = 1; + */ + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.DataSourceRequestOrBuilder getDatasourcesOrBuilder( + int index) { + return datasources_.get(index); + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + for (int i = 0; i < datasources_.size(); i++) { + output.writeMessage(1, datasources_.get(i)); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + for (int i = 0; i < datasources_.size(); i++) { + size += com.google.protobuf.CodedOutputStream + .computeMessageSize(1, datasources_.get(i)); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig)) { + return super.equals(obj); + } + io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig other = (io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig) obj; + + if (!getDatasourcesList() + .equals(other.getDatasourcesList())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + if (getDatasourcesCount() > 0) { + hash = (37 * hash) + DATASOURCES_FIELD_NUMBER; + hash = (53 * hash) + getDatasourcesList().hashCode(); + } + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.NotebookCellCellConfig} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.NotebookCellCellConfig) + io.trino.spi.grpc.Trinomanager.NotebookCellCellConfigOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_NotebookCellCellConfig_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_NotebookCellCellConfig_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig.class, io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig.Builder.class); + } + + // Construct using io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + if (datasourcesBuilder_ == null) { + datasources_ = java.util.Collections.emptyList(); + } else { + datasources_ = null; + datasourcesBuilder_.clear(); + } + bitField0_ = (bitField0_ & ~0x00000001); + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_NotebookCellCellConfig_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig getDefaultInstanceForType() { + return io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig build() { + io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig buildPartial() { + io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig result = new io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig(this); + buildPartialRepeatedFields(result); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartialRepeatedFields(io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig result) { + if (datasourcesBuilder_ == null) { + if (((bitField0_ & 0x00000001) != 0)) { + datasources_ = java.util.Collections.unmodifiableList(datasources_); + bitField0_ = (bitField0_ & ~0x00000001); + } + result.datasources_ = datasources_; + } else { + result.datasources_ = datasourcesBuilder_.build(); + } + } + + private void buildPartial0(io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig result) { + int from_bitField0_ = bitField0_; + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig) { + return mergeFrom((io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig other) { + if (other == io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig.getDefaultInstance()) return this; + if (datasourcesBuilder_ == null) { + if (!other.datasources_.isEmpty()) { + if (datasources_.isEmpty()) { + datasources_ = other.datasources_; + bitField0_ = (bitField0_ & ~0x00000001); + } else { + ensureDatasourcesIsMutable(); + datasources_.addAll(other.datasources_); + } + onChanged(); + } + } else { + if (!other.datasources_.isEmpty()) { + if (datasourcesBuilder_.isEmpty()) { + datasourcesBuilder_.dispose(); + datasourcesBuilder_ = null; + datasources_ = other.datasources_; + bitField0_ = (bitField0_ & ~0x00000001); + datasourcesBuilder_ = + com.google.protobuf.GeneratedMessageV3.alwaysUseFieldBuilders ? + getDatasourcesFieldBuilder() : null; + } else { + datasourcesBuilder_.addAllMessages(other.datasources_); + } + } + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + io.trino.spi.grpc.Trinomanager.DataSourceRequest m = + input.readMessage( + io.trino.spi.grpc.Trinomanager.DataSourceRequest.parser(), + extensionRegistry); + if (datasourcesBuilder_ == null) { + ensureDatasourcesIsMutable(); + datasources_.add(m); + } else { + datasourcesBuilder_.addMessage(m); + } + break; + } // case 10 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.util.List datasources_ = + java.util.Collections.emptyList(); + private void ensureDatasourcesIsMutable() { + if (!((bitField0_ & 0x00000001) != 0)) { + datasources_ = new java.util.ArrayList(datasources_); + bitField0_ |= 0x00000001; + } + } + + private com.google.protobuf.RepeatedFieldBuilderV3< + io.trino.spi.grpc.Trinomanager.DataSourceRequest, io.trino.spi.grpc.Trinomanager.DataSourceRequest.Builder, io.trino.spi.grpc.Trinomanager.DataSourceRequestOrBuilder> datasourcesBuilder_; + + /** + * repeated .grpc.DataSourceRequest datasources = 1; + */ + public java.util.List getDatasourcesList() { + if (datasourcesBuilder_ == null) { + return java.util.Collections.unmodifiableList(datasources_); + } else { + return datasourcesBuilder_.getMessageList(); + } + } + /** + * repeated .grpc.DataSourceRequest datasources = 1; + */ + public int getDatasourcesCount() { + if (datasourcesBuilder_ == null) { + return datasources_.size(); + } else { + return datasourcesBuilder_.getCount(); + } + } + /** + * repeated .grpc.DataSourceRequest datasources = 1; + */ + public io.trino.spi.grpc.Trinomanager.DataSourceRequest getDatasources(int index) { + if (datasourcesBuilder_ == null) { + return datasources_.get(index); + } else { + return datasourcesBuilder_.getMessage(index); + } + } + /** + * repeated .grpc.DataSourceRequest datasources = 1; + */ + public Builder setDatasources( + int index, io.trino.spi.grpc.Trinomanager.DataSourceRequest value) { + if (datasourcesBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + ensureDatasourcesIsMutable(); + datasources_.set(index, value); + onChanged(); + } else { + datasourcesBuilder_.setMessage(index, value); + } + return this; + } + /** + * repeated .grpc.DataSourceRequest datasources = 1; + */ + public Builder setDatasources( + int index, io.trino.spi.grpc.Trinomanager.DataSourceRequest.Builder builderForValue) { + if (datasourcesBuilder_ == null) { + ensureDatasourcesIsMutable(); + datasources_.set(index, builderForValue.build()); + onChanged(); + } else { + datasourcesBuilder_.setMessage(index, builderForValue.build()); + } + return this; + } + /** + * repeated .grpc.DataSourceRequest datasources = 1; + */ + public Builder addDatasources(io.trino.spi.grpc.Trinomanager.DataSourceRequest value) { + if (datasourcesBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + ensureDatasourcesIsMutable(); + datasources_.add(value); + onChanged(); + } else { + datasourcesBuilder_.addMessage(value); + } + return this; + } + /** + * repeated .grpc.DataSourceRequest datasources = 1; + */ + public Builder addDatasources( + int index, io.trino.spi.grpc.Trinomanager.DataSourceRequest value) { + if (datasourcesBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + ensureDatasourcesIsMutable(); + datasources_.add(index, value); + onChanged(); + } else { + datasourcesBuilder_.addMessage(index, value); + } + return this; + } + /** + * repeated .grpc.DataSourceRequest datasources = 1; + */ + public Builder addDatasources( + io.trino.spi.grpc.Trinomanager.DataSourceRequest.Builder builderForValue) { + if (datasourcesBuilder_ == null) { + ensureDatasourcesIsMutable(); + datasources_.add(builderForValue.build()); + onChanged(); + } else { + datasourcesBuilder_.addMessage(builderForValue.build()); + } + return this; + } + /** + * repeated .grpc.DataSourceRequest datasources = 1; + */ + public Builder addDatasources( + int index, io.trino.spi.grpc.Trinomanager.DataSourceRequest.Builder builderForValue) { + if (datasourcesBuilder_ == null) { + ensureDatasourcesIsMutable(); + datasources_.add(index, builderForValue.build()); + onChanged(); + } else { + datasourcesBuilder_.addMessage(index, builderForValue.build()); + } + return this; + } + /** + * repeated .grpc.DataSourceRequest datasources = 1; + */ + public Builder addAllDatasources( + java.lang.Iterable values) { + if (datasourcesBuilder_ == null) { + ensureDatasourcesIsMutable(); + com.google.protobuf.AbstractMessageLite.Builder.addAll( + values, datasources_); + onChanged(); + } else { + datasourcesBuilder_.addAllMessages(values); + } + return this; + } + /** + * repeated .grpc.DataSourceRequest datasources = 1; + */ + public Builder clearDatasources() { + if (datasourcesBuilder_ == null) { + datasources_ = java.util.Collections.emptyList(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + } else { + datasourcesBuilder_.clear(); + } + return this; + } + /** + * repeated .grpc.DataSourceRequest datasources = 1; + */ + public Builder removeDatasources(int index) { + if (datasourcesBuilder_ == null) { + ensureDatasourcesIsMutable(); + datasources_.remove(index); + onChanged(); + } else { + datasourcesBuilder_.remove(index); + } + return this; + } + /** + * repeated .grpc.DataSourceRequest datasources = 1; + */ + public io.trino.spi.grpc.Trinomanager.DataSourceRequest.Builder getDatasourcesBuilder( + int index) { + return getDatasourcesFieldBuilder().getBuilder(index); + } + /** + * repeated .grpc.DataSourceRequest datasources = 1; + */ + public io.trino.spi.grpc.Trinomanager.DataSourceRequestOrBuilder getDatasourcesOrBuilder( + int index) { + if (datasourcesBuilder_ == null) { + return datasources_.get(index); } else { + return datasourcesBuilder_.getMessageOrBuilder(index); + } + } + /** + * repeated .grpc.DataSourceRequest datasources = 1; + */ + public java.util.List + getDatasourcesOrBuilderList() { + if (datasourcesBuilder_ != null) { + return datasourcesBuilder_.getMessageOrBuilderList(); + } else { + return java.util.Collections.unmodifiableList(datasources_); + } + } + /** + * repeated .grpc.DataSourceRequest datasources = 1; + */ + public io.trino.spi.grpc.Trinomanager.DataSourceRequest.Builder addDatasourcesBuilder() { + return getDatasourcesFieldBuilder().addBuilder( + io.trino.spi.grpc.Trinomanager.DataSourceRequest.getDefaultInstance()); + } + /** + * repeated .grpc.DataSourceRequest datasources = 1; + */ + public io.trino.spi.grpc.Trinomanager.DataSourceRequest.Builder addDatasourcesBuilder( + int index) { + return getDatasourcesFieldBuilder().addBuilder( + index, io.trino.spi.grpc.Trinomanager.DataSourceRequest.getDefaultInstance()); + } + /** + * repeated .grpc.DataSourceRequest datasources = 1; + */ + public java.util.List + getDatasourcesBuilderList() { + return getDatasourcesFieldBuilder().getBuilderList(); + } + private com.google.protobuf.RepeatedFieldBuilderV3< + io.trino.spi.grpc.Trinomanager.DataSourceRequest, io.trino.spi.grpc.Trinomanager.DataSourceRequest.Builder, io.trino.spi.grpc.Trinomanager.DataSourceRequestOrBuilder> + getDatasourcesFieldBuilder() { + if (datasourcesBuilder_ == null) { + datasourcesBuilder_ = new com.google.protobuf.RepeatedFieldBuilderV3< + io.trino.spi.grpc.Trinomanager.DataSourceRequest, io.trino.spi.grpc.Trinomanager.DataSourceRequest.Builder, io.trino.spi.grpc.Trinomanager.DataSourceRequestOrBuilder>( + datasources_, + ((bitField0_ & 0x00000001) != 0), + getParentForChildren(), + isClean()); + datasources_ = null; + } + return datasourcesBuilder_; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.NotebookCellCellConfig) + } + + // @@protoc_insertion_point(class_scope:grpc.NotebookCellCellConfig) + private static final io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig(); + } + + public static io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public NotebookCellCellConfig parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface CreateNotebookCellRequestOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.CreateNotebookCellRequest) + com.google.protobuf.MessageOrBuilder { + + /** + * string tenant = 1; + * @return The tenant. + */ + java.lang.String getTenant(); + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + com.google.protobuf.ByteString + getTenantBytes(); + + /** + * string name = 2; + * @return The name. + */ + java.lang.String getName(); + /** + * string name = 2; + * @return The bytes for name. + */ + com.google.protobuf.ByteString + getNameBytes(); + + /** + * string sql_query = 3; + * @return The sqlQuery. + */ + java.lang.String getSqlQuery(); + /** + * string sql_query = 3; + * @return The bytes for sqlQuery. + */ + com.google.protobuf.ByteString + getSqlQueryBytes(); + + /** + * optional .grpc.DataSourceRequest cell_config = 4; + * @return Whether the cellConfig field is set. + */ + boolean hasCellConfig(); + /** + * optional .grpc.DataSourceRequest cell_config = 4; + * @return The cellConfig. + */ + io.trino.spi.grpc.Trinomanager.DataSourceRequest getCellConfig(); + /** + * optional .grpc.DataSourceRequest cell_config = 4; + */ + io.trino.spi.grpc.Trinomanager.DataSourceRequestOrBuilder getCellConfigOrBuilder(); + + /** + * optional string notebook_id = 5; + * @return Whether the notebookId field is set. + */ + boolean hasNotebookId(); + /** + * optional string notebook_id = 5; + * @return The notebookId. + */ + java.lang.String getNotebookId(); + /** + * optional string notebook_id = 5; + * @return The bytes for notebookId. + */ + com.google.protobuf.ByteString + getNotebookIdBytes(); + + /** + * optional int32 notebook_version = 6; + * @return Whether the notebookVersion field is set. + */ + boolean hasNotebookVersion(); + /** + * optional int32 notebook_version = 6; + * @return The notebookVersion. + */ + int getNotebookVersion(); + + /** + * optional int32 order = 7; + * @return Whether the order field is set. + */ + boolean hasOrder(); + /** + * optional int32 order = 7; + * @return The order. + */ + int getOrder(); + + /** + * optional string author = 8; + * @return Whether the author field is set. + */ + boolean hasAuthor(); + /** + * optional string author = 8; + * @return The author. + */ + java.lang.String getAuthor(); + /** + * optional string author = 8; + * @return The bytes for author. + */ + com.google.protobuf.ByteString + getAuthorBytes(); + } + /** + * Protobuf type {@code grpc.CreateNotebookCellRequest} + */ + public static final class CreateNotebookCellRequest extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.CreateNotebookCellRequest) + CreateNotebookCellRequestOrBuilder { + private static final long serialVersionUID = 0L; + // Use CreateNotebookCellRequest.newBuilder() to construct. + private CreateNotebookCellRequest(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private CreateNotebookCellRequest() { + tenant_ = ""; + name_ = ""; + sqlQuery_ = ""; + notebookId_ = ""; + author_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new CreateNotebookCellRequest(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_CreateNotebookCellRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_CreateNotebookCellRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest.class, io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest.Builder.class); + } + + private int bitField0_; + public static final int TENANT_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + @java.lang.Override + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int NAME_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object name_ = ""; + /** + * string name = 2; + * @return The name. + */ + @java.lang.Override + public java.lang.String getName() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } + } + /** + * string name = 2; + * @return The bytes for name. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int SQL_QUERY_FIELD_NUMBER = 3; + @SuppressWarnings("serial") + private volatile java.lang.Object sqlQuery_ = ""; + /** + * string sql_query = 3; + * @return The sqlQuery. + */ + @java.lang.Override + public java.lang.String getSqlQuery() { + java.lang.Object ref = sqlQuery_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + sqlQuery_ = s; + return s; + } + } + /** + * string sql_query = 3; + * @return The bytes for sqlQuery. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getSqlQueryBytes() { + java.lang.Object ref = sqlQuery_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + sqlQuery_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int CELL_CONFIG_FIELD_NUMBER = 4; + private io.trino.spi.grpc.Trinomanager.DataSourceRequest cellConfig_; + /** + * optional .grpc.DataSourceRequest cell_config = 4; + * @return Whether the cellConfig field is set. + */ + @java.lang.Override + public boolean hasCellConfig() { + return ((bitField0_ & 0x00000001) != 0); + } + /** + * optional .grpc.DataSourceRequest cell_config = 4; + * @return The cellConfig. + */ + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.DataSourceRequest getCellConfig() { + return cellConfig_ == null ? io.trino.spi.grpc.Trinomanager.DataSourceRequest.getDefaultInstance() : cellConfig_; + } + /** + * optional .grpc.DataSourceRequest cell_config = 4; + */ + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.DataSourceRequestOrBuilder getCellConfigOrBuilder() { + return cellConfig_ == null ? io.trino.spi.grpc.Trinomanager.DataSourceRequest.getDefaultInstance() : cellConfig_; + } + + public static final int NOTEBOOK_ID_FIELD_NUMBER = 5; + @SuppressWarnings("serial") + private volatile java.lang.Object notebookId_ = ""; + /** + * optional string notebook_id = 5; + * @return Whether the notebookId field is set. + */ + @java.lang.Override + public boolean hasNotebookId() { + return ((bitField0_ & 0x00000002) != 0); + } + /** + * optional string notebook_id = 5; + * @return The notebookId. + */ + @java.lang.Override + public java.lang.String getNotebookId() { + java.lang.Object ref = notebookId_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + notebookId_ = s; + return s; + } + } + /** + * optional string notebook_id = 5; + * @return The bytes for notebookId. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getNotebookIdBytes() { + java.lang.Object ref = notebookId_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + notebookId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int NOTEBOOK_VERSION_FIELD_NUMBER = 6; + private int notebookVersion_ = 0; + /** + * optional int32 notebook_version = 6; + * @return Whether the notebookVersion field is set. + */ + @java.lang.Override + public boolean hasNotebookVersion() { + return ((bitField0_ & 0x00000004) != 0); + } + /** + * optional int32 notebook_version = 6; + * @return The notebookVersion. + */ + @java.lang.Override + public int getNotebookVersion() { + return notebookVersion_; + } + + public static final int ORDER_FIELD_NUMBER = 7; + private int order_ = 0; + /** + * optional int32 order = 7; + * @return Whether the order field is set. + */ + @java.lang.Override + public boolean hasOrder() { + return ((bitField0_ & 0x00000008) != 0); + } + /** + * optional int32 order = 7; + * @return The order. + */ + @java.lang.Override + public int getOrder() { + return order_; + } + + public static final int AUTHOR_FIELD_NUMBER = 8; + @SuppressWarnings("serial") + private volatile java.lang.Object author_ = ""; + /** + * optional string author = 8; + * @return Whether the author field is set. + */ + @java.lang.Override + public boolean hasAuthor() { + return ((bitField0_ & 0x00000010) != 0); + } + /** + * optional string author = 8; + * @return The author. + */ + @java.lang.Override + public java.lang.String getAuthor() { + java.lang.Object ref = author_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + author_ = s; + return s; + } + } + /** + * optional string author = 8; + * @return The bytes for author. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getAuthorBytes() { + java.lang.Object ref = author_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + author_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(name_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, name_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(sqlQuery_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 3, sqlQuery_); + } + if (((bitField0_ & 0x00000001) != 0)) { + output.writeMessage(4, getCellConfig()); + } + if (((bitField0_ & 0x00000002) != 0)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 5, notebookId_); + } + if (((bitField0_ & 0x00000004) != 0)) { + output.writeInt32(6, notebookVersion_); + } + if (((bitField0_ & 0x00000008) != 0)) { + output.writeInt32(7, order_); + } + if (((bitField0_ & 0x00000010) != 0)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 8, author_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(name_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, name_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(sqlQuery_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(3, sqlQuery_); + } + if (((bitField0_ & 0x00000001) != 0)) { + size += com.google.protobuf.CodedOutputStream + .computeMessageSize(4, getCellConfig()); + } + if (((bitField0_ & 0x00000002) != 0)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(5, notebookId_); + } + if (((bitField0_ & 0x00000004) != 0)) { + size += com.google.protobuf.CodedOutputStream + .computeInt32Size(6, notebookVersion_); + } + if (((bitField0_ & 0x00000008) != 0)) { + size += com.google.protobuf.CodedOutputStream + .computeInt32Size(7, order_); + } + if (((bitField0_ & 0x00000010) != 0)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(8, author_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest)) { + return super.equals(obj); + } + io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest other = (io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest) obj; + + if (!getTenant() + .equals(other.getTenant())) return false; + if (!getName() + .equals(other.getName())) return false; + if (!getSqlQuery() + .equals(other.getSqlQuery())) return false; + if (hasCellConfig() != other.hasCellConfig()) return false; + if (hasCellConfig()) { + if (!getCellConfig() + .equals(other.getCellConfig())) return false; + } + if (hasNotebookId() != other.hasNotebookId()) return false; + if (hasNotebookId()) { + if (!getNotebookId() + .equals(other.getNotebookId())) return false; + } + if (hasNotebookVersion() != other.hasNotebookVersion()) return false; + if (hasNotebookVersion()) { + if (getNotebookVersion() + != other.getNotebookVersion()) return false; + } + if (hasOrder() != other.hasOrder()) return false; + if (hasOrder()) { + if (getOrder() + != other.getOrder()) return false; + } + if (hasAuthor() != other.hasAuthor()) return false; + if (hasAuthor()) { + if (!getAuthor() + .equals(other.getAuthor())) return false; + } + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + TENANT_FIELD_NUMBER; + hash = (53 * hash) + getTenant().hashCode(); + hash = (37 * hash) + NAME_FIELD_NUMBER; + hash = (53 * hash) + getName().hashCode(); + hash = (37 * hash) + SQL_QUERY_FIELD_NUMBER; + hash = (53 * hash) + getSqlQuery().hashCode(); + if (hasCellConfig()) { + hash = (37 * hash) + CELL_CONFIG_FIELD_NUMBER; + hash = (53 * hash) + getCellConfig().hashCode(); + } + if (hasNotebookId()) { + hash = (37 * hash) + NOTEBOOK_ID_FIELD_NUMBER; + hash = (53 * hash) + getNotebookId().hashCode(); + } + if (hasNotebookVersion()) { + hash = (37 * hash) + NOTEBOOK_VERSION_FIELD_NUMBER; + hash = (53 * hash) + getNotebookVersion(); + } + if (hasOrder()) { + hash = (37 * hash) + ORDER_FIELD_NUMBER; + hash = (53 * hash) + getOrder(); + } + if (hasAuthor()) { + hash = (37 * hash) + AUTHOR_FIELD_NUMBER; + hash = (53 * hash) + getAuthor().hashCode(); + } + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.CreateNotebookCellRequest} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.CreateNotebookCellRequest) + io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequestOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_CreateNotebookCellRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_CreateNotebookCellRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest.class, io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest.Builder.class); + } + + // Construct using io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest.newBuilder() + private Builder() { + maybeForceBuilderInitialization(); + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + maybeForceBuilderInitialization(); + } + private void maybeForceBuilderInitialization() { + if (com.google.protobuf.GeneratedMessageV3 + .alwaysUseFieldBuilders) { + getCellConfigFieldBuilder(); + } + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + tenant_ = ""; + name_ = ""; + sqlQuery_ = ""; + cellConfig_ = null; + if (cellConfigBuilder_ != null) { + cellConfigBuilder_.dispose(); + cellConfigBuilder_ = null; + } + notebookId_ = ""; + notebookVersion_ = 0; + order_ = 0; + author_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_CreateNotebookCellRequest_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest getDefaultInstanceForType() { + return io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest build() { + io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest buildPartial() { + io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest result = new io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.tenant_ = tenant_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.name_ = name_; + } + if (((from_bitField0_ & 0x00000004) != 0)) { + result.sqlQuery_ = sqlQuery_; + } + int to_bitField0_ = 0; + if (((from_bitField0_ & 0x00000008) != 0)) { + result.cellConfig_ = cellConfigBuilder_ == null + ? cellConfig_ + : cellConfigBuilder_.build(); + to_bitField0_ |= 0x00000001; + } + if (((from_bitField0_ & 0x00000010) != 0)) { + result.notebookId_ = notebookId_; + to_bitField0_ |= 0x00000002; + } + if (((from_bitField0_ & 0x00000020) != 0)) { + result.notebookVersion_ = notebookVersion_; + to_bitField0_ |= 0x00000004; + } + if (((from_bitField0_ & 0x00000040) != 0)) { + result.order_ = order_; + to_bitField0_ |= 0x00000008; + } + if (((from_bitField0_ & 0x00000080) != 0)) { + result.author_ = author_; + to_bitField0_ |= 0x00000010; + } + result.bitField0_ |= to_bitField0_; + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest) { + return mergeFrom((io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest other) { + if (other == io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest.getDefaultInstance()) return this; + if (!other.getTenant().isEmpty()) { + tenant_ = other.tenant_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getName().isEmpty()) { + name_ = other.name_; + bitField0_ |= 0x00000002; + onChanged(); + } + if (!other.getSqlQuery().isEmpty()) { + sqlQuery_ = other.sqlQuery_; + bitField0_ |= 0x00000004; + onChanged(); + } + if (other.hasCellConfig()) { + mergeCellConfig(other.getCellConfig()); + } + if (other.hasNotebookId()) { + notebookId_ = other.notebookId_; + bitField0_ |= 0x00000010; + onChanged(); + } + if (other.hasNotebookVersion()) { + setNotebookVersion(other.getNotebookVersion()); + } + if (other.hasOrder()) { + setOrder(other.getOrder()); + } + if (other.hasAuthor()) { + author_ = other.author_; + bitField0_ |= 0x00000080; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + tenant_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + name_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + case 26: { + sqlQuery_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000004; + break; + } // case 26 + case 34: { + input.readMessage( + getCellConfigFieldBuilder().getBuilder(), + extensionRegistry); + bitField0_ |= 0x00000008; + break; + } // case 34 + case 42: { + notebookId_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000010; + break; + } // case 42 + case 48: { + notebookVersion_ = input.readInt32(); + bitField0_ |= 0x00000020; + break; + } // case 48 + case 56: { + order_ = input.readInt32(); + bitField0_ |= 0x00000040; + break; + } // case 56 + case 66: { + author_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000080; + break; + } // case 66 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant = 1; + * @param value The tenant to set. + * @return This builder for chaining. + */ + public Builder setTenant( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string tenant = 1; + * @return This builder for chaining. + */ + public Builder clearTenant() { + tenant_ = getDefaultInstance().getTenant(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string tenant = 1; + * @param value The bytes for tenant to set. + * @return This builder for chaining. + */ + public Builder setTenantBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object name_ = ""; + /** + * string name = 2; + * @return The name. + */ + public java.lang.String getName() { + java.lang.Object ref = name_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string name = 2; + * @return The bytes for name. + */ + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string name = 2; + * @param value The name to set. + * @return This builder for chaining. + */ + public Builder setName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + name_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string name = 2; + * @return This builder for chaining. + */ + public Builder clearName() { + name_ = getDefaultInstance().getName(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string name = 2; + * @param value The bytes for name to set. + * @return This builder for chaining. + */ + public Builder setNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + name_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + + private java.lang.Object sqlQuery_ = ""; + /** + * string sql_query = 3; + * @return The sqlQuery. + */ + public java.lang.String getSqlQuery() { + java.lang.Object ref = sqlQuery_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + sqlQuery_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string sql_query = 3; + * @return The bytes for sqlQuery. + */ + public com.google.protobuf.ByteString + getSqlQueryBytes() { + java.lang.Object ref = sqlQuery_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + sqlQuery_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string sql_query = 3; + * @param value The sqlQuery to set. + * @return This builder for chaining. + */ + public Builder setSqlQuery( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + sqlQuery_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + /** + * string sql_query = 3; + * @return This builder for chaining. + */ + public Builder clearSqlQuery() { + sqlQuery_ = getDefaultInstance().getSqlQuery(); + bitField0_ = (bitField0_ & ~0x00000004); + onChanged(); + return this; + } + /** + * string sql_query = 3; + * @param value The bytes for sqlQuery to set. + * @return This builder for chaining. + */ + public Builder setSqlQueryBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + sqlQuery_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + + private io.trino.spi.grpc.Trinomanager.DataSourceRequest cellConfig_; + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Trinomanager.DataSourceRequest, io.trino.spi.grpc.Trinomanager.DataSourceRequest.Builder, io.trino.spi.grpc.Trinomanager.DataSourceRequestOrBuilder> cellConfigBuilder_; + /** + * optional .grpc.DataSourceRequest cell_config = 4; + * @return Whether the cellConfig field is set. + */ + public boolean hasCellConfig() { + return ((bitField0_ & 0x00000008) != 0); + } + /** + * optional .grpc.DataSourceRequest cell_config = 4; + * @return The cellConfig. + */ + public io.trino.spi.grpc.Trinomanager.DataSourceRequest getCellConfig() { + if (cellConfigBuilder_ == null) { + return cellConfig_ == null ? io.trino.spi.grpc.Trinomanager.DataSourceRequest.getDefaultInstance() : cellConfig_; + } else { + return cellConfigBuilder_.getMessage(); + } + } + /** + * optional .grpc.DataSourceRequest cell_config = 4; + */ + public Builder setCellConfig(io.trino.spi.grpc.Trinomanager.DataSourceRequest value) { + if (cellConfigBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + cellConfig_ = value; + } else { + cellConfigBuilder_.setMessage(value); + } + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + /** + * optional .grpc.DataSourceRequest cell_config = 4; + */ + public Builder setCellConfig( + io.trino.spi.grpc.Trinomanager.DataSourceRequest.Builder builderForValue) { + if (cellConfigBuilder_ == null) { + cellConfig_ = builderForValue.build(); + } else { + cellConfigBuilder_.setMessage(builderForValue.build()); + } + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + /** + * optional .grpc.DataSourceRequest cell_config = 4; + */ + public Builder mergeCellConfig(io.trino.spi.grpc.Trinomanager.DataSourceRequest value) { + if (cellConfigBuilder_ == null) { + if (((bitField0_ & 0x00000008) != 0) && + cellConfig_ != null && + cellConfig_ != io.trino.spi.grpc.Trinomanager.DataSourceRequest.getDefaultInstance()) { + getCellConfigBuilder().mergeFrom(value); + } else { + cellConfig_ = value; + } + } else { + cellConfigBuilder_.mergeFrom(value); + } + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + /** + * optional .grpc.DataSourceRequest cell_config = 4; + */ + public Builder clearCellConfig() { + bitField0_ = (bitField0_ & ~0x00000008); + cellConfig_ = null; + if (cellConfigBuilder_ != null) { + cellConfigBuilder_.dispose(); + cellConfigBuilder_ = null; + } + onChanged(); + return this; + } + /** + * optional .grpc.DataSourceRequest cell_config = 4; + */ + public io.trino.spi.grpc.Trinomanager.DataSourceRequest.Builder getCellConfigBuilder() { + bitField0_ |= 0x00000008; + onChanged(); + return getCellConfigFieldBuilder().getBuilder(); + } + /** + * optional .grpc.DataSourceRequest cell_config = 4; + */ + public io.trino.spi.grpc.Trinomanager.DataSourceRequestOrBuilder getCellConfigOrBuilder() { + if (cellConfigBuilder_ != null) { + return cellConfigBuilder_.getMessageOrBuilder(); + } else { + return cellConfig_ == null ? + io.trino.spi.grpc.Trinomanager.DataSourceRequest.getDefaultInstance() : cellConfig_; + } + } + /** + * optional .grpc.DataSourceRequest cell_config = 4; + */ + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Trinomanager.DataSourceRequest, io.trino.spi.grpc.Trinomanager.DataSourceRequest.Builder, io.trino.spi.grpc.Trinomanager.DataSourceRequestOrBuilder> + getCellConfigFieldBuilder() { + if (cellConfigBuilder_ == null) { + cellConfigBuilder_ = new com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Trinomanager.DataSourceRequest, io.trino.spi.grpc.Trinomanager.DataSourceRequest.Builder, io.trino.spi.grpc.Trinomanager.DataSourceRequestOrBuilder>( + getCellConfig(), + getParentForChildren(), + isClean()); + cellConfig_ = null; + } + return cellConfigBuilder_; + } + + private java.lang.Object notebookId_ = ""; + /** + * optional string notebook_id = 5; + * @return Whether the notebookId field is set. + */ + public boolean hasNotebookId() { + return ((bitField0_ & 0x00000010) != 0); + } + /** + * optional string notebook_id = 5; + * @return The notebookId. + */ + public java.lang.String getNotebookId() { + java.lang.Object ref = notebookId_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + notebookId_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * optional string notebook_id = 5; + * @return The bytes for notebookId. + */ + public com.google.protobuf.ByteString + getNotebookIdBytes() { + java.lang.Object ref = notebookId_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + notebookId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * optional string notebook_id = 5; + * @param value The notebookId to set. + * @return This builder for chaining. + */ + public Builder setNotebookId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + notebookId_ = value; + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + /** + * optional string notebook_id = 5; + * @return This builder for chaining. + */ + public Builder clearNotebookId() { + notebookId_ = getDefaultInstance().getNotebookId(); + bitField0_ = (bitField0_ & ~0x00000010); + onChanged(); + return this; + } + /** + * optional string notebook_id = 5; + * @param value The bytes for notebookId to set. + * @return This builder for chaining. + */ + public Builder setNotebookIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + notebookId_ = value; + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + + private int notebookVersion_ ; + /** + * optional int32 notebook_version = 6; + * @return Whether the notebookVersion field is set. + */ + @java.lang.Override + public boolean hasNotebookVersion() { + return ((bitField0_ & 0x00000020) != 0); + } + /** + * optional int32 notebook_version = 6; + * @return The notebookVersion. + */ + @java.lang.Override + public int getNotebookVersion() { + return notebookVersion_; + } + /** + * optional int32 notebook_version = 6; + * @param value The notebookVersion to set. + * @return This builder for chaining. + */ + public Builder setNotebookVersion(int value) { + + notebookVersion_ = value; + bitField0_ |= 0x00000020; + onChanged(); + return this; + } + /** + * optional int32 notebook_version = 6; + * @return This builder for chaining. + */ + public Builder clearNotebookVersion() { + bitField0_ = (bitField0_ & ~0x00000020); + notebookVersion_ = 0; + onChanged(); + return this; + } + + private int order_ ; + /** + * optional int32 order = 7; + * @return Whether the order field is set. + */ + @java.lang.Override + public boolean hasOrder() { + return ((bitField0_ & 0x00000040) != 0); + } + /** + * optional int32 order = 7; + * @return The order. + */ + @java.lang.Override + public int getOrder() { + return order_; + } + /** + * optional int32 order = 7; + * @param value The order to set. + * @return This builder for chaining. + */ + public Builder setOrder(int value) { + + order_ = value; + bitField0_ |= 0x00000040; + onChanged(); + return this; + } + /** + * optional int32 order = 7; + * @return This builder for chaining. + */ + public Builder clearOrder() { + bitField0_ = (bitField0_ & ~0x00000040); + order_ = 0; + onChanged(); + return this; + } + + private java.lang.Object author_ = ""; + /** + * optional string author = 8; + * @return Whether the author field is set. + */ + public boolean hasAuthor() { + return ((bitField0_ & 0x00000080) != 0); + } + /** + * optional string author = 8; + * @return The author. + */ + public java.lang.String getAuthor() { + java.lang.Object ref = author_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + author_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * optional string author = 8; + * @return The bytes for author. + */ + public com.google.protobuf.ByteString + getAuthorBytes() { + java.lang.Object ref = author_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + author_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * optional string author = 8; + * @param value The author to set. + * @return This builder for chaining. + */ + public Builder setAuthor( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + author_ = value; + bitField0_ |= 0x00000080; + onChanged(); + return this; + } + /** + * optional string author = 8; + * @return This builder for chaining. + */ + public Builder clearAuthor() { + author_ = getDefaultInstance().getAuthor(); + bitField0_ = (bitField0_ & ~0x00000080); + onChanged(); + return this; + } + /** + * optional string author = 8; + * @param value The bytes for author to set. + * @return This builder for chaining. + */ + public Builder setAuthorBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + author_ = value; + bitField0_ |= 0x00000080; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.CreateNotebookCellRequest) + } + + // @@protoc_insertion_point(class_scope:grpc.CreateNotebookCellRequest) + private static final io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest(); + } + + public static io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public CreateNotebookCellRequest parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.CreateNotebookCellRequest getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface DeleteNotebookCellRequestOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.DeleteNotebookCellRequest) + com.google.protobuf.MessageOrBuilder { + + /** + * string tenant = 1; + * @return The tenant. + */ + java.lang.String getTenant(); + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + com.google.protobuf.ByteString + getTenantBytes(); + + /** + * string id = 2; + * @return The id. + */ + java.lang.String getId(); + /** + * string id = 2; + * @return The bytes for id. + */ + com.google.protobuf.ByteString + getIdBytes(); + + /** + * optional string notebook_id = 3; + * @return Whether the notebookId field is set. + */ + boolean hasNotebookId(); + /** + * optional string notebook_id = 3; + * @return The notebookId. + */ + java.lang.String getNotebookId(); + /** + * optional string notebook_id = 3; + * @return The bytes for notebookId. + */ + com.google.protobuf.ByteString + getNotebookIdBytes(); + + /** + * optional int32 notebook_version = 4; + * @return Whether the notebookVersion field is set. + */ + boolean hasNotebookVersion(); + /** + * optional int32 notebook_version = 4; + * @return The notebookVersion. + */ + int getNotebookVersion(); + + /** + * optional string author = 5; + * @return Whether the author field is set. + */ + boolean hasAuthor(); + /** + * optional string author = 5; + * @return The author. + */ + java.lang.String getAuthor(); + /** + * optional string author = 5; + * @return The bytes for author. + */ + com.google.protobuf.ByteString + getAuthorBytes(); + } + /** + * Protobuf type {@code grpc.DeleteNotebookCellRequest} + */ + public static final class DeleteNotebookCellRequest extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.DeleteNotebookCellRequest) + DeleteNotebookCellRequestOrBuilder { + private static final long serialVersionUID = 0L; + // Use DeleteNotebookCellRequest.newBuilder() to construct. + private DeleteNotebookCellRequest(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private DeleteNotebookCellRequest() { + tenant_ = ""; + id_ = ""; + notebookId_ = ""; + author_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new DeleteNotebookCellRequest(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_DeleteNotebookCellRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_DeleteNotebookCellRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest.class, io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest.Builder.class); + } + + private int bitField0_; + public static final int TENANT_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + @java.lang.Override + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int ID_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object id_ = ""; + /** + * string id = 2; + * @return The id. + */ + @java.lang.Override + public java.lang.String getId() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } + } + /** + * string id = 2; + * @return The bytes for id. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int NOTEBOOK_ID_FIELD_NUMBER = 3; + @SuppressWarnings("serial") + private volatile java.lang.Object notebookId_ = ""; + /** + * optional string notebook_id = 3; + * @return Whether the notebookId field is set. + */ + @java.lang.Override + public boolean hasNotebookId() { + return ((bitField0_ & 0x00000001) != 0); + } + /** + * optional string notebook_id = 3; + * @return The notebookId. + */ + @java.lang.Override + public java.lang.String getNotebookId() { + java.lang.Object ref = notebookId_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + notebookId_ = s; + return s; + } + } + /** + * optional string notebook_id = 3; + * @return The bytes for notebookId. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getNotebookIdBytes() { + java.lang.Object ref = notebookId_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + notebookId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int NOTEBOOK_VERSION_FIELD_NUMBER = 4; + private int notebookVersion_ = 0; + /** + * optional int32 notebook_version = 4; + * @return Whether the notebookVersion field is set. + */ + @java.lang.Override + public boolean hasNotebookVersion() { + return ((bitField0_ & 0x00000002) != 0); + } + /** + * optional int32 notebook_version = 4; + * @return The notebookVersion. + */ + @java.lang.Override + public int getNotebookVersion() { + return notebookVersion_; + } + + public static final int AUTHOR_FIELD_NUMBER = 5; + @SuppressWarnings("serial") + private volatile java.lang.Object author_ = ""; + /** + * optional string author = 5; + * @return Whether the author field is set. + */ + @java.lang.Override + public boolean hasAuthor() { + return ((bitField0_ & 0x00000004) != 0); + } + /** + * optional string author = 5; + * @return The author. + */ + @java.lang.Override + public java.lang.String getAuthor() { + java.lang.Object ref = author_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + author_ = s; + return s; + } + } + /** + * optional string author = 5; + * @return The bytes for author. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getAuthorBytes() { + java.lang.Object ref = author_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + author_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, id_); + } + if (((bitField0_ & 0x00000001) != 0)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 3, notebookId_); + } + if (((bitField0_ & 0x00000002) != 0)) { + output.writeInt32(4, notebookVersion_); + } + if (((bitField0_ & 0x00000004) != 0)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 5, author_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, id_); + } + if (((bitField0_ & 0x00000001) != 0)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(3, notebookId_); + } + if (((bitField0_ & 0x00000002) != 0)) { + size += com.google.protobuf.CodedOutputStream + .computeInt32Size(4, notebookVersion_); + } + if (((bitField0_ & 0x00000004) != 0)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(5, author_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest)) { + return super.equals(obj); + } + io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest other = (io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest) obj; + + if (!getTenant() + .equals(other.getTenant())) return false; + if (!getId() + .equals(other.getId())) return false; + if (hasNotebookId() != other.hasNotebookId()) return false; + if (hasNotebookId()) { + if (!getNotebookId() + .equals(other.getNotebookId())) return false; + } + if (hasNotebookVersion() != other.hasNotebookVersion()) return false; + if (hasNotebookVersion()) { + if (getNotebookVersion() + != other.getNotebookVersion()) return false; + } + if (hasAuthor() != other.hasAuthor()) return false; + if (hasAuthor()) { + if (!getAuthor() + .equals(other.getAuthor())) return false; + } + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + TENANT_FIELD_NUMBER; + hash = (53 * hash) + getTenant().hashCode(); + hash = (37 * hash) + ID_FIELD_NUMBER; + hash = (53 * hash) + getId().hashCode(); + if (hasNotebookId()) { + hash = (37 * hash) + NOTEBOOK_ID_FIELD_NUMBER; + hash = (53 * hash) + getNotebookId().hashCode(); + } + if (hasNotebookVersion()) { + hash = (37 * hash) + NOTEBOOK_VERSION_FIELD_NUMBER; + hash = (53 * hash) + getNotebookVersion(); + } + if (hasAuthor()) { + hash = (37 * hash) + AUTHOR_FIELD_NUMBER; + hash = (53 * hash) + getAuthor().hashCode(); + } + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.DeleteNotebookCellRequest} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.DeleteNotebookCellRequest) + io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequestOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_DeleteNotebookCellRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_DeleteNotebookCellRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest.class, io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest.Builder.class); + } + + // Construct using io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + tenant_ = ""; + id_ = ""; + notebookId_ = ""; + notebookVersion_ = 0; + author_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_DeleteNotebookCellRequest_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest getDefaultInstanceForType() { + return io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest build() { + io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest buildPartial() { + io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest result = new io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.tenant_ = tenant_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.id_ = id_; + } + int to_bitField0_ = 0; + if (((from_bitField0_ & 0x00000004) != 0)) { + result.notebookId_ = notebookId_; + to_bitField0_ |= 0x00000001; + } + if (((from_bitField0_ & 0x00000008) != 0)) { + result.notebookVersion_ = notebookVersion_; + to_bitField0_ |= 0x00000002; + } + if (((from_bitField0_ & 0x00000010) != 0)) { + result.author_ = author_; + to_bitField0_ |= 0x00000004; + } + result.bitField0_ |= to_bitField0_; + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest) { + return mergeFrom((io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest other) { + if (other == io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest.getDefaultInstance()) return this; + if (!other.getTenant().isEmpty()) { + tenant_ = other.tenant_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getId().isEmpty()) { + id_ = other.id_; + bitField0_ |= 0x00000002; + onChanged(); + } + if (other.hasNotebookId()) { + notebookId_ = other.notebookId_; + bitField0_ |= 0x00000004; + onChanged(); + } + if (other.hasNotebookVersion()) { + setNotebookVersion(other.getNotebookVersion()); + } + if (other.hasAuthor()) { + author_ = other.author_; + bitField0_ |= 0x00000010; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + tenant_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + id_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + case 26: { + notebookId_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000004; + break; + } // case 26 + case 32: { + notebookVersion_ = input.readInt32(); + bitField0_ |= 0x00000008; + break; + } // case 32 + case 42: { + author_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000010; + break; + } // case 42 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant = 1; + * @param value The tenant to set. + * @return This builder for chaining. + */ + public Builder setTenant( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string tenant = 1; + * @return This builder for chaining. + */ + public Builder clearTenant() { + tenant_ = getDefaultInstance().getTenant(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string tenant = 1; + * @param value The bytes for tenant to set. + * @return This builder for chaining. + */ + public Builder setTenantBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object id_ = ""; + /** + * string id = 2; + * @return The id. + */ + public java.lang.String getId() { + java.lang.Object ref = id_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string id = 2; + * @return The bytes for id. + */ + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string id = 2; + * @param value The id to set. + * @return This builder for chaining. + */ + public Builder setId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + id_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string id = 2; + * @return This builder for chaining. + */ + public Builder clearId() { + id_ = getDefaultInstance().getId(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string id = 2; + * @param value The bytes for id to set. + * @return This builder for chaining. + */ + public Builder setIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + id_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + + private java.lang.Object notebookId_ = ""; + /** + * optional string notebook_id = 3; + * @return Whether the notebookId field is set. + */ + public boolean hasNotebookId() { + return ((bitField0_ & 0x00000004) != 0); + } + /** + * optional string notebook_id = 3; + * @return The notebookId. + */ + public java.lang.String getNotebookId() { + java.lang.Object ref = notebookId_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + notebookId_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * optional string notebook_id = 3; + * @return The bytes for notebookId. + */ + public com.google.protobuf.ByteString + getNotebookIdBytes() { + java.lang.Object ref = notebookId_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + notebookId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * optional string notebook_id = 3; + * @param value The notebookId to set. + * @return This builder for chaining. + */ + public Builder setNotebookId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + notebookId_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + /** + * optional string notebook_id = 3; + * @return This builder for chaining. + */ + public Builder clearNotebookId() { + notebookId_ = getDefaultInstance().getNotebookId(); + bitField0_ = (bitField0_ & ~0x00000004); + onChanged(); + return this; + } + /** + * optional string notebook_id = 3; + * @param value The bytes for notebookId to set. + * @return This builder for chaining. + */ + public Builder setNotebookIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + notebookId_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + + private int notebookVersion_ ; + /** + * optional int32 notebook_version = 4; + * @return Whether the notebookVersion field is set. + */ + @java.lang.Override + public boolean hasNotebookVersion() { + return ((bitField0_ & 0x00000008) != 0); + } + /** + * optional int32 notebook_version = 4; + * @return The notebookVersion. + */ + @java.lang.Override + public int getNotebookVersion() { + return notebookVersion_; + } + /** + * optional int32 notebook_version = 4; + * @param value The notebookVersion to set. + * @return This builder for chaining. + */ + public Builder setNotebookVersion(int value) { + + notebookVersion_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + /** + * optional int32 notebook_version = 4; + * @return This builder for chaining. + */ + public Builder clearNotebookVersion() { + bitField0_ = (bitField0_ & ~0x00000008); + notebookVersion_ = 0; + onChanged(); + return this; + } + + private java.lang.Object author_ = ""; + /** + * optional string author = 5; + * @return Whether the author field is set. + */ + public boolean hasAuthor() { + return ((bitField0_ & 0x00000010) != 0); + } + /** + * optional string author = 5; + * @return The author. + */ + public java.lang.String getAuthor() { + java.lang.Object ref = author_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + author_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * optional string author = 5; + * @return The bytes for author. + */ + public com.google.protobuf.ByteString + getAuthorBytes() { + java.lang.Object ref = author_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + author_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * optional string author = 5; + * @param value The author to set. + * @return This builder for chaining. + */ + public Builder setAuthor( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + author_ = value; + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + /** + * optional string author = 5; + * @return This builder for chaining. + */ + public Builder clearAuthor() { + author_ = getDefaultInstance().getAuthor(); + bitField0_ = (bitField0_ & ~0x00000010); + onChanged(); + return this; + } + /** + * optional string author = 5; + * @param value The bytes for author to set. + * @return This builder for chaining. + */ + public Builder setAuthorBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + author_ = value; + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.DeleteNotebookCellRequest) + } + + // @@protoc_insertion_point(class_scope:grpc.DeleteNotebookCellRequest) + private static final io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest(); + } + + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public DeleteNotebookCellRequest parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.DeleteNotebookCellRequest getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface EditNotebookCellRequestOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.EditNotebookCellRequest) + com.google.protobuf.MessageOrBuilder { + + /** + * string tenant = 1; + * @return The tenant. + */ + java.lang.String getTenant(); + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + com.google.protobuf.ByteString + getTenantBytes(); + + /** + * string id = 2; + * @return The id. + */ + java.lang.String getId(); + /** + * string id = 2; + * @return The bytes for id. + */ + com.google.protobuf.ByteString + getIdBytes(); + + /** + * string notebook_id = 3; + * @return The notebookId. + */ + java.lang.String getNotebookId(); + /** + * string notebook_id = 3; + * @return The bytes for notebookId. + */ + com.google.protobuf.ByteString + getNotebookIdBytes(); + + /** + * int32 notebook_version = 4; + * @return The notebookVersion. + */ + int getNotebookVersion(); + + /** + * optional string name = 5; + * @return Whether the name field is set. + */ + boolean hasName(); + /** + * optional string name = 5; + * @return The name. + */ + java.lang.String getName(); + /** + * optional string name = 5; + * @return The bytes for name. + */ + com.google.protobuf.ByteString + getNameBytes(); + + /** + * optional string sql_query = 6; + * @return Whether the sqlQuery field is set. + */ + boolean hasSqlQuery(); + /** + * optional string sql_query = 6; + * @return The sqlQuery. + */ + java.lang.String getSqlQuery(); + /** + * optional string sql_query = 6; + * @return The bytes for sqlQuery. + */ + com.google.protobuf.ByteString + getSqlQueryBytes(); + + /** + * optional .grpc.NotebookCellCellConfig cell_config = 7; + * @return Whether the cellConfig field is set. + */ + boolean hasCellConfig(); + /** + * optional .grpc.NotebookCellCellConfig cell_config = 7; + * @return The cellConfig. + */ + io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig getCellConfig(); + /** + * optional .grpc.NotebookCellCellConfig cell_config = 7; + */ + io.trino.spi.grpc.Trinomanager.NotebookCellCellConfigOrBuilder getCellConfigOrBuilder(); + + /** + * optional int32 last_execution_state = 8; + * @return Whether the lastExecutionState field is set. + */ + boolean hasLastExecutionState(); + /** + * optional int32 last_execution_state = 8; + * @return The lastExecutionState. + */ + int getLastExecutionState(); + + /** + * optional int64 last_executed_at = 9; + * @return Whether the lastExecutedAt field is set. + */ + boolean hasLastExecutedAt(); + /** + * optional int64 last_executed_at = 9; + * @return The lastExecutedAt. + */ + long getLastExecutedAt(); + + /** + * optional string last_execution_error = 10; + * @return Whether the lastExecutionError field is set. + */ + boolean hasLastExecutionError(); + /** + * optional string last_execution_error = 10; + * @return The lastExecutionError. + */ + java.lang.String getLastExecutionError(); + /** + * optional string last_execution_error = 10; + * @return The bytes for lastExecutionError. + */ + com.google.protobuf.ByteString + getLastExecutionErrorBytes(); + + /** + * optional string last_executed_trino_qeury_id = 11; + * @return Whether the lastExecutedTrinoQeuryId field is set. + */ + boolean hasLastExecutedTrinoQeuryId(); + /** + * optional string last_executed_trino_qeury_id = 11; + * @return The lastExecutedTrinoQeuryId. + */ + java.lang.String getLastExecutedTrinoQeuryId(); + /** + * optional string last_executed_trino_qeury_id = 11; + * @return The bytes for lastExecutedTrinoQeuryId. + */ + com.google.protobuf.ByteString + getLastExecutedTrinoQeuryIdBytes(); + + /** + * optional string author = 12; + * @return Whether the author field is set. + */ + boolean hasAuthor(); + /** + * optional string author = 12; + * @return The author. + */ + java.lang.String getAuthor(); + /** + * optional string author = 12; + * @return The bytes for author. + */ + com.google.protobuf.ByteString + getAuthorBytes(); + + /** + * optional string unexpanded_sql_query = 13; + * @return Whether the unexpandedSqlQuery field is set. + */ + boolean hasUnexpandedSqlQuery(); + /** + * optional string unexpanded_sql_query = 13; + * @return The unexpandedSqlQuery. + */ + java.lang.String getUnexpandedSqlQuery(); + /** + * optional string unexpanded_sql_query = 13; + * @return The bytes for unexpandedSqlQuery. + */ + com.google.protobuf.ByteString + getUnexpandedSqlQueryBytes(); + + /** + * optional string order_by = 14; + * @return Whether the orderBy field is set. + */ + boolean hasOrderBy(); + /** + * optional string order_by = 14; + * @return The orderBy. + */ + java.lang.String getOrderBy(); + /** + * optional string order_by = 14; + * @return The bytes for orderBy. + */ + com.google.protobuf.ByteString + getOrderByBytes(); + } + /** + * Protobuf type {@code grpc.EditNotebookCellRequest} + */ + public static final class EditNotebookCellRequest extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.EditNotebookCellRequest) + EditNotebookCellRequestOrBuilder { + private static final long serialVersionUID = 0L; + // Use EditNotebookCellRequest.newBuilder() to construct. + private EditNotebookCellRequest(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private EditNotebookCellRequest() { + tenant_ = ""; + id_ = ""; + notebookId_ = ""; + name_ = ""; + sqlQuery_ = ""; + lastExecutionError_ = ""; + lastExecutedTrinoQeuryId_ = ""; + author_ = ""; + unexpandedSqlQuery_ = ""; + orderBy_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new EditNotebookCellRequest(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_EditNotebookCellRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_EditNotebookCellRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest.class, io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest.Builder.class); + } + + private int bitField0_; + public static final int TENANT_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + @java.lang.Override + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int ID_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object id_ = ""; + /** + * string id = 2; + * @return The id. + */ + @java.lang.Override + public java.lang.String getId() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } + } + /** + * string id = 2; + * @return The bytes for id. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int NOTEBOOK_ID_FIELD_NUMBER = 3; + @SuppressWarnings("serial") + private volatile java.lang.Object notebookId_ = ""; + /** + * string notebook_id = 3; + * @return The notebookId. + */ + @java.lang.Override + public java.lang.String getNotebookId() { + java.lang.Object ref = notebookId_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + notebookId_ = s; + return s; + } + } + /** + * string notebook_id = 3; + * @return The bytes for notebookId. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getNotebookIdBytes() { + java.lang.Object ref = notebookId_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + notebookId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int NOTEBOOK_VERSION_FIELD_NUMBER = 4; + private int notebookVersion_ = 0; + /** + * int32 notebook_version = 4; + * @return The notebookVersion. + */ + @java.lang.Override + public int getNotebookVersion() { + return notebookVersion_; + } + + public static final int NAME_FIELD_NUMBER = 5; + @SuppressWarnings("serial") + private volatile java.lang.Object name_ = ""; + /** + * optional string name = 5; + * @return Whether the name field is set. + */ + @java.lang.Override + public boolean hasName() { + return ((bitField0_ & 0x00000001) != 0); + } + /** + * optional string name = 5; + * @return The name. + */ + @java.lang.Override + public java.lang.String getName() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } + } + /** + * optional string name = 5; + * @return The bytes for name. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int SQL_QUERY_FIELD_NUMBER = 6; + @SuppressWarnings("serial") + private volatile java.lang.Object sqlQuery_ = ""; + /** + * optional string sql_query = 6; + * @return Whether the sqlQuery field is set. + */ + @java.lang.Override + public boolean hasSqlQuery() { + return ((bitField0_ & 0x00000002) != 0); + } + /** + * optional string sql_query = 6; + * @return The sqlQuery. + */ + @java.lang.Override + public java.lang.String getSqlQuery() { + java.lang.Object ref = sqlQuery_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + sqlQuery_ = s; + return s; + } + } + /** + * optional string sql_query = 6; + * @return The bytes for sqlQuery. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getSqlQueryBytes() { + java.lang.Object ref = sqlQuery_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + sqlQuery_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int CELL_CONFIG_FIELD_NUMBER = 7; + private io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig cellConfig_; + /** + * optional .grpc.NotebookCellCellConfig cell_config = 7; + * @return Whether the cellConfig field is set. + */ + @java.lang.Override + public boolean hasCellConfig() { + return ((bitField0_ & 0x00000004) != 0); + } + /** + * optional .grpc.NotebookCellCellConfig cell_config = 7; + * @return The cellConfig. + */ + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig getCellConfig() { + return cellConfig_ == null ? io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig.getDefaultInstance() : cellConfig_; + } + /** + * optional .grpc.NotebookCellCellConfig cell_config = 7; + */ + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.NotebookCellCellConfigOrBuilder getCellConfigOrBuilder() { + return cellConfig_ == null ? io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig.getDefaultInstance() : cellConfig_; + } + + public static final int LAST_EXECUTION_STATE_FIELD_NUMBER = 8; + private int lastExecutionState_ = 0; + /** + * optional int32 last_execution_state = 8; + * @return Whether the lastExecutionState field is set. + */ + @java.lang.Override + public boolean hasLastExecutionState() { + return ((bitField0_ & 0x00000008) != 0); + } + /** + * optional int32 last_execution_state = 8; + * @return The lastExecutionState. + */ + @java.lang.Override + public int getLastExecutionState() { + return lastExecutionState_; + } + + public static final int LAST_EXECUTED_AT_FIELD_NUMBER = 9; + private long lastExecutedAt_ = 0L; + /** + * optional int64 last_executed_at = 9; + * @return Whether the lastExecutedAt field is set. + */ + @java.lang.Override + public boolean hasLastExecutedAt() { + return ((bitField0_ & 0x00000010) != 0); + } + /** + * optional int64 last_executed_at = 9; + * @return The lastExecutedAt. + */ + @java.lang.Override + public long getLastExecutedAt() { + return lastExecutedAt_; + } + + public static final int LAST_EXECUTION_ERROR_FIELD_NUMBER = 10; + @SuppressWarnings("serial") + private volatile java.lang.Object lastExecutionError_ = ""; + /** + * optional string last_execution_error = 10; + * @return Whether the lastExecutionError field is set. + */ + @java.lang.Override + public boolean hasLastExecutionError() { + return ((bitField0_ & 0x00000020) != 0); + } + /** + * optional string last_execution_error = 10; + * @return The lastExecutionError. + */ + @java.lang.Override + public java.lang.String getLastExecutionError() { + java.lang.Object ref = lastExecutionError_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + lastExecutionError_ = s; + return s; + } + } + /** + * optional string last_execution_error = 10; + * @return The bytes for lastExecutionError. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getLastExecutionErrorBytes() { + java.lang.Object ref = lastExecutionError_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + lastExecutionError_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int LAST_EXECUTED_TRINO_QEURY_ID_FIELD_NUMBER = 11; + @SuppressWarnings("serial") + private volatile java.lang.Object lastExecutedTrinoQeuryId_ = ""; + /** + * optional string last_executed_trino_qeury_id = 11; + * @return Whether the lastExecutedTrinoQeuryId field is set. + */ + @java.lang.Override + public boolean hasLastExecutedTrinoQeuryId() { + return ((bitField0_ & 0x00000040) != 0); + } + /** + * optional string last_executed_trino_qeury_id = 11; + * @return The lastExecutedTrinoQeuryId. + */ + @java.lang.Override + public java.lang.String getLastExecutedTrinoQeuryId() { + java.lang.Object ref = lastExecutedTrinoQeuryId_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + lastExecutedTrinoQeuryId_ = s; + return s; + } + } + /** + * optional string last_executed_trino_qeury_id = 11; + * @return The bytes for lastExecutedTrinoQeuryId. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getLastExecutedTrinoQeuryIdBytes() { + java.lang.Object ref = lastExecutedTrinoQeuryId_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + lastExecutedTrinoQeuryId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int AUTHOR_FIELD_NUMBER = 12; + @SuppressWarnings("serial") + private volatile java.lang.Object author_ = ""; + /** + * optional string author = 12; + * @return Whether the author field is set. + */ + @java.lang.Override + public boolean hasAuthor() { + return ((bitField0_ & 0x00000080) != 0); + } + /** + * optional string author = 12; + * @return The author. + */ + @java.lang.Override + public java.lang.String getAuthor() { + java.lang.Object ref = author_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + author_ = s; + return s; + } + } + /** + * optional string author = 12; + * @return The bytes for author. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getAuthorBytes() { + java.lang.Object ref = author_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + author_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int UNEXPANDED_SQL_QUERY_FIELD_NUMBER = 13; + @SuppressWarnings("serial") + private volatile java.lang.Object unexpandedSqlQuery_ = ""; + /** + * optional string unexpanded_sql_query = 13; + * @return Whether the unexpandedSqlQuery field is set. + */ + @java.lang.Override + public boolean hasUnexpandedSqlQuery() { + return ((bitField0_ & 0x00000100) != 0); + } + /** + * optional string unexpanded_sql_query = 13; + * @return The unexpandedSqlQuery. + */ + @java.lang.Override + public java.lang.String getUnexpandedSqlQuery() { + java.lang.Object ref = unexpandedSqlQuery_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + unexpandedSqlQuery_ = s; + return s; + } + } + /** + * optional string unexpanded_sql_query = 13; + * @return The bytes for unexpandedSqlQuery. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getUnexpandedSqlQueryBytes() { + java.lang.Object ref = unexpandedSqlQuery_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + unexpandedSqlQuery_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int ORDER_BY_FIELD_NUMBER = 14; + @SuppressWarnings("serial") + private volatile java.lang.Object orderBy_ = ""; + /** + * optional string order_by = 14; + * @return Whether the orderBy field is set. + */ + @java.lang.Override + public boolean hasOrderBy() { + return ((bitField0_ & 0x00000200) != 0); + } + /** + * optional string order_by = 14; + * @return The orderBy. + */ + @java.lang.Override + public java.lang.String getOrderBy() { + java.lang.Object ref = orderBy_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + orderBy_ = s; + return s; + } + } + /** + * optional string order_by = 14; + * @return The bytes for orderBy. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getOrderByBytes() { + java.lang.Object ref = orderBy_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + orderBy_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, id_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(notebookId_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 3, notebookId_); + } + if (notebookVersion_ != 0) { + output.writeInt32(4, notebookVersion_); + } + if (((bitField0_ & 0x00000001) != 0)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 5, name_); + } + if (((bitField0_ & 0x00000002) != 0)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 6, sqlQuery_); + } + if (((bitField0_ & 0x00000004) != 0)) { + output.writeMessage(7, getCellConfig()); + } + if (((bitField0_ & 0x00000008) != 0)) { + output.writeInt32(8, lastExecutionState_); + } + if (((bitField0_ & 0x00000010) != 0)) { + output.writeInt64(9, lastExecutedAt_); + } + if (((bitField0_ & 0x00000020) != 0)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 10, lastExecutionError_); + } + if (((bitField0_ & 0x00000040) != 0)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 11, lastExecutedTrinoQeuryId_); + } + if (((bitField0_ & 0x00000080) != 0)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 12, author_); + } + if (((bitField0_ & 0x00000100) != 0)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 13, unexpandedSqlQuery_); + } + if (((bitField0_ & 0x00000200) != 0)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 14, orderBy_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, id_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(notebookId_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(3, notebookId_); + } + if (notebookVersion_ != 0) { + size += com.google.protobuf.CodedOutputStream + .computeInt32Size(4, notebookVersion_); + } + if (((bitField0_ & 0x00000001) != 0)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(5, name_); + } + if (((bitField0_ & 0x00000002) != 0)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(6, sqlQuery_); + } + if (((bitField0_ & 0x00000004) != 0)) { + size += com.google.protobuf.CodedOutputStream + .computeMessageSize(7, getCellConfig()); + } + if (((bitField0_ & 0x00000008) != 0)) { + size += com.google.protobuf.CodedOutputStream + .computeInt32Size(8, lastExecutionState_); + } + if (((bitField0_ & 0x00000010) != 0)) { + size += com.google.protobuf.CodedOutputStream + .computeInt64Size(9, lastExecutedAt_); + } + if (((bitField0_ & 0x00000020) != 0)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(10, lastExecutionError_); + } + if (((bitField0_ & 0x00000040) != 0)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(11, lastExecutedTrinoQeuryId_); + } + if (((bitField0_ & 0x00000080) != 0)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(12, author_); + } + if (((bitField0_ & 0x00000100) != 0)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(13, unexpandedSqlQuery_); + } + if (((bitField0_ & 0x00000200) != 0)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(14, orderBy_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest)) { + return super.equals(obj); + } + io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest other = (io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest) obj; + + if (!getTenant() + .equals(other.getTenant())) return false; + if (!getId() + .equals(other.getId())) return false; + if (!getNotebookId() + .equals(other.getNotebookId())) return false; + if (getNotebookVersion() + != other.getNotebookVersion()) return false; + if (hasName() != other.hasName()) return false; + if (hasName()) { + if (!getName() + .equals(other.getName())) return false; + } + if (hasSqlQuery() != other.hasSqlQuery()) return false; + if (hasSqlQuery()) { + if (!getSqlQuery() + .equals(other.getSqlQuery())) return false; + } + if (hasCellConfig() != other.hasCellConfig()) return false; + if (hasCellConfig()) { + if (!getCellConfig() + .equals(other.getCellConfig())) return false; + } + if (hasLastExecutionState() != other.hasLastExecutionState()) return false; + if (hasLastExecutionState()) { + if (getLastExecutionState() + != other.getLastExecutionState()) return false; + } + if (hasLastExecutedAt() != other.hasLastExecutedAt()) return false; + if (hasLastExecutedAt()) { + if (getLastExecutedAt() + != other.getLastExecutedAt()) return false; + } + if (hasLastExecutionError() != other.hasLastExecutionError()) return false; + if (hasLastExecutionError()) { + if (!getLastExecutionError() + .equals(other.getLastExecutionError())) return false; + } + if (hasLastExecutedTrinoQeuryId() != other.hasLastExecutedTrinoQeuryId()) return false; + if (hasLastExecutedTrinoQeuryId()) { + if (!getLastExecutedTrinoQeuryId() + .equals(other.getLastExecutedTrinoQeuryId())) return false; + } + if (hasAuthor() != other.hasAuthor()) return false; + if (hasAuthor()) { + if (!getAuthor() + .equals(other.getAuthor())) return false; + } + if (hasUnexpandedSqlQuery() != other.hasUnexpandedSqlQuery()) return false; + if (hasUnexpandedSqlQuery()) { + if (!getUnexpandedSqlQuery() + .equals(other.getUnexpandedSqlQuery())) return false; + } + if (hasOrderBy() != other.hasOrderBy()) return false; + if (hasOrderBy()) { + if (!getOrderBy() + .equals(other.getOrderBy())) return false; + } + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + TENANT_FIELD_NUMBER; + hash = (53 * hash) + getTenant().hashCode(); + hash = (37 * hash) + ID_FIELD_NUMBER; + hash = (53 * hash) + getId().hashCode(); + hash = (37 * hash) + NOTEBOOK_ID_FIELD_NUMBER; + hash = (53 * hash) + getNotebookId().hashCode(); + hash = (37 * hash) + NOTEBOOK_VERSION_FIELD_NUMBER; + hash = (53 * hash) + getNotebookVersion(); + if (hasName()) { + hash = (37 * hash) + NAME_FIELD_NUMBER; + hash = (53 * hash) + getName().hashCode(); + } + if (hasSqlQuery()) { + hash = (37 * hash) + SQL_QUERY_FIELD_NUMBER; + hash = (53 * hash) + getSqlQuery().hashCode(); + } + if (hasCellConfig()) { + hash = (37 * hash) + CELL_CONFIG_FIELD_NUMBER; + hash = (53 * hash) + getCellConfig().hashCode(); + } + if (hasLastExecutionState()) { + hash = (37 * hash) + LAST_EXECUTION_STATE_FIELD_NUMBER; + hash = (53 * hash) + getLastExecutionState(); + } + if (hasLastExecutedAt()) { + hash = (37 * hash) + LAST_EXECUTED_AT_FIELD_NUMBER; + hash = (53 * hash) + com.google.protobuf.Internal.hashLong( + getLastExecutedAt()); + } + if (hasLastExecutionError()) { + hash = (37 * hash) + LAST_EXECUTION_ERROR_FIELD_NUMBER; + hash = (53 * hash) + getLastExecutionError().hashCode(); + } + if (hasLastExecutedTrinoQeuryId()) { + hash = (37 * hash) + LAST_EXECUTED_TRINO_QEURY_ID_FIELD_NUMBER; + hash = (53 * hash) + getLastExecutedTrinoQeuryId().hashCode(); + } + if (hasAuthor()) { + hash = (37 * hash) + AUTHOR_FIELD_NUMBER; + hash = (53 * hash) + getAuthor().hashCode(); + } + if (hasUnexpandedSqlQuery()) { + hash = (37 * hash) + UNEXPANDED_SQL_QUERY_FIELD_NUMBER; + hash = (53 * hash) + getUnexpandedSqlQuery().hashCode(); + } + if (hasOrderBy()) { + hash = (37 * hash) + ORDER_BY_FIELD_NUMBER; + hash = (53 * hash) + getOrderBy().hashCode(); + } + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.EditNotebookCellRequest} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.EditNotebookCellRequest) + io.trino.spi.grpc.Trinomanager.EditNotebookCellRequestOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_EditNotebookCellRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_EditNotebookCellRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest.class, io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest.Builder.class); + } + + // Construct using io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest.newBuilder() + private Builder() { + maybeForceBuilderInitialization(); + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + maybeForceBuilderInitialization(); + } + private void maybeForceBuilderInitialization() { + if (com.google.protobuf.GeneratedMessageV3 + .alwaysUseFieldBuilders) { + getCellConfigFieldBuilder(); + } + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + tenant_ = ""; + id_ = ""; + notebookId_ = ""; + notebookVersion_ = 0; + name_ = ""; + sqlQuery_ = ""; + cellConfig_ = null; + if (cellConfigBuilder_ != null) { + cellConfigBuilder_.dispose(); + cellConfigBuilder_ = null; + } + lastExecutionState_ = 0; + lastExecutedAt_ = 0L; + lastExecutionError_ = ""; + lastExecutedTrinoQeuryId_ = ""; + author_ = ""; + unexpandedSqlQuery_ = ""; + orderBy_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_EditNotebookCellRequest_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest getDefaultInstanceForType() { + return io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest build() { + io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest buildPartial() { + io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest result = new io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.tenant_ = tenant_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.id_ = id_; + } + if (((from_bitField0_ & 0x00000004) != 0)) { + result.notebookId_ = notebookId_; + } + if (((from_bitField0_ & 0x00000008) != 0)) { + result.notebookVersion_ = notebookVersion_; + } + int to_bitField0_ = 0; + if (((from_bitField0_ & 0x00000010) != 0)) { + result.name_ = name_; + to_bitField0_ |= 0x00000001; + } + if (((from_bitField0_ & 0x00000020) != 0)) { + result.sqlQuery_ = sqlQuery_; + to_bitField0_ |= 0x00000002; + } + if (((from_bitField0_ & 0x00000040) != 0)) { + result.cellConfig_ = cellConfigBuilder_ == null + ? cellConfig_ + : cellConfigBuilder_.build(); + to_bitField0_ |= 0x00000004; + } + if (((from_bitField0_ & 0x00000080) != 0)) { + result.lastExecutionState_ = lastExecutionState_; + to_bitField0_ |= 0x00000008; + } + if (((from_bitField0_ & 0x00000100) != 0)) { + result.lastExecutedAt_ = lastExecutedAt_; + to_bitField0_ |= 0x00000010; + } + if (((from_bitField0_ & 0x00000200) != 0)) { + result.lastExecutionError_ = lastExecutionError_; + to_bitField0_ |= 0x00000020; + } + if (((from_bitField0_ & 0x00000400) != 0)) { + result.lastExecutedTrinoQeuryId_ = lastExecutedTrinoQeuryId_; + to_bitField0_ |= 0x00000040; + } + if (((from_bitField0_ & 0x00000800) != 0)) { + result.author_ = author_; + to_bitField0_ |= 0x00000080; + } + if (((from_bitField0_ & 0x00001000) != 0)) { + result.unexpandedSqlQuery_ = unexpandedSqlQuery_; + to_bitField0_ |= 0x00000100; + } + if (((from_bitField0_ & 0x00002000) != 0)) { + result.orderBy_ = orderBy_; + to_bitField0_ |= 0x00000200; + } + result.bitField0_ |= to_bitField0_; + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest) { + return mergeFrom((io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest other) { + if (other == io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest.getDefaultInstance()) return this; + if (!other.getTenant().isEmpty()) { + tenant_ = other.tenant_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getId().isEmpty()) { + id_ = other.id_; + bitField0_ |= 0x00000002; + onChanged(); + } + if (!other.getNotebookId().isEmpty()) { + notebookId_ = other.notebookId_; + bitField0_ |= 0x00000004; + onChanged(); + } + if (other.getNotebookVersion() != 0) { + setNotebookVersion(other.getNotebookVersion()); + } + if (other.hasName()) { + name_ = other.name_; + bitField0_ |= 0x00000010; + onChanged(); + } + if (other.hasSqlQuery()) { + sqlQuery_ = other.sqlQuery_; + bitField0_ |= 0x00000020; + onChanged(); + } + if (other.hasCellConfig()) { + mergeCellConfig(other.getCellConfig()); + } + if (other.hasLastExecutionState()) { + setLastExecutionState(other.getLastExecutionState()); + } + if (other.hasLastExecutedAt()) { + setLastExecutedAt(other.getLastExecutedAt()); + } + if (other.hasLastExecutionError()) { + lastExecutionError_ = other.lastExecutionError_; + bitField0_ |= 0x00000200; + onChanged(); + } + if (other.hasLastExecutedTrinoQeuryId()) { + lastExecutedTrinoQeuryId_ = other.lastExecutedTrinoQeuryId_; + bitField0_ |= 0x00000400; + onChanged(); + } + if (other.hasAuthor()) { + author_ = other.author_; + bitField0_ |= 0x00000800; + onChanged(); + } + if (other.hasUnexpandedSqlQuery()) { + unexpandedSqlQuery_ = other.unexpandedSqlQuery_; + bitField0_ |= 0x00001000; + onChanged(); + } + if (other.hasOrderBy()) { + orderBy_ = other.orderBy_; + bitField0_ |= 0x00002000; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + tenant_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + id_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + case 26: { + notebookId_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000004; + break; + } // case 26 + case 32: { + notebookVersion_ = input.readInt32(); + bitField0_ |= 0x00000008; + break; + } // case 32 + case 42: { + name_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000010; + break; + } // case 42 + case 50: { + sqlQuery_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000020; + break; + } // case 50 + case 58: { + input.readMessage( + getCellConfigFieldBuilder().getBuilder(), + extensionRegistry); + bitField0_ |= 0x00000040; + break; + } // case 58 + case 64: { + lastExecutionState_ = input.readInt32(); + bitField0_ |= 0x00000080; + break; + } // case 64 + case 72: { + lastExecutedAt_ = input.readInt64(); + bitField0_ |= 0x00000100; + break; + } // case 72 + case 82: { + lastExecutionError_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000200; + break; + } // case 82 + case 90: { + lastExecutedTrinoQeuryId_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000400; + break; + } // case 90 + case 98: { + author_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000800; + break; + } // case 98 + case 106: { + unexpandedSqlQuery_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00001000; + break; + } // case 106 + case 114: { + orderBy_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00002000; + break; + } // case 114 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant = 1; + * @param value The tenant to set. + * @return This builder for chaining. + */ + public Builder setTenant( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string tenant = 1; + * @return This builder for chaining. + */ + public Builder clearTenant() { + tenant_ = getDefaultInstance().getTenant(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string tenant = 1; + * @param value The bytes for tenant to set. + * @return This builder for chaining. + */ + public Builder setTenantBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object id_ = ""; + /** + * string id = 2; + * @return The id. + */ + public java.lang.String getId() { + java.lang.Object ref = id_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string id = 2; + * @return The bytes for id. + */ + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string id = 2; + * @param value The id to set. + * @return This builder for chaining. + */ + public Builder setId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + id_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string id = 2; + * @return This builder for chaining. + */ + public Builder clearId() { + id_ = getDefaultInstance().getId(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string id = 2; + * @param value The bytes for id to set. + * @return This builder for chaining. + */ + public Builder setIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + id_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + + private java.lang.Object notebookId_ = ""; + /** + * string notebook_id = 3; + * @return The notebookId. + */ + public java.lang.String getNotebookId() { + java.lang.Object ref = notebookId_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + notebookId_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string notebook_id = 3; + * @return The bytes for notebookId. + */ + public com.google.protobuf.ByteString + getNotebookIdBytes() { + java.lang.Object ref = notebookId_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + notebookId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string notebook_id = 3; + * @param value The notebookId to set. + * @return This builder for chaining. + */ + public Builder setNotebookId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + notebookId_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + /** + * string notebook_id = 3; + * @return This builder for chaining. + */ + public Builder clearNotebookId() { + notebookId_ = getDefaultInstance().getNotebookId(); + bitField0_ = (bitField0_ & ~0x00000004); + onChanged(); + return this; + } + /** + * string notebook_id = 3; + * @param value The bytes for notebookId to set. + * @return This builder for chaining. + */ + public Builder setNotebookIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + notebookId_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + + private int notebookVersion_ ; + /** + * int32 notebook_version = 4; + * @return The notebookVersion. + */ + @java.lang.Override + public int getNotebookVersion() { + return notebookVersion_; + } + /** + * int32 notebook_version = 4; + * @param value The notebookVersion to set. + * @return This builder for chaining. + */ + public Builder setNotebookVersion(int value) { + + notebookVersion_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + /** + * int32 notebook_version = 4; + * @return This builder for chaining. + */ + public Builder clearNotebookVersion() { + bitField0_ = (bitField0_ & ~0x00000008); + notebookVersion_ = 0; + onChanged(); + return this; + } + + private java.lang.Object name_ = ""; + /** + * optional string name = 5; + * @return Whether the name field is set. + */ + public boolean hasName() { + return ((bitField0_ & 0x00000010) != 0); + } + /** + * optional string name = 5; + * @return The name. + */ + public java.lang.String getName() { + java.lang.Object ref = name_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + name_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * optional string name = 5; + * @return The bytes for name. + */ + public com.google.protobuf.ByteString + getNameBytes() { + java.lang.Object ref = name_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + name_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * optional string name = 5; + * @param value The name to set. + * @return This builder for chaining. + */ + public Builder setName( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + name_ = value; + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + /** + * optional string name = 5; + * @return This builder for chaining. + */ + public Builder clearName() { + name_ = getDefaultInstance().getName(); + bitField0_ = (bitField0_ & ~0x00000010); + onChanged(); + return this; + } + /** + * optional string name = 5; + * @param value The bytes for name to set. + * @return This builder for chaining. + */ + public Builder setNameBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + name_ = value; + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + + private java.lang.Object sqlQuery_ = ""; + /** + * optional string sql_query = 6; + * @return Whether the sqlQuery field is set. + */ + public boolean hasSqlQuery() { + return ((bitField0_ & 0x00000020) != 0); + } + /** + * optional string sql_query = 6; + * @return The sqlQuery. + */ + public java.lang.String getSqlQuery() { + java.lang.Object ref = sqlQuery_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + sqlQuery_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * optional string sql_query = 6; + * @return The bytes for sqlQuery. + */ + public com.google.protobuf.ByteString + getSqlQueryBytes() { + java.lang.Object ref = sqlQuery_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + sqlQuery_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * optional string sql_query = 6; + * @param value The sqlQuery to set. + * @return This builder for chaining. + */ + public Builder setSqlQuery( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + sqlQuery_ = value; + bitField0_ |= 0x00000020; + onChanged(); + return this; + } + /** + * optional string sql_query = 6; + * @return This builder for chaining. + */ + public Builder clearSqlQuery() { + sqlQuery_ = getDefaultInstance().getSqlQuery(); + bitField0_ = (bitField0_ & ~0x00000020); + onChanged(); + return this; + } + /** + * optional string sql_query = 6; + * @param value The bytes for sqlQuery to set. + * @return This builder for chaining. + */ + public Builder setSqlQueryBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + sqlQuery_ = value; + bitField0_ |= 0x00000020; + onChanged(); + return this; + } + + private io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig cellConfig_; + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig, io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig.Builder, io.trino.spi.grpc.Trinomanager.NotebookCellCellConfigOrBuilder> cellConfigBuilder_; + /** + * optional .grpc.NotebookCellCellConfig cell_config = 7; + * @return Whether the cellConfig field is set. + */ + public boolean hasCellConfig() { + return ((bitField0_ & 0x00000040) != 0); + } + /** + * optional .grpc.NotebookCellCellConfig cell_config = 7; + * @return The cellConfig. + */ + public io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig getCellConfig() { + if (cellConfigBuilder_ == null) { + return cellConfig_ == null ? io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig.getDefaultInstance() : cellConfig_; + } else { + return cellConfigBuilder_.getMessage(); + } + } + /** + * optional .grpc.NotebookCellCellConfig cell_config = 7; + */ + public Builder setCellConfig(io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig value) { + if (cellConfigBuilder_ == null) { + if (value == null) { + throw new NullPointerException(); + } + cellConfig_ = value; + } else { + cellConfigBuilder_.setMessage(value); + } + bitField0_ |= 0x00000040; + onChanged(); + return this; + } + /** + * optional .grpc.NotebookCellCellConfig cell_config = 7; + */ + public Builder setCellConfig( + io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig.Builder builderForValue) { + if (cellConfigBuilder_ == null) { + cellConfig_ = builderForValue.build(); + } else { + cellConfigBuilder_.setMessage(builderForValue.build()); + } + bitField0_ |= 0x00000040; + onChanged(); + return this; + } + /** + * optional .grpc.NotebookCellCellConfig cell_config = 7; + */ + public Builder mergeCellConfig(io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig value) { + if (cellConfigBuilder_ == null) { + if (((bitField0_ & 0x00000040) != 0) && + cellConfig_ != null && + cellConfig_ != io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig.getDefaultInstance()) { + getCellConfigBuilder().mergeFrom(value); + } else { + cellConfig_ = value; + } + } else { + cellConfigBuilder_.mergeFrom(value); + } + bitField0_ |= 0x00000040; + onChanged(); + return this; + } + /** + * optional .grpc.NotebookCellCellConfig cell_config = 7; + */ + public Builder clearCellConfig() { + bitField0_ = (bitField0_ & ~0x00000040); + cellConfig_ = null; + if (cellConfigBuilder_ != null) { + cellConfigBuilder_.dispose(); + cellConfigBuilder_ = null; + } + onChanged(); + return this; + } + /** + * optional .grpc.NotebookCellCellConfig cell_config = 7; + */ + public io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig.Builder getCellConfigBuilder() { + bitField0_ |= 0x00000040; + onChanged(); + return getCellConfigFieldBuilder().getBuilder(); + } + /** + * optional .grpc.NotebookCellCellConfig cell_config = 7; + */ + public io.trino.spi.grpc.Trinomanager.NotebookCellCellConfigOrBuilder getCellConfigOrBuilder() { + if (cellConfigBuilder_ != null) { + return cellConfigBuilder_.getMessageOrBuilder(); + } else { + return cellConfig_ == null ? + io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig.getDefaultInstance() : cellConfig_; + } + } + /** + * optional .grpc.NotebookCellCellConfig cell_config = 7; + */ + private com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig, io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig.Builder, io.trino.spi.grpc.Trinomanager.NotebookCellCellConfigOrBuilder> + getCellConfigFieldBuilder() { + if (cellConfigBuilder_ == null) { + cellConfigBuilder_ = new com.google.protobuf.SingleFieldBuilderV3< + io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig, io.trino.spi.grpc.Trinomanager.NotebookCellCellConfig.Builder, io.trino.spi.grpc.Trinomanager.NotebookCellCellConfigOrBuilder>( + getCellConfig(), + getParentForChildren(), + isClean()); + cellConfig_ = null; + } + return cellConfigBuilder_; + } + + private int lastExecutionState_ ; + /** + * optional int32 last_execution_state = 8; + * @return Whether the lastExecutionState field is set. + */ + @java.lang.Override + public boolean hasLastExecutionState() { + return ((bitField0_ & 0x00000080) != 0); + } + /** + * optional int32 last_execution_state = 8; + * @return The lastExecutionState. + */ + @java.lang.Override + public int getLastExecutionState() { + return lastExecutionState_; + } + /** + * optional int32 last_execution_state = 8; + * @param value The lastExecutionState to set. + * @return This builder for chaining. + */ + public Builder setLastExecutionState(int value) { + + lastExecutionState_ = value; + bitField0_ |= 0x00000080; + onChanged(); + return this; + } + /** + * optional int32 last_execution_state = 8; + * @return This builder for chaining. + */ + public Builder clearLastExecutionState() { + bitField0_ = (bitField0_ & ~0x00000080); + lastExecutionState_ = 0; + onChanged(); + return this; + } + + private long lastExecutedAt_ ; + /** + * optional int64 last_executed_at = 9; + * @return Whether the lastExecutedAt field is set. + */ + @java.lang.Override + public boolean hasLastExecutedAt() { + return ((bitField0_ & 0x00000100) != 0); + } + /** + * optional int64 last_executed_at = 9; + * @return The lastExecutedAt. + */ + @java.lang.Override + public long getLastExecutedAt() { + return lastExecutedAt_; + } + /** + * optional int64 last_executed_at = 9; + * @param value The lastExecutedAt to set. + * @return This builder for chaining. + */ + public Builder setLastExecutedAt(long value) { + + lastExecutedAt_ = value; + bitField0_ |= 0x00000100; + onChanged(); + return this; + } + /** + * optional int64 last_executed_at = 9; + * @return This builder for chaining. + */ + public Builder clearLastExecutedAt() { + bitField0_ = (bitField0_ & ~0x00000100); + lastExecutedAt_ = 0L; + onChanged(); + return this; + } + + private java.lang.Object lastExecutionError_ = ""; + /** + * optional string last_execution_error = 10; + * @return Whether the lastExecutionError field is set. + */ + public boolean hasLastExecutionError() { + return ((bitField0_ & 0x00000200) != 0); + } + /** + * optional string last_execution_error = 10; + * @return The lastExecutionError. + */ + public java.lang.String getLastExecutionError() { + java.lang.Object ref = lastExecutionError_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + lastExecutionError_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * optional string last_execution_error = 10; + * @return The bytes for lastExecutionError. + */ + public com.google.protobuf.ByteString + getLastExecutionErrorBytes() { + java.lang.Object ref = lastExecutionError_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + lastExecutionError_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * optional string last_execution_error = 10; + * @param value The lastExecutionError to set. + * @return This builder for chaining. + */ + public Builder setLastExecutionError( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + lastExecutionError_ = value; + bitField0_ |= 0x00000200; + onChanged(); + return this; + } + /** + * optional string last_execution_error = 10; + * @return This builder for chaining. + */ + public Builder clearLastExecutionError() { + lastExecutionError_ = getDefaultInstance().getLastExecutionError(); + bitField0_ = (bitField0_ & ~0x00000200); + onChanged(); + return this; + } + /** + * optional string last_execution_error = 10; + * @param value The bytes for lastExecutionError to set. + * @return This builder for chaining. + */ + public Builder setLastExecutionErrorBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + lastExecutionError_ = value; + bitField0_ |= 0x00000200; + onChanged(); + return this; + } + + private java.lang.Object lastExecutedTrinoQeuryId_ = ""; + /** + * optional string last_executed_trino_qeury_id = 11; + * @return Whether the lastExecutedTrinoQeuryId field is set. + */ + public boolean hasLastExecutedTrinoQeuryId() { + return ((bitField0_ & 0x00000400) != 0); + } + /** + * optional string last_executed_trino_qeury_id = 11; + * @return The lastExecutedTrinoQeuryId. + */ + public java.lang.String getLastExecutedTrinoQeuryId() { + java.lang.Object ref = lastExecutedTrinoQeuryId_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + lastExecutedTrinoQeuryId_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * optional string last_executed_trino_qeury_id = 11; + * @return The bytes for lastExecutedTrinoQeuryId. + */ + public com.google.protobuf.ByteString + getLastExecutedTrinoQeuryIdBytes() { + java.lang.Object ref = lastExecutedTrinoQeuryId_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + lastExecutedTrinoQeuryId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * optional string last_executed_trino_qeury_id = 11; + * @param value The lastExecutedTrinoQeuryId to set. + * @return This builder for chaining. + */ + public Builder setLastExecutedTrinoQeuryId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + lastExecutedTrinoQeuryId_ = value; + bitField0_ |= 0x00000400; + onChanged(); + return this; + } + /** + * optional string last_executed_trino_qeury_id = 11; + * @return This builder for chaining. + */ + public Builder clearLastExecutedTrinoQeuryId() { + lastExecutedTrinoQeuryId_ = getDefaultInstance().getLastExecutedTrinoQeuryId(); + bitField0_ = (bitField0_ & ~0x00000400); + onChanged(); + return this; + } + /** + * optional string last_executed_trino_qeury_id = 11; + * @param value The bytes for lastExecutedTrinoQeuryId to set. + * @return This builder for chaining. + */ + public Builder setLastExecutedTrinoQeuryIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + lastExecutedTrinoQeuryId_ = value; + bitField0_ |= 0x00000400; + onChanged(); + return this; + } + + private java.lang.Object author_ = ""; + /** + * optional string author = 12; + * @return Whether the author field is set. + */ + public boolean hasAuthor() { + return ((bitField0_ & 0x00000800) != 0); + } + /** + * optional string author = 12; + * @return The author. + */ + public java.lang.String getAuthor() { + java.lang.Object ref = author_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + author_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * optional string author = 12; + * @return The bytes for author. + */ + public com.google.protobuf.ByteString + getAuthorBytes() { + java.lang.Object ref = author_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + author_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * optional string author = 12; + * @param value The author to set. + * @return This builder for chaining. + */ + public Builder setAuthor( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + author_ = value; + bitField0_ |= 0x00000800; + onChanged(); + return this; + } + /** + * optional string author = 12; + * @return This builder for chaining. + */ + public Builder clearAuthor() { + author_ = getDefaultInstance().getAuthor(); + bitField0_ = (bitField0_ & ~0x00000800); + onChanged(); + return this; + } + /** + * optional string author = 12; + * @param value The bytes for author to set. + * @return This builder for chaining. + */ + public Builder setAuthorBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + author_ = value; + bitField0_ |= 0x00000800; + onChanged(); + return this; + } + + private java.lang.Object unexpandedSqlQuery_ = ""; + /** + * optional string unexpanded_sql_query = 13; + * @return Whether the unexpandedSqlQuery field is set. + */ + public boolean hasUnexpandedSqlQuery() { + return ((bitField0_ & 0x00001000) != 0); + } + /** + * optional string unexpanded_sql_query = 13; + * @return The unexpandedSqlQuery. + */ + public java.lang.String getUnexpandedSqlQuery() { + java.lang.Object ref = unexpandedSqlQuery_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + unexpandedSqlQuery_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * optional string unexpanded_sql_query = 13; + * @return The bytes for unexpandedSqlQuery. + */ + public com.google.protobuf.ByteString + getUnexpandedSqlQueryBytes() { + java.lang.Object ref = unexpandedSqlQuery_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + unexpandedSqlQuery_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * optional string unexpanded_sql_query = 13; + * @param value The unexpandedSqlQuery to set. + * @return This builder for chaining. + */ + public Builder setUnexpandedSqlQuery( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + unexpandedSqlQuery_ = value; + bitField0_ |= 0x00001000; + onChanged(); + return this; + } + /** + * optional string unexpanded_sql_query = 13; + * @return This builder for chaining. + */ + public Builder clearUnexpandedSqlQuery() { + unexpandedSqlQuery_ = getDefaultInstance().getUnexpandedSqlQuery(); + bitField0_ = (bitField0_ & ~0x00001000); + onChanged(); + return this; + } + /** + * optional string unexpanded_sql_query = 13; + * @param value The bytes for unexpandedSqlQuery to set. + * @return This builder for chaining. + */ + public Builder setUnexpandedSqlQueryBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + unexpandedSqlQuery_ = value; + bitField0_ |= 0x00001000; + onChanged(); + return this; + } + + private java.lang.Object orderBy_ = ""; + /** + * optional string order_by = 14; + * @return Whether the orderBy field is set. + */ + public boolean hasOrderBy() { + return ((bitField0_ & 0x00002000) != 0); + } + /** + * optional string order_by = 14; + * @return The orderBy. + */ + public java.lang.String getOrderBy() { + java.lang.Object ref = orderBy_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + orderBy_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * optional string order_by = 14; + * @return The bytes for orderBy. + */ + public com.google.protobuf.ByteString + getOrderByBytes() { + java.lang.Object ref = orderBy_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + orderBy_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * optional string order_by = 14; + * @param value The orderBy to set. + * @return This builder for chaining. + */ + public Builder setOrderBy( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + orderBy_ = value; + bitField0_ |= 0x00002000; + onChanged(); + return this; + } + /** + * optional string order_by = 14; + * @return This builder for chaining. + */ + public Builder clearOrderBy() { + orderBy_ = getDefaultInstance().getOrderBy(); + bitField0_ = (bitField0_ & ~0x00002000); + onChanged(); + return this; + } + /** + * optional string order_by = 14; + * @param value The bytes for orderBy to set. + * @return This builder for chaining. + */ + public Builder setOrderByBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + orderBy_ = value; + bitField0_ |= 0x00002000; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.EditNotebookCellRequest) + } + + // @@protoc_insertion_point(class_scope:grpc.EditNotebookCellRequest) + private static final io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest(); + } + + public static io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public EditNotebookCellRequest parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.EditNotebookCellRequest getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface GetNotebookCellRequestOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.GetNotebookCellRequest) + com.google.protobuf.MessageOrBuilder { + + /** + * string tenant = 1; + * @return The tenant. + */ + java.lang.String getTenant(); + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + com.google.protobuf.ByteString + getTenantBytes(); + + /** + * string query_id = 2; + * @return The queryId. + */ + java.lang.String getQueryId(); + /** + * string query_id = 2; + * @return The bytes for queryId. + */ + com.google.protobuf.ByteString + getQueryIdBytes(); + } + /** + * Protobuf type {@code grpc.GetNotebookCellRequest} + */ + public static final class GetNotebookCellRequest extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.GetNotebookCellRequest) + GetNotebookCellRequestOrBuilder { + private static final long serialVersionUID = 0L; + // Use GetNotebookCellRequest.newBuilder() to construct. + private GetNotebookCellRequest(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private GetNotebookCellRequest() { + tenant_ = ""; + queryId_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new GetNotebookCellRequest(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_GetNotebookCellRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_GetNotebookCellRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest.class, io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest.Builder.class); + } + + public static final int TENANT_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + @java.lang.Override + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int QUERY_ID_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object queryId_ = ""; + /** + * string query_id = 2; + * @return The queryId. + */ + @java.lang.Override + public java.lang.String getQueryId() { + java.lang.Object ref = queryId_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + queryId_ = s; + return s; + } + } + /** + * string query_id = 2; + * @return The bytes for queryId. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getQueryIdBytes() { + java.lang.Object ref = queryId_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + queryId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(queryId_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, queryId_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(queryId_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, queryId_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest)) { + return super.equals(obj); + } + io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest other = (io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest) obj; + + if (!getTenant() + .equals(other.getTenant())) return false; + if (!getQueryId() + .equals(other.getQueryId())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + TENANT_FIELD_NUMBER; + hash = (53 * hash) + getTenant().hashCode(); + hash = (37 * hash) + QUERY_ID_FIELD_NUMBER; + hash = (53 * hash) + getQueryId().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.GetNotebookCellRequest} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.GetNotebookCellRequest) + io.trino.spi.grpc.Trinomanager.GetNotebookCellRequestOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_GetNotebookCellRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_GetNotebookCellRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest.class, io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest.Builder.class); + } + + // Construct using io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + tenant_ = ""; + queryId_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_GetNotebookCellRequest_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest getDefaultInstanceForType() { + return io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest build() { + io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest buildPartial() { + io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest result = new io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.tenant_ = tenant_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.queryId_ = queryId_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest) { + return mergeFrom((io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest other) { + if (other == io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest.getDefaultInstance()) return this; + if (!other.getTenant().isEmpty()) { + tenant_ = other.tenant_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getQueryId().isEmpty()) { + queryId_ = other.queryId_; + bitField0_ |= 0x00000002; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + tenant_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + queryId_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant = 1; + * @param value The tenant to set. + * @return This builder for chaining. + */ + public Builder setTenant( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string tenant = 1; + * @return This builder for chaining. + */ + public Builder clearTenant() { + tenant_ = getDefaultInstance().getTenant(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string tenant = 1; + * @param value The bytes for tenant to set. + * @return This builder for chaining. + */ + public Builder setTenantBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object queryId_ = ""; + /** + * string query_id = 2; + * @return The queryId. + */ + public java.lang.String getQueryId() { + java.lang.Object ref = queryId_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + queryId_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string query_id = 2; + * @return The bytes for queryId. + */ + public com.google.protobuf.ByteString + getQueryIdBytes() { + java.lang.Object ref = queryId_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + queryId_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string query_id = 2; + * @param value The queryId to set. + * @return This builder for chaining. + */ + public Builder setQueryId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + queryId_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string query_id = 2; + * @return This builder for chaining. + */ + public Builder clearQueryId() { + queryId_ = getDefaultInstance().getQueryId(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string query_id = 2; + * @param value The bytes for queryId to set. + * @return This builder for chaining. + */ + public Builder setQueryIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + queryId_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.GetNotebookCellRequest) + } + + // @@protoc_insertion_point(class_scope:grpc.GetNotebookCellRequest) + private static final io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest(); + } + + public static io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public GetNotebookCellRequest parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.GetNotebookCellRequest getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface GetNotebookRequestOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.GetNotebookRequest) + com.google.protobuf.MessageOrBuilder { + + /** + * string tenant = 1; + * @return The tenant. + */ + java.lang.String getTenant(); + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + com.google.protobuf.ByteString + getTenantBytes(); + + /** + * string id = 2; + * @return The id. + */ + java.lang.String getId(); + /** + * string id = 2; + * @return The bytes for id. + */ + com.google.protobuf.ByteString + getIdBytes(); + } + /** + * Protobuf type {@code grpc.GetNotebookRequest} + */ + public static final class GetNotebookRequest extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.GetNotebookRequest) + GetNotebookRequestOrBuilder { + private static final long serialVersionUID = 0L; + // Use GetNotebookRequest.newBuilder() to construct. + private GetNotebookRequest(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private GetNotebookRequest() { + tenant_ = ""; + id_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new GetNotebookRequest(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_GetNotebookRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_GetNotebookRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.GetNotebookRequest.class, io.trino.spi.grpc.Trinomanager.GetNotebookRequest.Builder.class); + } + + public static final int TENANT_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + @java.lang.Override + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int ID_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object id_ = ""; + /** + * string id = 2; + * @return The id. + */ + @java.lang.Override + public java.lang.String getId() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } + } + /** + * string id = 2; + * @return The bytes for id. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, id_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, id_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Trinomanager.GetNotebookRequest)) { + return super.equals(obj); + } + io.trino.spi.grpc.Trinomanager.GetNotebookRequest other = (io.trino.spi.grpc.Trinomanager.GetNotebookRequest) obj; + + if (!getTenant() + .equals(other.getTenant())) return false; + if (!getId() + .equals(other.getId())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + TENANT_FIELD_NUMBER; + hash = (53 * hash) + getTenant().hashCode(); + hash = (37 * hash) + ID_FIELD_NUMBER; + hash = (53 * hash) + getId().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Trinomanager.GetNotebookRequest parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.GetNotebookRequest parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.GetNotebookRequest parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.GetNotebookRequest parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.GetNotebookRequest parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.GetNotebookRequest parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.GetNotebookRequest parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.GetNotebookRequest parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Trinomanager.GetNotebookRequest parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Trinomanager.GetNotebookRequest parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.GetNotebookRequest parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.GetNotebookRequest parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Trinomanager.GetNotebookRequest prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.GetNotebookRequest} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.GetNotebookRequest) + io.trino.spi.grpc.Trinomanager.GetNotebookRequestOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_GetNotebookRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_GetNotebookRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.GetNotebookRequest.class, io.trino.spi.grpc.Trinomanager.GetNotebookRequest.Builder.class); + } + + // Construct using io.trino.spi.grpc.Trinomanager.GetNotebookRequest.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + tenant_ = ""; + id_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_GetNotebookRequest_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.GetNotebookRequest getDefaultInstanceForType() { + return io.trino.spi.grpc.Trinomanager.GetNotebookRequest.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.GetNotebookRequest build() { + io.trino.spi.grpc.Trinomanager.GetNotebookRequest result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.GetNotebookRequest buildPartial() { + io.trino.spi.grpc.Trinomanager.GetNotebookRequest result = new io.trino.spi.grpc.Trinomanager.GetNotebookRequest(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Trinomanager.GetNotebookRequest result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.tenant_ = tenant_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.id_ = id_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Trinomanager.GetNotebookRequest) { + return mergeFrom((io.trino.spi.grpc.Trinomanager.GetNotebookRequest)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Trinomanager.GetNotebookRequest other) { + if (other == io.trino.spi.grpc.Trinomanager.GetNotebookRequest.getDefaultInstance()) return this; + if (!other.getTenant().isEmpty()) { + tenant_ = other.tenant_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getId().isEmpty()) { + id_ = other.id_; + bitField0_ |= 0x00000002; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + tenant_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + id_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant = 1; + * @param value The tenant to set. + * @return This builder for chaining. + */ + public Builder setTenant( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string tenant = 1; + * @return This builder for chaining. + */ + public Builder clearTenant() { + tenant_ = getDefaultInstance().getTenant(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string tenant = 1; + * @param value The bytes for tenant to set. + * @return This builder for chaining. + */ + public Builder setTenantBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object id_ = ""; + /** + * string id = 2; + * @return The id. + */ + public java.lang.String getId() { + java.lang.Object ref = id_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string id = 2; + * @return The bytes for id. + */ + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string id = 2; + * @param value The id to set. + * @return This builder for chaining. + */ + public Builder setId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + id_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string id = 2; + * @return This builder for chaining. + */ + public Builder clearId() { + id_ = getDefaultInstance().getId(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string id = 2; + * @param value The bytes for id to set. + * @return This builder for chaining. + */ + public Builder setIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + id_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.GetNotebookRequest) + } + + // @@protoc_insertion_point(class_scope:grpc.GetNotebookRequest) + private static final io.trino.spi.grpc.Trinomanager.GetNotebookRequest DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Trinomanager.GetNotebookRequest(); + } + + public static io.trino.spi.grpc.Trinomanager.GetNotebookRequest getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public GetNotebookRequest parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.GetNotebookRequest getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface CreateNotebookRequestOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.CreateNotebookRequest) + com.google.protobuf.MessageOrBuilder { + + /** + * string tenant = 1; + * @return The tenant. + */ + java.lang.String getTenant(); + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + com.google.protobuf.ByteString + getTenantBytes(); + + /** + * string title = 2; + * @return The title. + */ + java.lang.String getTitle(); + /** + * string title = 2; + * @return The bytes for title. + */ + com.google.protobuf.ByteString + getTitleBytes(); + + /** + * string description = 3; + * @return The description. + */ + java.lang.String getDescription(); + /** + * string description = 3; + * @return The bytes for description. + */ + com.google.protobuf.ByteString + getDescriptionBytes(); + + /** + * string author = 4; + * @return The author. + */ + java.lang.String getAuthor(); + /** + * string author = 4; + * @return The bytes for author. + */ + com.google.protobuf.ByteString + getAuthorBytes(); + + /** + * string owner = 5; + * @return The owner. + */ + java.lang.String getOwner(); + /** + * string owner = 5; + * @return The bytes for owner. + */ + com.google.protobuf.ByteString + getOwnerBytes(); + } + /** + * Protobuf type {@code grpc.CreateNotebookRequest} + */ + public static final class CreateNotebookRequest extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.CreateNotebookRequest) + CreateNotebookRequestOrBuilder { + private static final long serialVersionUID = 0L; + // Use CreateNotebookRequest.newBuilder() to construct. + private CreateNotebookRequest(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private CreateNotebookRequest() { + tenant_ = ""; + title_ = ""; + description_ = ""; + author_ = ""; + owner_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new CreateNotebookRequest(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_CreateNotebookRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_CreateNotebookRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.CreateNotebookRequest.class, io.trino.spi.grpc.Trinomanager.CreateNotebookRequest.Builder.class); + } + + public static final int TENANT_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + @java.lang.Override + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int TITLE_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object title_ = ""; + /** + * string title = 2; + * @return The title. + */ + @java.lang.Override + public java.lang.String getTitle() { + java.lang.Object ref = title_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + title_ = s; + return s; + } + } + /** + * string title = 2; + * @return The bytes for title. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTitleBytes() { + java.lang.Object ref = title_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + title_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int DESCRIPTION_FIELD_NUMBER = 3; + @SuppressWarnings("serial") + private volatile java.lang.Object description_ = ""; + /** + * string description = 3; + * @return The description. + */ + @java.lang.Override + public java.lang.String getDescription() { + java.lang.Object ref = description_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + description_ = s; + return s; + } + } + /** + * string description = 3; + * @return The bytes for description. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getDescriptionBytes() { + java.lang.Object ref = description_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + description_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int AUTHOR_FIELD_NUMBER = 4; + @SuppressWarnings("serial") + private volatile java.lang.Object author_ = ""; + /** + * string author = 4; + * @return The author. + */ + @java.lang.Override + public java.lang.String getAuthor() { + java.lang.Object ref = author_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + author_ = s; + return s; + } + } + /** + * string author = 4; + * @return The bytes for author. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getAuthorBytes() { + java.lang.Object ref = author_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + author_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int OWNER_FIELD_NUMBER = 5; + @SuppressWarnings("serial") + private volatile java.lang.Object owner_ = ""; + /** + * string owner = 5; + * @return The owner. + */ + @java.lang.Override + public java.lang.String getOwner() { + java.lang.Object ref = owner_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + owner_ = s; + return s; + } + } + /** + * string owner = 5; + * @return The bytes for owner. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getOwnerBytes() { + java.lang.Object ref = owner_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + owner_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(title_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, title_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(description_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 3, description_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(author_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 4, author_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(owner_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 5, owner_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(title_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, title_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(description_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(3, description_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(author_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(4, author_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(owner_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(5, owner_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Trinomanager.CreateNotebookRequest)) { + return super.equals(obj); + } + io.trino.spi.grpc.Trinomanager.CreateNotebookRequest other = (io.trino.spi.grpc.Trinomanager.CreateNotebookRequest) obj; + + if (!getTenant() + .equals(other.getTenant())) return false; + if (!getTitle() + .equals(other.getTitle())) return false; + if (!getDescription() + .equals(other.getDescription())) return false; + if (!getAuthor() + .equals(other.getAuthor())) return false; + if (!getOwner() + .equals(other.getOwner())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + TENANT_FIELD_NUMBER; + hash = (53 * hash) + getTenant().hashCode(); + hash = (37 * hash) + TITLE_FIELD_NUMBER; + hash = (53 * hash) + getTitle().hashCode(); + hash = (37 * hash) + DESCRIPTION_FIELD_NUMBER; + hash = (53 * hash) + getDescription().hashCode(); + hash = (37 * hash) + AUTHOR_FIELD_NUMBER; + hash = (53 * hash) + getAuthor().hashCode(); + hash = (37 * hash) + OWNER_FIELD_NUMBER; + hash = (53 * hash) + getOwner().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Trinomanager.CreateNotebookRequest parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.CreateNotebookRequest parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.CreateNotebookRequest parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.CreateNotebookRequest parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.CreateNotebookRequest parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.CreateNotebookRequest parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.CreateNotebookRequest parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.CreateNotebookRequest parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Trinomanager.CreateNotebookRequest parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Trinomanager.CreateNotebookRequest parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.CreateNotebookRequest parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.CreateNotebookRequest parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Trinomanager.CreateNotebookRequest prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.CreateNotebookRequest} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.CreateNotebookRequest) + io.trino.spi.grpc.Trinomanager.CreateNotebookRequestOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_CreateNotebookRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_CreateNotebookRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.CreateNotebookRequest.class, io.trino.spi.grpc.Trinomanager.CreateNotebookRequest.Builder.class); + } + + // Construct using io.trino.spi.grpc.Trinomanager.CreateNotebookRequest.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + tenant_ = ""; + title_ = ""; + description_ = ""; + author_ = ""; + owner_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_CreateNotebookRequest_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.CreateNotebookRequest getDefaultInstanceForType() { + return io.trino.spi.grpc.Trinomanager.CreateNotebookRequest.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.CreateNotebookRequest build() { + io.trino.spi.grpc.Trinomanager.CreateNotebookRequest result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.CreateNotebookRequest buildPartial() { + io.trino.spi.grpc.Trinomanager.CreateNotebookRequest result = new io.trino.spi.grpc.Trinomanager.CreateNotebookRequest(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Trinomanager.CreateNotebookRequest result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.tenant_ = tenant_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.title_ = title_; + } + if (((from_bitField0_ & 0x00000004) != 0)) { + result.description_ = description_; + } + if (((from_bitField0_ & 0x00000008) != 0)) { + result.author_ = author_; + } + if (((from_bitField0_ & 0x00000010) != 0)) { + result.owner_ = owner_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Trinomanager.CreateNotebookRequest) { + return mergeFrom((io.trino.spi.grpc.Trinomanager.CreateNotebookRequest)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Trinomanager.CreateNotebookRequest other) { + if (other == io.trino.spi.grpc.Trinomanager.CreateNotebookRequest.getDefaultInstance()) return this; + if (!other.getTenant().isEmpty()) { + tenant_ = other.tenant_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getTitle().isEmpty()) { + title_ = other.title_; + bitField0_ |= 0x00000002; + onChanged(); + } + if (!other.getDescription().isEmpty()) { + description_ = other.description_; + bitField0_ |= 0x00000004; + onChanged(); + } + if (!other.getAuthor().isEmpty()) { + author_ = other.author_; + bitField0_ |= 0x00000008; + onChanged(); + } + if (!other.getOwner().isEmpty()) { + owner_ = other.owner_; + bitField0_ |= 0x00000010; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + tenant_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + title_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + case 26: { + description_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000004; + break; + } // case 26 + case 34: { + author_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000008; + break; + } // case 34 + case 42: { + owner_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000010; + break; + } // case 42 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant = 1; + * @param value The tenant to set. + * @return This builder for chaining. + */ + public Builder setTenant( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string tenant = 1; + * @return This builder for chaining. + */ + public Builder clearTenant() { + tenant_ = getDefaultInstance().getTenant(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string tenant = 1; + * @param value The bytes for tenant to set. + * @return This builder for chaining. + */ + public Builder setTenantBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object title_ = ""; + /** + * string title = 2; + * @return The title. + */ + public java.lang.String getTitle() { + java.lang.Object ref = title_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + title_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string title = 2; + * @return The bytes for title. + */ + public com.google.protobuf.ByteString + getTitleBytes() { + java.lang.Object ref = title_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + title_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string title = 2; + * @param value The title to set. + * @return This builder for chaining. + */ + public Builder setTitle( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + title_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string title = 2; + * @return This builder for chaining. + */ + public Builder clearTitle() { + title_ = getDefaultInstance().getTitle(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string title = 2; + * @param value The bytes for title to set. + * @return This builder for chaining. + */ + public Builder setTitleBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + title_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + + private java.lang.Object description_ = ""; + /** + * string description = 3; + * @return The description. + */ + public java.lang.String getDescription() { + java.lang.Object ref = description_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + description_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string description = 3; + * @return The bytes for description. + */ + public com.google.protobuf.ByteString + getDescriptionBytes() { + java.lang.Object ref = description_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + description_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string description = 3; + * @param value The description to set. + * @return This builder for chaining. + */ + public Builder setDescription( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + description_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + /** + * string description = 3; + * @return This builder for chaining. + */ + public Builder clearDescription() { + description_ = getDefaultInstance().getDescription(); + bitField0_ = (bitField0_ & ~0x00000004); + onChanged(); + return this; + } + /** + * string description = 3; + * @param value The bytes for description to set. + * @return This builder for chaining. + */ + public Builder setDescriptionBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + description_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + + private java.lang.Object author_ = ""; + /** + * string author = 4; + * @return The author. + */ + public java.lang.String getAuthor() { + java.lang.Object ref = author_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + author_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string author = 4; + * @return The bytes for author. + */ + public com.google.protobuf.ByteString + getAuthorBytes() { + java.lang.Object ref = author_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + author_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string author = 4; + * @param value The author to set. + * @return This builder for chaining. + */ + public Builder setAuthor( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + author_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + /** + * string author = 4; + * @return This builder for chaining. + */ + public Builder clearAuthor() { + author_ = getDefaultInstance().getAuthor(); + bitField0_ = (bitField0_ & ~0x00000008); + onChanged(); + return this; + } + /** + * string author = 4; + * @param value The bytes for author to set. + * @return This builder for chaining. + */ + public Builder setAuthorBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + author_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + + private java.lang.Object owner_ = ""; + /** + * string owner = 5; + * @return The owner. + */ + public java.lang.String getOwner() { + java.lang.Object ref = owner_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + owner_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string owner = 5; + * @return The bytes for owner. + */ + public com.google.protobuf.ByteString + getOwnerBytes() { + java.lang.Object ref = owner_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + owner_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string owner = 5; + * @param value The owner to set. + * @return This builder for chaining. + */ + public Builder setOwner( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + owner_ = value; + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + /** + * string owner = 5; + * @return This builder for chaining. + */ + public Builder clearOwner() { + owner_ = getDefaultInstance().getOwner(); + bitField0_ = (bitField0_ & ~0x00000010); + onChanged(); + return this; + } + /** + * string owner = 5; + * @param value The bytes for owner to set. + * @return This builder for chaining. + */ + public Builder setOwnerBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + owner_ = value; + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.CreateNotebookRequest) + } + + // @@protoc_insertion_point(class_scope:grpc.CreateNotebookRequest) + private static final io.trino.spi.grpc.Trinomanager.CreateNotebookRequest DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Trinomanager.CreateNotebookRequest(); + } + + public static io.trino.spi.grpc.Trinomanager.CreateNotebookRequest getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public CreateNotebookRequest parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.CreateNotebookRequest getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface EditNotebookRequestOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.EditNotebookRequest) + com.google.protobuf.MessageOrBuilder { + + /** + * string tenant = 1; + * @return The tenant. + */ + java.lang.String getTenant(); + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + com.google.protobuf.ByteString + getTenantBytes(); + + /** + * string id = 2; + * @return The id. + */ + java.lang.String getId(); + /** + * string id = 2; + * @return The bytes for id. + */ + com.google.protobuf.ByteString + getIdBytes(); + + /** + * optional string title = 3; + * @return Whether the title field is set. + */ + boolean hasTitle(); + /** + * optional string title = 3; + * @return The title. + */ + java.lang.String getTitle(); + /** + * optional string title = 3; + * @return The bytes for title. + */ + com.google.protobuf.ByteString + getTitleBytes(); + + /** + * optional string description = 4; + * @return Whether the description field is set. + */ + boolean hasDescription(); + /** + * optional string description = 4; + * @return The description. + */ + java.lang.String getDescription(); + /** + * optional string description = 4; + * @return The bytes for description. + */ + com.google.protobuf.ByteString + getDescriptionBytes(); + + /** + * string author = 5; + * @return The author. + */ + java.lang.String getAuthor(); + /** + * string author = 5; + * @return The bytes for author. + */ + com.google.protobuf.ByteString + getAuthorBytes(); + + /** + * int32 version = 6; + * @return The version. + */ + int getVersion(); + } + /** + * Protobuf type {@code grpc.EditNotebookRequest} + */ + public static final class EditNotebookRequest extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.EditNotebookRequest) + EditNotebookRequestOrBuilder { + private static final long serialVersionUID = 0L; + // Use EditNotebookRequest.newBuilder() to construct. + private EditNotebookRequest(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private EditNotebookRequest() { + tenant_ = ""; + id_ = ""; + title_ = ""; + description_ = ""; + author_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new EditNotebookRequest(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_EditNotebookRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_EditNotebookRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.EditNotebookRequest.class, io.trino.spi.grpc.Trinomanager.EditNotebookRequest.Builder.class); + } + + private int bitField0_; + public static final int TENANT_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + @java.lang.Override + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int ID_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object id_ = ""; + /** + * string id = 2; + * @return The id. + */ + @java.lang.Override + public java.lang.String getId() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } + } + /** + * string id = 2; + * @return The bytes for id. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int TITLE_FIELD_NUMBER = 3; + @SuppressWarnings("serial") + private volatile java.lang.Object title_ = ""; + /** + * optional string title = 3; + * @return Whether the title field is set. + */ + @java.lang.Override + public boolean hasTitle() { + return ((bitField0_ & 0x00000001) != 0); + } + /** + * optional string title = 3; + * @return The title. + */ + @java.lang.Override + public java.lang.String getTitle() { + java.lang.Object ref = title_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + title_ = s; + return s; + } + } + /** + * optional string title = 3; + * @return The bytes for title. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTitleBytes() { + java.lang.Object ref = title_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + title_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int DESCRIPTION_FIELD_NUMBER = 4; + @SuppressWarnings("serial") + private volatile java.lang.Object description_ = ""; + /** + * optional string description = 4; + * @return Whether the description field is set. + */ + @java.lang.Override + public boolean hasDescription() { + return ((bitField0_ & 0x00000002) != 0); + } + /** + * optional string description = 4; + * @return The description. + */ + @java.lang.Override + public java.lang.String getDescription() { + java.lang.Object ref = description_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + description_ = s; + return s; + } + } + /** + * optional string description = 4; + * @return The bytes for description. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getDescriptionBytes() { + java.lang.Object ref = description_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + description_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int AUTHOR_FIELD_NUMBER = 5; + @SuppressWarnings("serial") + private volatile java.lang.Object author_ = ""; + /** + * string author = 5; + * @return The author. + */ + @java.lang.Override + public java.lang.String getAuthor() { + java.lang.Object ref = author_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + author_ = s; + return s; + } + } + /** + * string author = 5; + * @return The bytes for author. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getAuthorBytes() { + java.lang.Object ref = author_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + author_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int VERSION_FIELD_NUMBER = 6; + private int version_ = 0; + /** + * int32 version = 6; + * @return The version. + */ + @java.lang.Override + public int getVersion() { + return version_; + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, id_); + } + if (((bitField0_ & 0x00000001) != 0)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 3, title_); + } + if (((bitField0_ & 0x00000002) != 0)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 4, description_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(author_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 5, author_); + } + if (version_ != 0) { + output.writeInt32(6, version_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, id_); + } + if (((bitField0_ & 0x00000001) != 0)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(3, title_); + } + if (((bitField0_ & 0x00000002) != 0)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(4, description_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(author_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(5, author_); + } + if (version_ != 0) { + size += com.google.protobuf.CodedOutputStream + .computeInt32Size(6, version_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Trinomanager.EditNotebookRequest)) { + return super.equals(obj); + } + io.trino.spi.grpc.Trinomanager.EditNotebookRequest other = (io.trino.spi.grpc.Trinomanager.EditNotebookRequest) obj; + + if (!getTenant() + .equals(other.getTenant())) return false; + if (!getId() + .equals(other.getId())) return false; + if (hasTitle() != other.hasTitle()) return false; + if (hasTitle()) { + if (!getTitle() + .equals(other.getTitle())) return false; + } + if (hasDescription() != other.hasDescription()) return false; + if (hasDescription()) { + if (!getDescription() + .equals(other.getDescription())) return false; + } + if (!getAuthor() + .equals(other.getAuthor())) return false; + if (getVersion() + != other.getVersion()) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + TENANT_FIELD_NUMBER; + hash = (53 * hash) + getTenant().hashCode(); + hash = (37 * hash) + ID_FIELD_NUMBER; + hash = (53 * hash) + getId().hashCode(); + if (hasTitle()) { + hash = (37 * hash) + TITLE_FIELD_NUMBER; + hash = (53 * hash) + getTitle().hashCode(); + } + if (hasDescription()) { + hash = (37 * hash) + DESCRIPTION_FIELD_NUMBER; + hash = (53 * hash) + getDescription().hashCode(); + } + hash = (37 * hash) + AUTHOR_FIELD_NUMBER; + hash = (53 * hash) + getAuthor().hashCode(); + hash = (37 * hash) + VERSION_FIELD_NUMBER; + hash = (53 * hash) + getVersion(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Trinomanager.EditNotebookRequest parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.EditNotebookRequest parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.EditNotebookRequest parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.EditNotebookRequest parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.EditNotebookRequest parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.EditNotebookRequest parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.EditNotebookRequest parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.EditNotebookRequest parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Trinomanager.EditNotebookRequest parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Trinomanager.EditNotebookRequest parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.EditNotebookRequest parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.EditNotebookRequest parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Trinomanager.EditNotebookRequest prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.EditNotebookRequest} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.EditNotebookRequest) + io.trino.spi.grpc.Trinomanager.EditNotebookRequestOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_EditNotebookRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_EditNotebookRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.EditNotebookRequest.class, io.trino.spi.grpc.Trinomanager.EditNotebookRequest.Builder.class); + } + + // Construct using io.trino.spi.grpc.Trinomanager.EditNotebookRequest.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + tenant_ = ""; + id_ = ""; + title_ = ""; + description_ = ""; + author_ = ""; + version_ = 0; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_EditNotebookRequest_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.EditNotebookRequest getDefaultInstanceForType() { + return io.trino.spi.grpc.Trinomanager.EditNotebookRequest.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.EditNotebookRequest build() { + io.trino.spi.grpc.Trinomanager.EditNotebookRequest result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.EditNotebookRequest buildPartial() { + io.trino.spi.grpc.Trinomanager.EditNotebookRequest result = new io.trino.spi.grpc.Trinomanager.EditNotebookRequest(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Trinomanager.EditNotebookRequest result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.tenant_ = tenant_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.id_ = id_; + } + int to_bitField0_ = 0; + if (((from_bitField0_ & 0x00000004) != 0)) { + result.title_ = title_; + to_bitField0_ |= 0x00000001; + } + if (((from_bitField0_ & 0x00000008) != 0)) { + result.description_ = description_; + to_bitField0_ |= 0x00000002; + } + if (((from_bitField0_ & 0x00000010) != 0)) { + result.author_ = author_; + } + if (((from_bitField0_ & 0x00000020) != 0)) { + result.version_ = version_; + } + result.bitField0_ |= to_bitField0_; + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Trinomanager.EditNotebookRequest) { + return mergeFrom((io.trino.spi.grpc.Trinomanager.EditNotebookRequest)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Trinomanager.EditNotebookRequest other) { + if (other == io.trino.spi.grpc.Trinomanager.EditNotebookRequest.getDefaultInstance()) return this; + if (!other.getTenant().isEmpty()) { + tenant_ = other.tenant_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getId().isEmpty()) { + id_ = other.id_; + bitField0_ |= 0x00000002; + onChanged(); + } + if (other.hasTitle()) { + title_ = other.title_; + bitField0_ |= 0x00000004; + onChanged(); + } + if (other.hasDescription()) { + description_ = other.description_; + bitField0_ |= 0x00000008; + onChanged(); + } + if (!other.getAuthor().isEmpty()) { + author_ = other.author_; + bitField0_ |= 0x00000010; + onChanged(); + } + if (other.getVersion() != 0) { + setVersion(other.getVersion()); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + tenant_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + id_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + case 26: { + title_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000004; + break; + } // case 26 + case 34: { + description_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000008; + break; + } // case 34 + case 42: { + author_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000010; + break; + } // case 42 + case 48: { + version_ = input.readInt32(); + bitField0_ |= 0x00000020; + break; + } // case 48 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant = 1; + * @param value The tenant to set. + * @return This builder for chaining. + */ + public Builder setTenant( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string tenant = 1; + * @return This builder for chaining. + */ + public Builder clearTenant() { + tenant_ = getDefaultInstance().getTenant(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string tenant = 1; + * @param value The bytes for tenant to set. + * @return This builder for chaining. + */ + public Builder setTenantBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object id_ = ""; + /** + * string id = 2; + * @return The id. + */ + public java.lang.String getId() { + java.lang.Object ref = id_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string id = 2; + * @return The bytes for id. + */ + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string id = 2; + * @param value The id to set. + * @return This builder for chaining. + */ + public Builder setId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + id_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string id = 2; + * @return This builder for chaining. + */ + public Builder clearId() { + id_ = getDefaultInstance().getId(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string id = 2; + * @param value The bytes for id to set. + * @return This builder for chaining. + */ + public Builder setIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + id_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + + private java.lang.Object title_ = ""; + /** + * optional string title = 3; + * @return Whether the title field is set. + */ + public boolean hasTitle() { + return ((bitField0_ & 0x00000004) != 0); + } + /** + * optional string title = 3; + * @return The title. + */ + public java.lang.String getTitle() { + java.lang.Object ref = title_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + title_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * optional string title = 3; + * @return The bytes for title. + */ + public com.google.protobuf.ByteString + getTitleBytes() { + java.lang.Object ref = title_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + title_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * optional string title = 3; + * @param value The title to set. + * @return This builder for chaining. + */ + public Builder setTitle( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + title_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + /** + * optional string title = 3; + * @return This builder for chaining. + */ + public Builder clearTitle() { + title_ = getDefaultInstance().getTitle(); + bitField0_ = (bitField0_ & ~0x00000004); + onChanged(); + return this; + } + /** + * optional string title = 3; + * @param value The bytes for title to set. + * @return This builder for chaining. + */ + public Builder setTitleBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + title_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + + private java.lang.Object description_ = ""; + /** + * optional string description = 4; + * @return Whether the description field is set. + */ + public boolean hasDescription() { + return ((bitField0_ & 0x00000008) != 0); + } + /** + * optional string description = 4; + * @return The description. + */ + public java.lang.String getDescription() { + java.lang.Object ref = description_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + description_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * optional string description = 4; + * @return The bytes for description. + */ + public com.google.protobuf.ByteString + getDescriptionBytes() { + java.lang.Object ref = description_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + description_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * optional string description = 4; + * @param value The description to set. + * @return This builder for chaining. + */ + public Builder setDescription( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + description_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + /** + * optional string description = 4; + * @return This builder for chaining. + */ + public Builder clearDescription() { + description_ = getDefaultInstance().getDescription(); + bitField0_ = (bitField0_ & ~0x00000008); + onChanged(); + return this; + } + /** + * optional string description = 4; + * @param value The bytes for description to set. + * @return This builder for chaining. + */ + public Builder setDescriptionBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + description_ = value; + bitField0_ |= 0x00000008; + onChanged(); + return this; + } + + private java.lang.Object author_ = ""; + /** + * string author = 5; + * @return The author. + */ + public java.lang.String getAuthor() { + java.lang.Object ref = author_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + author_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string author = 5; + * @return The bytes for author. + */ + public com.google.protobuf.ByteString + getAuthorBytes() { + java.lang.Object ref = author_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + author_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string author = 5; + * @param value The author to set. + * @return This builder for chaining. + */ + public Builder setAuthor( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + author_ = value; + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + /** + * string author = 5; + * @return This builder for chaining. + */ + public Builder clearAuthor() { + author_ = getDefaultInstance().getAuthor(); + bitField0_ = (bitField0_ & ~0x00000010); + onChanged(); + return this; + } + /** + * string author = 5; + * @param value The bytes for author to set. + * @return This builder for chaining. + */ + public Builder setAuthorBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + author_ = value; + bitField0_ |= 0x00000010; + onChanged(); + return this; + } + + private int version_ ; + /** + * int32 version = 6; + * @return The version. + */ + @java.lang.Override + public int getVersion() { + return version_; + } + /** + * int32 version = 6; + * @param value The version to set. + * @return This builder for chaining. + */ + public Builder setVersion(int value) { + + version_ = value; + bitField0_ |= 0x00000020; + onChanged(); + return this; + } + /** + * int32 version = 6; + * @return This builder for chaining. + */ + public Builder clearVersion() { + bitField0_ = (bitField0_ & ~0x00000020); + version_ = 0; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.EditNotebookRequest) + } + + // @@protoc_insertion_point(class_scope:grpc.EditNotebookRequest) + private static final io.trino.spi.grpc.Trinomanager.EditNotebookRequest DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Trinomanager.EditNotebookRequest(); + } + + public static io.trino.spi.grpc.Trinomanager.EditNotebookRequest getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public EditNotebookRequest parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.EditNotebookRequest getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface DeleteNotebookRequestOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.DeleteNotebookRequest) + com.google.protobuf.MessageOrBuilder { + + /** + * string tenant = 1; + * @return The tenant. + */ + java.lang.String getTenant(); + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + com.google.protobuf.ByteString + getTenantBytes(); + + /** + * string id = 2; + * @return The id. + */ + java.lang.String getId(); + /** + * string id = 2; + * @return The bytes for id. + */ + com.google.protobuf.ByteString + getIdBytes(); + + /** + * int32 version = 3; + * @return The version. + */ + int getVersion(); + } + /** + * Protobuf type {@code grpc.DeleteNotebookRequest} + */ + public static final class DeleteNotebookRequest extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.DeleteNotebookRequest) + DeleteNotebookRequestOrBuilder { + private static final long serialVersionUID = 0L; + // Use DeleteNotebookRequest.newBuilder() to construct. + private DeleteNotebookRequest(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private DeleteNotebookRequest() { + tenant_ = ""; + id_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new DeleteNotebookRequest(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_DeleteNotebookRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_DeleteNotebookRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest.class, io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest.Builder.class); + } + + public static final int TENANT_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + @java.lang.Override + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int ID_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object id_ = ""; + /** + * string id = 2; + * @return The id. + */ + @java.lang.Override + public java.lang.String getId() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } + } + /** + * string id = 2; + * @return The bytes for id. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int VERSION_FIELD_NUMBER = 3; + private int version_ = 0; + /** + * int32 version = 3; + * @return The version. + */ + @java.lang.Override + public int getVersion() { + return version_; + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, id_); + } + if (version_ != 0) { + output.writeInt32(3, version_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(id_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, id_); + } + if (version_ != 0) { + size += com.google.protobuf.CodedOutputStream + .computeInt32Size(3, version_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest)) { + return super.equals(obj); + } + io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest other = (io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest) obj; + + if (!getTenant() + .equals(other.getTenant())) return false; + if (!getId() + .equals(other.getId())) return false; + if (getVersion() + != other.getVersion()) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + TENANT_FIELD_NUMBER; + hash = (53 * hash) + getTenant().hashCode(); + hash = (37 * hash) + ID_FIELD_NUMBER; + hash = (53 * hash) + getId().hashCode(); + hash = (37 * hash) + VERSION_FIELD_NUMBER; + hash = (53 * hash) + getVersion(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.DeleteNotebookRequest} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.DeleteNotebookRequest) + io.trino.spi.grpc.Trinomanager.DeleteNotebookRequestOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_DeleteNotebookRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_DeleteNotebookRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest.class, io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest.Builder.class); + } + + // Construct using io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + tenant_ = ""; + id_ = ""; + version_ = 0; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_DeleteNotebookRequest_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest getDefaultInstanceForType() { + return io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest build() { + io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest buildPartial() { + io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest result = new io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.tenant_ = tenant_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.id_ = id_; + } + if (((from_bitField0_ & 0x00000004) != 0)) { + result.version_ = version_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest) { + return mergeFrom((io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest other) { + if (other == io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest.getDefaultInstance()) return this; + if (!other.getTenant().isEmpty()) { + tenant_ = other.tenant_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getId().isEmpty()) { + id_ = other.id_; + bitField0_ |= 0x00000002; + onChanged(); + } + if (other.getVersion() != 0) { + setVersion(other.getVersion()); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + tenant_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + id_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + case 24: { + version_ = input.readInt32(); + bitField0_ |= 0x00000004; + break; + } // case 24 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant = 1; + * @param value The tenant to set. + * @return This builder for chaining. + */ + public Builder setTenant( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string tenant = 1; + * @return This builder for chaining. + */ + public Builder clearTenant() { + tenant_ = getDefaultInstance().getTenant(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string tenant = 1; + * @param value The bytes for tenant to set. + * @return This builder for chaining. + */ + public Builder setTenantBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object id_ = ""; + /** + * string id = 2; + * @return The id. + */ + public java.lang.String getId() { + java.lang.Object ref = id_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + id_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string id = 2; + * @return The bytes for id. + */ + public com.google.protobuf.ByteString + getIdBytes() { + java.lang.Object ref = id_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + id_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string id = 2; + * @param value The id to set. + * @return This builder for chaining. + */ + public Builder setId( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + id_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string id = 2; + * @return This builder for chaining. + */ + public Builder clearId() { + id_ = getDefaultInstance().getId(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string id = 2; + * @param value The bytes for id to set. + * @return This builder for chaining. + */ + public Builder setIdBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + id_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + + private int version_ ; + /** + * int32 version = 3; + * @return The version. + */ + @java.lang.Override + public int getVersion() { + return version_; + } + /** + * int32 version = 3; + * @param value The version to set. + * @return This builder for chaining. + */ + public Builder setVersion(int value) { + + version_ = value; + bitField0_ |= 0x00000004; + onChanged(); + return this; + } + /** + * int32 version = 3; + * @return This builder for chaining. + */ + public Builder clearVersion() { + bitField0_ = (bitField0_ & ~0x00000004); + version_ = 0; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.DeleteNotebookRequest) + } + + // @@protoc_insertion_point(class_scope:grpc.DeleteNotebookRequest) + private static final io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest(); + } + + public static io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public DeleteNotebookRequest parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.DeleteNotebookRequest getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + public interface TestConnectionRequestOrBuilder extends + // @@protoc_insertion_point(interface_extends:grpc.TestConnectionRequest) + com.google.protobuf.MessageOrBuilder { + + /** + * string tenant = 1; + * @return The tenant. + */ + java.lang.String getTenant(); + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + com.google.protobuf.ByteString + getTenantBytes(); + + /** + * string catalog = 2; + * @return The catalog. + */ + java.lang.String getCatalog(); + /** + * string catalog = 2; + * @return The bytes for catalog. + */ + com.google.protobuf.ByteString + getCatalogBytes(); + } + /** + * Protobuf type {@code grpc.TestConnectionRequest} + */ + public static final class TestConnectionRequest extends + com.google.protobuf.GeneratedMessageV3 implements + // @@protoc_insertion_point(message_implements:grpc.TestConnectionRequest) + TestConnectionRequestOrBuilder { + private static final long serialVersionUID = 0L; + // Use TestConnectionRequest.newBuilder() to construct. + private TestConnectionRequest(com.google.protobuf.GeneratedMessageV3.Builder builder) { + super(builder); + } + private TestConnectionRequest() { + tenant_ = ""; + catalog_ = ""; + } + + @java.lang.Override + @SuppressWarnings({"unused"}) + protected java.lang.Object newInstance( + UnusedPrivateParameter unused) { + return new TestConnectionRequest(); + } + + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_TestConnectionRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_TestConnectionRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.TestConnectionRequest.class, io.trino.spi.grpc.Trinomanager.TestConnectionRequest.Builder.class); + } + + public static final int TENANT_FIELD_NUMBER = 1; + @SuppressWarnings("serial") + private volatile java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + @java.lang.Override + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + public static final int CATALOG_FIELD_NUMBER = 2; + @SuppressWarnings("serial") + private volatile java.lang.Object catalog_ = ""; + /** + * string catalog = 2; + * @return The catalog. + */ + @java.lang.Override + public java.lang.String getCatalog() { + java.lang.Object ref = catalog_; + if (ref instanceof java.lang.String) { + return (java.lang.String) ref; + } else { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + catalog_ = s; + return s; + } + } + /** + * string catalog = 2; + * @return The bytes for catalog. + */ + @java.lang.Override + public com.google.protobuf.ByteString + getCatalogBytes() { + java.lang.Object ref = catalog_; + if (ref instanceof java.lang.String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + catalog_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + + private byte memoizedIsInitialized = -1; + @java.lang.Override + public final boolean isInitialized() { + byte isInitialized = memoizedIsInitialized; + if (isInitialized == 1) return true; + if (isInitialized == 0) return false; + + memoizedIsInitialized = 1; + return true; + } + + @java.lang.Override + public void writeTo(com.google.protobuf.CodedOutputStream output) + throws java.io.IOException { + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(catalog_)) { + com.google.protobuf.GeneratedMessageV3.writeString(output, 2, catalog_); + } + getUnknownFields().writeTo(output); + } + + @java.lang.Override + public int getSerializedSize() { + int size = memoizedSize; + if (size != -1) return size; + + size = 0; + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(tenant_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(1, tenant_); + } + if (!com.google.protobuf.GeneratedMessageV3.isStringEmpty(catalog_)) { + size += com.google.protobuf.GeneratedMessageV3.computeStringSize(2, catalog_); + } + size += getUnknownFields().getSerializedSize(); + memoizedSize = size; + return size; + } + + @java.lang.Override + public boolean equals(final java.lang.Object obj) { + if (obj == this) { + return true; + } + if (!(obj instanceof io.trino.spi.grpc.Trinomanager.TestConnectionRequest)) { + return super.equals(obj); + } + io.trino.spi.grpc.Trinomanager.TestConnectionRequest other = (io.trino.spi.grpc.Trinomanager.TestConnectionRequest) obj; + + if (!getTenant() + .equals(other.getTenant())) return false; + if (!getCatalog() + .equals(other.getCatalog())) return false; + if (!getUnknownFields().equals(other.getUnknownFields())) return false; + return true; + } + + @java.lang.Override + public int hashCode() { + if (memoizedHashCode != 0) { + return memoizedHashCode; + } + int hash = 41; + hash = (19 * hash) + getDescriptor().hashCode(); + hash = (37 * hash) + TENANT_FIELD_NUMBER; + hash = (53 * hash) + getTenant().hashCode(); + hash = (37 * hash) + CATALOG_FIELD_NUMBER; + hash = (53 * hash) + getCatalog().hashCode(); + hash = (29 * hash) + getUnknownFields().hashCode(); + memoizedHashCode = hash; + return hash; + } + + public static io.trino.spi.grpc.Trinomanager.TestConnectionRequest parseFrom( + java.nio.ByteBuffer data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.TestConnectionRequest parseFrom( + java.nio.ByteBuffer data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.TestConnectionRequest parseFrom( + com.google.protobuf.ByteString data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.TestConnectionRequest parseFrom( + com.google.protobuf.ByteString data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.TestConnectionRequest parseFrom(byte[] data) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data); + } + public static io.trino.spi.grpc.Trinomanager.TestConnectionRequest parseFrom( + byte[] data, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + return PARSER.parseFrom(data, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.TestConnectionRequest parseFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.TestConnectionRequest parseFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + public static io.trino.spi.grpc.Trinomanager.TestConnectionRequest parseDelimitedFrom(java.io.InputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input); + } + + public static io.trino.spi.grpc.Trinomanager.TestConnectionRequest parseDelimitedFrom( + java.io.InputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseDelimitedWithIOException(PARSER, input, extensionRegistry); + } + public static io.trino.spi.grpc.Trinomanager.TestConnectionRequest parseFrom( + com.google.protobuf.CodedInputStream input) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input); + } + public static io.trino.spi.grpc.Trinomanager.TestConnectionRequest parseFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + return com.google.protobuf.GeneratedMessageV3 + .parseWithIOException(PARSER, input, extensionRegistry); + } + + @java.lang.Override + public Builder newBuilderForType() { return newBuilder(); } + public static Builder newBuilder() { + return DEFAULT_INSTANCE.toBuilder(); + } + public static Builder newBuilder(io.trino.spi.grpc.Trinomanager.TestConnectionRequest prototype) { + return DEFAULT_INSTANCE.toBuilder().mergeFrom(prototype); + } + @java.lang.Override + public Builder toBuilder() { + return this == DEFAULT_INSTANCE + ? new Builder() : new Builder().mergeFrom(this); + } + + @java.lang.Override + protected Builder newBuilderForType( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + Builder builder = new Builder(parent); + return builder; + } + /** + * Protobuf type {@code grpc.TestConnectionRequest} + */ + public static final class Builder extends + com.google.protobuf.GeneratedMessageV3.Builder implements + // @@protoc_insertion_point(builder_implements:grpc.TestConnectionRequest) + io.trino.spi.grpc.Trinomanager.TestConnectionRequestOrBuilder { + public static final com.google.protobuf.Descriptors.Descriptor + getDescriptor() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_TestConnectionRequest_descriptor; + } + + @java.lang.Override + protected com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internalGetFieldAccessorTable() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_TestConnectionRequest_fieldAccessorTable + .ensureFieldAccessorsInitialized( + io.trino.spi.grpc.Trinomanager.TestConnectionRequest.class, io.trino.spi.grpc.Trinomanager.TestConnectionRequest.Builder.class); + } + + // Construct using io.trino.spi.grpc.Trinomanager.TestConnectionRequest.newBuilder() + private Builder() { + + } + + private Builder( + com.google.protobuf.GeneratedMessageV3.BuilderParent parent) { + super(parent); + + } + @java.lang.Override + public Builder clear() { + super.clear(); + bitField0_ = 0; + tenant_ = ""; + catalog_ = ""; + return this; + } + + @java.lang.Override + public com.google.protobuf.Descriptors.Descriptor + getDescriptorForType() { + return io.trino.spi.grpc.Trinomanager.internal_static_grpc_TestConnectionRequest_descriptor; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.TestConnectionRequest getDefaultInstanceForType() { + return io.trino.spi.grpc.Trinomanager.TestConnectionRequest.getDefaultInstance(); + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.TestConnectionRequest build() { + io.trino.spi.grpc.Trinomanager.TestConnectionRequest result = buildPartial(); + if (!result.isInitialized()) { + throw newUninitializedMessageException(result); + } + return result; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.TestConnectionRequest buildPartial() { + io.trino.spi.grpc.Trinomanager.TestConnectionRequest result = new io.trino.spi.grpc.Trinomanager.TestConnectionRequest(this); + if (bitField0_ != 0) { buildPartial0(result); } + onBuilt(); + return result; + } + + private void buildPartial0(io.trino.spi.grpc.Trinomanager.TestConnectionRequest result) { + int from_bitField0_ = bitField0_; + if (((from_bitField0_ & 0x00000001) != 0)) { + result.tenant_ = tenant_; + } + if (((from_bitField0_ & 0x00000002) != 0)) { + result.catalog_ = catalog_; + } + } + + @java.lang.Override + public Builder mergeFrom(com.google.protobuf.Message other) { + if (other instanceof io.trino.spi.grpc.Trinomanager.TestConnectionRequest) { + return mergeFrom((io.trino.spi.grpc.Trinomanager.TestConnectionRequest)other); + } else { + super.mergeFrom(other); + return this; + } + } + + public Builder mergeFrom(io.trino.spi.grpc.Trinomanager.TestConnectionRequest other) { + if (other == io.trino.spi.grpc.Trinomanager.TestConnectionRequest.getDefaultInstance()) return this; + if (!other.getTenant().isEmpty()) { + tenant_ = other.tenant_; + bitField0_ |= 0x00000001; + onChanged(); + } + if (!other.getCatalog().isEmpty()) { + catalog_ = other.catalog_; + bitField0_ |= 0x00000002; + onChanged(); + } + this.mergeUnknownFields(other.getUnknownFields()); + onChanged(); + return this; + } + + @java.lang.Override + public final boolean isInitialized() { + return true; + } + + @java.lang.Override + public Builder mergeFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws java.io.IOException { + if (extensionRegistry == null) { + throw new java.lang.NullPointerException(); + } + try { + boolean done = false; + while (!done) { + int tag = input.readTag(); + switch (tag) { + case 0: + done = true; + break; + case 10: { + tenant_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000001; + break; + } // case 10 + case 18: { + catalog_ = input.readStringRequireUtf8(); + bitField0_ |= 0x00000002; + break; + } // case 18 + default: { + if (!super.parseUnknownField(input, extensionRegistry, tag)) { + done = true; // was an endgroup tag + } + break; + } // default: + } // switch (tag) + } // while (!done) + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.unwrapIOException(); + } finally { + onChanged(); + } // finally + return this; + } + private int bitField0_; + + private java.lang.Object tenant_ = ""; + /** + * string tenant = 1; + * @return The tenant. + */ + public java.lang.String getTenant() { + java.lang.Object ref = tenant_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + tenant_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string tenant = 1; + * @return The bytes for tenant. + */ + public com.google.protobuf.ByteString + getTenantBytes() { + java.lang.Object ref = tenant_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + tenant_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string tenant = 1; + * @param value The tenant to set. + * @return This builder for chaining. + */ + public Builder setTenant( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + /** + * string tenant = 1; + * @return This builder for chaining. + */ + public Builder clearTenant() { + tenant_ = getDefaultInstance().getTenant(); + bitField0_ = (bitField0_ & ~0x00000001); + onChanged(); + return this; + } + /** + * string tenant = 1; + * @param value The bytes for tenant to set. + * @return This builder for chaining. + */ + public Builder setTenantBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + tenant_ = value; + bitField0_ |= 0x00000001; + onChanged(); + return this; + } + + private java.lang.Object catalog_ = ""; + /** + * string catalog = 2; + * @return The catalog. + */ + public java.lang.String getCatalog() { + java.lang.Object ref = catalog_; + if (!(ref instanceof java.lang.String)) { + com.google.protobuf.ByteString bs = + (com.google.protobuf.ByteString) ref; + java.lang.String s = bs.toStringUtf8(); + catalog_ = s; + return s; + } else { + return (java.lang.String) ref; + } + } + /** + * string catalog = 2; + * @return The bytes for catalog. + */ + public com.google.protobuf.ByteString + getCatalogBytes() { + java.lang.Object ref = catalog_; + if (ref instanceof String) { + com.google.protobuf.ByteString b = + com.google.protobuf.ByteString.copyFromUtf8( + (java.lang.String) ref); + catalog_ = b; + return b; + } else { + return (com.google.protobuf.ByteString) ref; + } + } + /** + * string catalog = 2; + * @param value The catalog to set. + * @return This builder for chaining. + */ + public Builder setCatalog( + java.lang.String value) { + if (value == null) { throw new NullPointerException(); } + catalog_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + /** + * string catalog = 2; + * @return This builder for chaining. + */ + public Builder clearCatalog() { + catalog_ = getDefaultInstance().getCatalog(); + bitField0_ = (bitField0_ & ~0x00000002); + onChanged(); + return this; + } + /** + * string catalog = 2; + * @param value The bytes for catalog to set. + * @return This builder for chaining. + */ + public Builder setCatalogBytes( + com.google.protobuf.ByteString value) { + if (value == null) { throw new NullPointerException(); } + checkByteStringIsUtf8(value); + catalog_ = value; + bitField0_ |= 0x00000002; + onChanged(); + return this; + } + @java.lang.Override + public final Builder setUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.setUnknownFields(unknownFields); + } + + @java.lang.Override + public final Builder mergeUnknownFields( + final com.google.protobuf.UnknownFieldSet unknownFields) { + return super.mergeUnknownFields(unknownFields); + } + + + // @@protoc_insertion_point(builder_scope:grpc.TestConnectionRequest) + } + + // @@protoc_insertion_point(class_scope:grpc.TestConnectionRequest) + private static final io.trino.spi.grpc.Trinomanager.TestConnectionRequest DEFAULT_INSTANCE; + static { + DEFAULT_INSTANCE = new io.trino.spi.grpc.Trinomanager.TestConnectionRequest(); + } + + public static io.trino.spi.grpc.Trinomanager.TestConnectionRequest getDefaultInstance() { + return DEFAULT_INSTANCE; + } + + private static final com.google.protobuf.Parser + PARSER = new com.google.protobuf.AbstractParser() { + @java.lang.Override + public TestConnectionRequest parsePartialFrom( + com.google.protobuf.CodedInputStream input, + com.google.protobuf.ExtensionRegistryLite extensionRegistry) + throws com.google.protobuf.InvalidProtocolBufferException { + Builder builder = newBuilder(); + try { + builder.mergeFrom(input, extensionRegistry); + } catch (com.google.protobuf.InvalidProtocolBufferException e) { + throw e.setUnfinishedMessage(builder.buildPartial()); + } catch (com.google.protobuf.UninitializedMessageException e) { + throw e.asInvalidProtocolBufferException().setUnfinishedMessage(builder.buildPartial()); + } catch (java.io.IOException e) { + throw new com.google.protobuf.InvalidProtocolBufferException(e) + .setUnfinishedMessage(builder.buildPartial()); + } + return builder.buildPartial(); + } + }; + + public static com.google.protobuf.Parser parser() { + return PARSER; + } + + @java.lang.Override + public com.google.protobuf.Parser getParserForType() { + return PARSER; + } + + @java.lang.Override + public io.trino.spi.grpc.Trinomanager.TestConnectionRequest getDefaultInstanceForType() { + return DEFAULT_INSTANCE; + } + + } + + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_Catalog_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_Catalog_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_Catalog_ParamsEntry_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_Catalog_ParamsEntry_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_View_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_View_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_SQLColumn_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_SQLColumn_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_Schema_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_Schema_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_NotebookCell_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_NotebookCell_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_DeleteNotebookCellReply_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_DeleteNotebookCellReply_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_Notebook_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_Notebook_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_NotebookMetadata_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_NotebookMetadata_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_QueryDetailsRequest_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_QueryDetailsRequest_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_QueryDetailsReply_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_QueryDetailsReply_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_ExpandQueryByDataSourceIDsRequest_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_ExpandQueryByDataSourceIDsRequest_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_ExpandQueryByDataSourceInstancesIDsRequest_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_ExpandQueryByDataSourceInstancesIDsRequest_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_ExpandedQueryReply_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_ExpandedQueryReply_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_DataSourceRequest_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_DataSourceRequest_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_ExecuteQueryNotebookMetadata_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_ExecuteQueryNotebookMetadata_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_ExecuteQueryRequest_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_ExecuteQueryRequest_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_ExecuteQueryReply_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_ExecuteQueryReply_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_TenantDataRequest_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_TenantDataRequest_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_WorkflowRunReply_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_WorkflowRunReply_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_NotebookCellCellConfig_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_NotebookCellCellConfig_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_CreateNotebookCellRequest_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_CreateNotebookCellRequest_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_DeleteNotebookCellRequest_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_DeleteNotebookCellRequest_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_EditNotebookCellRequest_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_EditNotebookCellRequest_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_GetNotebookCellRequest_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_GetNotebookCellRequest_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_GetNotebookRequest_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_GetNotebookRequest_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_CreateNotebookRequest_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_CreateNotebookRequest_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_EditNotebookRequest_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_EditNotebookRequest_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_DeleteNotebookRequest_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_DeleteNotebookRequest_fieldAccessorTable; + private static final com.google.protobuf.Descriptors.Descriptor + internal_static_grpc_TestConnectionRequest_descriptor; + private static final + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable + internal_static_grpc_TestConnectionRequest_fieldAccessorTable; + + public static com.google.protobuf.Descriptors.FileDescriptor + getDescriptor() { + return descriptor; + } + private static com.google.protobuf.Descriptors.FileDescriptor + descriptor; + static { + java.lang.String[] descriptorData = { + "\n\022trinomanager.proto\022\004grpc\032\033google/proto" + + "buf/empty.proto\"\231\001\n\007Catalog\022\014\n\004name\030\001 \001(" + + "\t\022\021\n\tconnector\030\002 \001(\t\022)\n\006params\030\003 \003(\0132\031.g" + + "rpc.Catalog.ParamsEntry\022\023\n\013tenant_name\030\004" + + " \001(\t\032-\n\013ParamsEntry\022\013\n\003key\030\001 \001(\t\022\r\n\005valu" + + "e\030\002 \001(\t:\0028\001\"v\n\004View\022\014\n\004name\030\001 \001(\t\022\021\n\tsql" + + "_query\030\002 \001(\t\022\016\n\006schema\030\003 \001(\t\022\022\n\nquery_ha" + + "sh\030\004 \001(\004\022\023\n\013tenant_name\030\005 \001(\t\022\024\n\014catalog" + + "_name\030\006 \001(\t\"\'\n\tSQLColumn\022\014\n\004name\030\001 \001(\t\022\014" + + "\n\004type\030\002 \001(\t\"\026\n\006Schema\022\014\n\004name\030\001 \001(\t\"\247\004\n" + + "\014NotebookCell\022\016\n\006tenant\030\001 \001(\t\022\n\n\002id\030\002 \001(" + + "\t\022\022\n\ncreated_at\030\003 \001(\003\022\022\n\nupdated_at\030\004 \001(" + + "\003\022\014\n\004name\030\005 \001(\t\022\021\n\tsql_query\030\006 \001(\t\022\022\n\005or" + + "der\030\007 \001(\005H\000\210\001\001\022-\n\010notebook\030\010 \001(\0132\026.grpc." + + "NotebookMetadataH\001\210\001\001\022)\n\034last_executed_t" + + "rino_qeury_id\030\t \001(\tH\002\210\001\001\022!\n\024last_executi" + + "on_state\030\n \001(\tH\003\210\001\001\022!\n\024last_execution_er" + + "ror\030\013 \001(\tH\004\210\001\001\022\035\n\020last_executed_at\030\014 \001(\003" + + "H\005\210\001\001\0225\n\ncellConfig\030\r \001(\0132\034.grpc.Noteboo" + + "kCellCellConfigH\006\210\001\001\022\032\n\022sql_query_expand" + + "ed\030\016 \001(\tB\010\n\006_orderB\013\n\t_notebookB\037\n\035_last" + + "_executed_trino_qeury_idB\027\n\025_last_execut" + + "ion_stateB\027\n\025_last_execution_errorB\023\n\021_l" + + "ast_executed_atB\r\n\013_cellConfig\"a\n\027Delete" + + "NotebookCellReply\022\n\n\002id\030\001 \001(\t\022-\n\010noteboo" + + "k\030\002 \001(\0132\026.grpc.NotebookMetadataH\000\210\001\001B\013\n\t" + + "_notebook\"\353\001\n\010Notebook\022\016\n\006tenant\030\001 \001(\t\022\n" + + "\n\002id\030\002 \001(\t\022\022\n\ncreated_at\030\003 \001(\003\022\022\n\nupdate" + + "d_at\030\004 \001(\003\022\r\n\005title\030\005 \001(\t\022\023\n\013description" + + "\030\006 \001(\t\022\017\n\007authors\030\007 \003(\t\022\017\n\007deleted\030\010 \001(\010" + + "\022\022\n\ndeleted_at\030\t \001(\003\022\017\n\007version\030\n \001(\005\022!\n" + + "\005cells\030\013 \003(\0132\022.grpc.NotebookCell\022\r\n\005owne" + + "r\030\014 \001(\t\"\210\001\n\020NotebookMetadata\022\016\n\006tenant\030\001" + + " \001(\t\022\n\n\002id\030\002 \001(\t\022\017\n\007version\030\003 \001(\005\022\022\n\nupd" + + "ated_at\030\004 \001(\003\022\r\n\005title\030\005 \001(\t\022\023\n\013descript" + + "ion\030\006 \001(\t\022\017\n\007authors\030\007 \003(\t\"<\n\023QueryDetai" + + "lsRequest\022\023\n\013tenant_name\030\001 \001(\t\022\020\n\010query_" + + "id\030\002 \001(\t\"w\n\021QueryDetailsReply\022\020\n\010query_i" + + "d\030\001 \001(\t\022\r\n\005state\030\002 \001(\005\022\032\n\rerror_message\030" + + "\003 \001(\tH\000\210\001\001\022\023\n\013tenant_name\030\004 \001(\tB\020\n\016_erro" + + "r_message\"`\n!ExpandQueryByDataSourceIDsR" + + "equest\022\027\n\017data_source_ids\030\001 \003(\t\022\r\n\005query" + + "\030\002 \001(\t\022\023\n\013tenant_name\030\003 \001(\t\"s\n*ExpandQue" + + "ryByDataSourceInstancesIDsRequest\022!\n\031dat" + + "a_source_instances_ids\030\001 \003(\t\022\r\n\005query\030\002 " + + "\001(\t\022\023\n\013tenant_name\030\003 \001(\t\"#\n\022ExpandedQuer" + + "yReply\022\r\n\005query\030\001 \001(\t\"6\n\021DataSourceReque" + + "st\022\014\n\004name\030\001 \001(\t\022\023\n\013storageName\030\002 \001(\t\"w\n" + + "\034ExecuteQueryNotebookMetadata\022\016\n\006tenant\030" + + "\001 \001(\t\022\023\n\013notebook_id\030\002 \001(\t\022\030\n\020notebook_v" + + "ersion\030\003 \001(\005\022\030\n\020notebook_cell_id\030\004 \001(\t\"\257" + + "\002\n\023ExecuteQueryRequest\022\023\n\013tenant_name\030\001 " + + "\001(\t\022\021\n\tsql_query\030\002 \001(\t\022\020\n\010query_id\030\003 \001(\t" + + "\022-\n\014data_sources\030\004 \003(\0132\027.grpc.DataSource" + + "Request\022B\n\021notebook_metadata\030\005 \001(\0132\".grp" + + "c.ExecuteQueryNotebookMetadataH\000\210\001\001\022\025\n\010t" + + "imespan\030\006 \001(\tH\001\210\001\001\022\035\n\025trino_header_query" + + "_id\030\007 \001(\t\022\022\n\nuser_email\030\010 \001(\tB\024\n\022_notebo" + + "ok_metadataB\013\n\t_timespan\"@\n\021ExecuteQuery" + + "Reply\022\r\n\005state\030\001 \001(\005\022\017\n\007columns\030\002 \003(\t\022\013\n" + + "\003row\030\003 \001(\t\"#\n\021TenantDataRequest\022\016\n\006tenan" + + "t\030\001 \001(\t\"\"\n\020WorkflowRunReply\022\016\n\006result\030\001 " + + "\001(\t\"F\n\026NotebookCellCellConfig\022,\n\013datasou" + + "rces\030\001 \003(\0132\027.grpc.DataSourceRequest\"\253\002\n\031" + + "CreateNotebookCellRequest\022\016\n\006tenant\030\001 \001(" + + "\t\022\014\n\004name\030\002 \001(\t\022\021\n\tsql_query\030\003 \001(\t\0221\n\013ce" + + "ll_config\030\004 \001(\0132\027.grpc.DataSourceRequest" + + "H\000\210\001\001\022\030\n\013notebook_id\030\005 \001(\tH\001\210\001\001\022\035\n\020noteb" + + "ook_version\030\006 \001(\005H\002\210\001\001\022\022\n\005order\030\007 \001(\005H\003\210" + + "\001\001\022\023\n\006author\030\010 \001(\tH\004\210\001\001B\016\n\014_cell_configB" + + "\016\n\014_notebook_idB\023\n\021_notebook_versionB\010\n\006" + + "_orderB\t\n\007_author\"\265\001\n\031DeleteNotebookCell" + + "Request\022\016\n\006tenant\030\001 \001(\t\022\n\n\002id\030\002 \001(\t\022\030\n\013n" + + "otebook_id\030\003 \001(\tH\000\210\001\001\022\035\n\020notebook_versio" + + "n\030\004 \001(\005H\001\210\001\001\022\023\n\006author\030\005 \001(\tH\002\210\001\001B\016\n\014_no" + + "tebook_idB\023\n\021_notebook_versionB\t\n\007_autho" + + "r\"\346\004\n\027EditNotebookCellRequest\022\016\n\006tenant\030" + + "\001 \001(\t\022\n\n\002id\030\002 \001(\t\022\023\n\013notebook_id\030\003 \001(\t\022\030" + + "\n\020notebook_version\030\004 \001(\005\022\021\n\004name\030\005 \001(\tH\000" + + "\210\001\001\022\026\n\tsql_query\030\006 \001(\tH\001\210\001\001\0226\n\013cell_conf" + + "ig\030\007 \001(\0132\034.grpc.NotebookCellCellConfigH\002" + + "\210\001\001\022!\n\024last_execution_state\030\010 \001(\005H\003\210\001\001\022\035" + + "\n\020last_executed_at\030\t \001(\003H\004\210\001\001\022!\n\024last_ex" + + "ecution_error\030\n \001(\tH\005\210\001\001\022)\n\034last_execute" + + "d_trino_qeury_id\030\013 \001(\tH\006\210\001\001\022\023\n\006author\030\014 " + + "\001(\tH\007\210\001\001\022!\n\024unexpanded_sql_query\030\r \001(\tH\010" + + "\210\001\001\022\025\n\010order_by\030\016 \001(\tH\t\210\001\001B\007\n\005_nameB\014\n\n_" + + "sql_queryB\016\n\014_cell_configB\027\n\025_last_execu" + + "tion_stateB\023\n\021_last_executed_atB\027\n\025_last" + + "_execution_errorB\037\n\035_last_executed_trino" + + "_qeury_idB\t\n\007_authorB\027\n\025_unexpanded_sql_" + + "queryB\013\n\t_order_by\":\n\026GetNotebookCellReq" + + "uest\022\016\n\006tenant\030\001 \001(\t\022\020\n\010query_id\030\002 \001(\t\"0" + + "\n\022GetNotebookRequest\022\016\n\006tenant\030\001 \001(\t\022\n\n\002" + + "id\030\002 \001(\t\"j\n\025CreateNotebookRequest\022\016\n\006ten" + + "ant\030\001 \001(\t\022\r\n\005title\030\002 \001(\t\022\023\n\013description\030" + + "\003 \001(\t\022\016\n\006author\030\004 \001(\t\022\r\n\005owner\030\005 \001(\t\"\232\001\n" + + "\023EditNotebookRequest\022\016\n\006tenant\030\001 \001(\t\022\n\n\002" + + "id\030\002 \001(\t\022\022\n\005title\030\003 \001(\tH\000\210\001\001\022\030\n\013descript" + + "ion\030\004 \001(\tH\001\210\001\001\022\016\n\006author\030\005 \001(\t\022\017\n\007versio" + + "n\030\006 \001(\005B\010\n\006_titleB\016\n\014_description\"D\n\025Del" + + "eteNotebookRequest\022\016\n\006tenant\030\001 \001(\t\022\n\n\002id" + + "\030\002 \001(\t\022\017\n\007version\030\003 \001(\005\"8\n\025TestConnectio" + + "nRequest\022\016\n\006tenant\030\001 \001(\t\022\017\n\007catalog\030\002 \001(" + + "\t2\344\t\n\023TrinoManagerService\022A\n\tQueryInfo\022\031" + + ".grpc.QueryDetailsRequest\032\027.grpc.QueryDe" + + "tailsReply\"\000\022C\n\tSyncQuery\022\031.grpc.Execute" + + "QueryRequest\032\027.grpc.ExecuteQueryReply\"\0000" + + "\001\0228\n\013GetCatalogs\022\026.google.protobuf.Empty" + + "\032\r.grpc.Catalog\"\0000\001\0222\n\010GetViews\022\026.google" + + ".protobuf.Empty\032\n.grpc.View\"\0000\001\022K\n\022Creat" + + "eNotebookCell\022\037.grpc.CreateNotebookCellR" + + "equest\032\022.grpc.NotebookCell\"\000\022V\n\022DeleteNo" + + "tebookCell\022\037.grpc.DeleteNotebookCellRequ" + + "est\032\035.grpc.DeleteNotebookCellReply\"\000\022G\n\020" + + "EditNotebookCell\022\035.grpc.EditNotebookCell" + + "Request\032\022.grpc.NotebookCell\"\000\022C\n\020GetNote" + + "bookCells\022\027.grpc.TenantDataRequest\032\022.grp" + + "c.NotebookCell\"\0000\001\022E\n\017GetNotebookCell\022\034." + + "grpc.GetNotebookCellRequest\032\022.grpc.Noteb" + + "ookCell\"\000\022;\n\014GetNotebooks\022\027.grpc.TenantD" + + "ataRequest\032\016.grpc.Notebook\"\0000\001\0229\n\013GetNot" + + "ebook\022\030.grpc.GetNotebookRequest\032\016.grpc.N" + + "otebook\"\000\022?\n\016CreateNotebook\022\033.grpc.Creat" + + "eNotebookRequest\032\016.grpc.Notebook\"\000\022G\n\016De" + + "leteNotebook\022\033.grpc.DeleteNotebookReques" + + "t\032\026.google.protobuf.Empty\"\000\022;\n\014EditNoteb" + + "ook\022\031.grpc.EditNotebookRequest\032\016.grpc.No" + + "tebook\"\000\022G\n\016TestConnection\022\033.grpc.TestCo" + + "nnectionRequest\032\026.google.protobuf.Empty\"" + + "\000\022a\n\032ExpandQueryByDataSourceIDs\022\'.grpc.E" + + "xpandQueryByDataSourceIDsRequest\032\030.grpc." + + "ExpandedQueryReply\"\000\022r\n\"ExpandQueryByDat" + + "aSourceInstanceIDs\0220.grpc.ExpandQueryByD" + + "ataSourceInstancesIDsRequest\032\030.grpc.Expa" + + "ndedQueryReply\"\000B\033\n\021io.trino.spi.grpcZ\006." + + ";grpcb\006proto3" + }; + descriptor = com.google.protobuf.Descriptors.FileDescriptor + .internalBuildGeneratedFileFrom(descriptorData, + new com.google.protobuf.Descriptors.FileDescriptor[] { + com.google.protobuf.EmptyProto.getDescriptor(), + }); + internal_static_grpc_Catalog_descriptor = + getDescriptor().getMessageTypes().get(0); + internal_static_grpc_Catalog_fieldAccessorTable = new + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable( + internal_static_grpc_Catalog_descriptor, + new java.lang.String[] { "Name", "Connector", "Params", "TenantName", }); + internal_static_grpc_Catalog_ParamsEntry_descriptor = + internal_static_grpc_Catalog_descriptor.getNestedTypes().get(0); + internal_static_grpc_Catalog_ParamsEntry_fieldAccessorTable = new + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable( + internal_static_grpc_Catalog_ParamsEntry_descriptor, + new java.lang.String[] { "Key", "Value", }); + internal_static_grpc_View_descriptor = + getDescriptor().getMessageTypes().get(1); + internal_static_grpc_View_fieldAccessorTable = new + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable( + internal_static_grpc_View_descriptor, + new java.lang.String[] { "Name", "SqlQuery", "Schema", "QueryHash", "TenantName", "CatalogName", }); + internal_static_grpc_SQLColumn_descriptor = + getDescriptor().getMessageTypes().get(2); + internal_static_grpc_SQLColumn_fieldAccessorTable = new + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable( + internal_static_grpc_SQLColumn_descriptor, + new java.lang.String[] { "Name", "Type", }); + internal_static_grpc_Schema_descriptor = + getDescriptor().getMessageTypes().get(3); + internal_static_grpc_Schema_fieldAccessorTable = new + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable( + internal_static_grpc_Schema_descriptor, + new java.lang.String[] { "Name", }); + internal_static_grpc_NotebookCell_descriptor = + getDescriptor().getMessageTypes().get(4); + internal_static_grpc_NotebookCell_fieldAccessorTable = new + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable( + internal_static_grpc_NotebookCell_descriptor, + new java.lang.String[] { "Tenant", "Id", "CreatedAt", "UpdatedAt", "Name", "SqlQuery", "Order", "Notebook", "LastExecutedTrinoQeuryId", "LastExecutionState", "LastExecutionError", "LastExecutedAt", "CellConfig", "SqlQueryExpanded", "Order", "Notebook", "LastExecutedTrinoQeuryId", "LastExecutionState", "LastExecutionError", "LastExecutedAt", "CellConfig", }); + internal_static_grpc_DeleteNotebookCellReply_descriptor = + getDescriptor().getMessageTypes().get(5); + internal_static_grpc_DeleteNotebookCellReply_fieldAccessorTable = new + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable( + internal_static_grpc_DeleteNotebookCellReply_descriptor, + new java.lang.String[] { "Id", "Notebook", "Notebook", }); + internal_static_grpc_Notebook_descriptor = + getDescriptor().getMessageTypes().get(6); + internal_static_grpc_Notebook_fieldAccessorTable = new + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable( + internal_static_grpc_Notebook_descriptor, + new java.lang.String[] { "Tenant", "Id", "CreatedAt", "UpdatedAt", "Title", "Description", "Authors", "Deleted", "DeletedAt", "Version", "Cells", "Owner", }); + internal_static_grpc_NotebookMetadata_descriptor = + getDescriptor().getMessageTypes().get(7); + internal_static_grpc_NotebookMetadata_fieldAccessorTable = new + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable( + internal_static_grpc_NotebookMetadata_descriptor, + new java.lang.String[] { "Tenant", "Id", "Version", "UpdatedAt", "Title", "Description", "Authors", }); + internal_static_grpc_QueryDetailsRequest_descriptor = + getDescriptor().getMessageTypes().get(8); + internal_static_grpc_QueryDetailsRequest_fieldAccessorTable = new + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable( + internal_static_grpc_QueryDetailsRequest_descriptor, + new java.lang.String[] { "TenantName", "QueryId", }); + internal_static_grpc_QueryDetailsReply_descriptor = + getDescriptor().getMessageTypes().get(9); + internal_static_grpc_QueryDetailsReply_fieldAccessorTable = new + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable( + internal_static_grpc_QueryDetailsReply_descriptor, + new java.lang.String[] { "QueryId", "State", "ErrorMessage", "TenantName", "ErrorMessage", }); + internal_static_grpc_ExpandQueryByDataSourceIDsRequest_descriptor = + getDescriptor().getMessageTypes().get(10); + internal_static_grpc_ExpandQueryByDataSourceIDsRequest_fieldAccessorTable = new + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable( + internal_static_grpc_ExpandQueryByDataSourceIDsRequest_descriptor, + new java.lang.String[] { "DataSourceIds", "Query", "TenantName", }); + internal_static_grpc_ExpandQueryByDataSourceInstancesIDsRequest_descriptor = + getDescriptor().getMessageTypes().get(11); + internal_static_grpc_ExpandQueryByDataSourceInstancesIDsRequest_fieldAccessorTable = new + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable( + internal_static_grpc_ExpandQueryByDataSourceInstancesIDsRequest_descriptor, + new java.lang.String[] { "DataSourceInstancesIds", "Query", "TenantName", }); + internal_static_grpc_ExpandedQueryReply_descriptor = + getDescriptor().getMessageTypes().get(12); + internal_static_grpc_ExpandedQueryReply_fieldAccessorTable = new + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable( + internal_static_grpc_ExpandedQueryReply_descriptor, + new java.lang.String[] { "Query", }); + internal_static_grpc_DataSourceRequest_descriptor = + getDescriptor().getMessageTypes().get(13); + internal_static_grpc_DataSourceRequest_fieldAccessorTable = new + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable( + internal_static_grpc_DataSourceRequest_descriptor, + new java.lang.String[] { "Name", "StorageName", }); + internal_static_grpc_ExecuteQueryNotebookMetadata_descriptor = + getDescriptor().getMessageTypes().get(14); + internal_static_grpc_ExecuteQueryNotebookMetadata_fieldAccessorTable = new + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable( + internal_static_grpc_ExecuteQueryNotebookMetadata_descriptor, + new java.lang.String[] { "Tenant", "NotebookId", "NotebookVersion", "NotebookCellId", }); + internal_static_grpc_ExecuteQueryRequest_descriptor = + getDescriptor().getMessageTypes().get(15); + internal_static_grpc_ExecuteQueryRequest_fieldAccessorTable = new + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable( + internal_static_grpc_ExecuteQueryRequest_descriptor, + new java.lang.String[] { "TenantName", "SqlQuery", "QueryId", "DataSources", "NotebookMetadata", "Timespan", "TrinoHeaderQueryId", "UserEmail", "NotebookMetadata", "Timespan", }); + internal_static_grpc_ExecuteQueryReply_descriptor = + getDescriptor().getMessageTypes().get(16); + internal_static_grpc_ExecuteQueryReply_fieldAccessorTable = new + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable( + internal_static_grpc_ExecuteQueryReply_descriptor, + new java.lang.String[] { "State", "Columns", "Row", }); + internal_static_grpc_TenantDataRequest_descriptor = + getDescriptor().getMessageTypes().get(17); + internal_static_grpc_TenantDataRequest_fieldAccessorTable = new + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable( + internal_static_grpc_TenantDataRequest_descriptor, + new java.lang.String[] { "Tenant", }); + internal_static_grpc_WorkflowRunReply_descriptor = + getDescriptor().getMessageTypes().get(18); + internal_static_grpc_WorkflowRunReply_fieldAccessorTable = new + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable( + internal_static_grpc_WorkflowRunReply_descriptor, + new java.lang.String[] { "Result", }); + internal_static_grpc_NotebookCellCellConfig_descriptor = + getDescriptor().getMessageTypes().get(19); + internal_static_grpc_NotebookCellCellConfig_fieldAccessorTable = new + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable( + internal_static_grpc_NotebookCellCellConfig_descriptor, + new java.lang.String[] { "Datasources", }); + internal_static_grpc_CreateNotebookCellRequest_descriptor = + getDescriptor().getMessageTypes().get(20); + internal_static_grpc_CreateNotebookCellRequest_fieldAccessorTable = new + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable( + internal_static_grpc_CreateNotebookCellRequest_descriptor, + new java.lang.String[] { "Tenant", "Name", "SqlQuery", "CellConfig", "NotebookId", "NotebookVersion", "Order", "Author", "CellConfig", "NotebookId", "NotebookVersion", "Order", "Author", }); + internal_static_grpc_DeleteNotebookCellRequest_descriptor = + getDescriptor().getMessageTypes().get(21); + internal_static_grpc_DeleteNotebookCellRequest_fieldAccessorTable = new + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable( + internal_static_grpc_DeleteNotebookCellRequest_descriptor, + new java.lang.String[] { "Tenant", "Id", "NotebookId", "NotebookVersion", "Author", "NotebookId", "NotebookVersion", "Author", }); + internal_static_grpc_EditNotebookCellRequest_descriptor = + getDescriptor().getMessageTypes().get(22); + internal_static_grpc_EditNotebookCellRequest_fieldAccessorTable = new + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable( + internal_static_grpc_EditNotebookCellRequest_descriptor, + new java.lang.String[] { "Tenant", "Id", "NotebookId", "NotebookVersion", "Name", "SqlQuery", "CellConfig", "LastExecutionState", "LastExecutedAt", "LastExecutionError", "LastExecutedTrinoQeuryId", "Author", "UnexpandedSqlQuery", "OrderBy", "Name", "SqlQuery", "CellConfig", "LastExecutionState", "LastExecutedAt", "LastExecutionError", "LastExecutedTrinoQeuryId", "Author", "UnexpandedSqlQuery", "OrderBy", }); + internal_static_grpc_GetNotebookCellRequest_descriptor = + getDescriptor().getMessageTypes().get(23); + internal_static_grpc_GetNotebookCellRequest_fieldAccessorTable = new + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable( + internal_static_grpc_GetNotebookCellRequest_descriptor, + new java.lang.String[] { "Tenant", "QueryId", }); + internal_static_grpc_GetNotebookRequest_descriptor = + getDescriptor().getMessageTypes().get(24); + internal_static_grpc_GetNotebookRequest_fieldAccessorTable = new + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable( + internal_static_grpc_GetNotebookRequest_descriptor, + new java.lang.String[] { "Tenant", "Id", }); + internal_static_grpc_CreateNotebookRequest_descriptor = + getDescriptor().getMessageTypes().get(25); + internal_static_grpc_CreateNotebookRequest_fieldAccessorTable = new + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable( + internal_static_grpc_CreateNotebookRequest_descriptor, + new java.lang.String[] { "Tenant", "Title", "Description", "Author", "Owner", }); + internal_static_grpc_EditNotebookRequest_descriptor = + getDescriptor().getMessageTypes().get(26); + internal_static_grpc_EditNotebookRequest_fieldAccessorTable = new + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable( + internal_static_grpc_EditNotebookRequest_descriptor, + new java.lang.String[] { "Tenant", "Id", "Title", "Description", "Author", "Version", "Title", "Description", }); + internal_static_grpc_DeleteNotebookRequest_descriptor = + getDescriptor().getMessageTypes().get(27); + internal_static_grpc_DeleteNotebookRequest_fieldAccessorTable = new + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable( + internal_static_grpc_DeleteNotebookRequest_descriptor, + new java.lang.String[] { "Tenant", "Id", "Version", }); + internal_static_grpc_TestConnectionRequest_descriptor = + getDescriptor().getMessageTypes().get(28); + internal_static_grpc_TestConnectionRequest_fieldAccessorTable = new + com.google.protobuf.GeneratedMessageV3.FieldAccessorTable( + internal_static_grpc_TestConnectionRequest_descriptor, + new java.lang.String[] { "Tenant", "Catalog", }); + com.google.protobuf.EmptyProto.getDescriptor(); + } + + // @@protoc_insertion_point(outer_class_scope) +} diff --git a/trino_hash.txt b/trino_hash.txt new file mode 100644 index 000000000000..21fabd103830 --- /dev/null +++ b/trino_hash.txt @@ -0,0 +1 @@ +a0e60fd0ddf13ee5c0a9f08d67ee6550828e9fd6a76c40e12d2961d1395c4208